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

A

ABORTED - org.infinispan.transaction.impl.TransactionTable.CompletedTransactionStatus
 
AbstractCacheEventFilterConverter<K,​V,​C> - Class in org.infinispan.notifications.cachelistener.filter
AbstractCacheEventFilterConverter() - Constructor for class org.infinispan.notifications.cachelistener.filter.AbstractCacheEventFilterConverter
 
AbstractCacheStream<Original,​T,​S extends BaseStream<T,​S>,​S2 extends S> - Class in org.infinispan.stream.impl
Abstract stream that provides all of the common functionality required for all types of Streams including the various primitive types.
AbstractCacheStream(Address, boolean, DistributionManager, Supplier<CacheStream<Original>>, ClusterStreamManager<Original, Object>, boolean, int, Executor, ComponentRegistry, Function<? super Original, ?>) - Constructor for class org.infinispan.stream.impl.AbstractCacheStream
 
AbstractCacheStream(AbstractCacheStream<Original, T, S, S2>) - Constructor for class org.infinispan.stream.impl.AbstractCacheStream
 
AbstractCacheStream.MapOpsExternalizer - Class in org.infinispan.stream.impl
 
AbstractCacheTransaction - Class in org.infinispan.transaction.impl
Base class for local and remote transaction.
AbstractCacheTransaction(GlobalTransaction, int, long) - Constructor for class org.infinispan.transaction.impl.AbstractCacheTransaction
 
AbstractCloseableIteratorCollection<O,​K,​V> - Class in org.infinispan.commands.read
Abstract collection that uses an underlying Cache instance to do various operations.
AbstractCloseableIteratorCollection(Cache<K, V>) - Constructor for class org.infinispan.commands.read.AbstractCloseableIteratorCollection
 
AbstractClusteringDependentLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
AbstractClusterStats - Class in org.infinispan.stats.impl
 
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
 
AbstractComponentRegistry - Class in org.infinispan.factories
Deprecated.
Since 9.4, please use BasicComponentRegistry instead.
AbstractComponentRegistry(ComponentMetadataRepo, ClassLoader, Scopes, BasicComponentRegistry) - Constructor for class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
AbstractComponentRegistry.Component - Class in org.infinispan.factories
Deprecated.
A wrapper representing a component in the registry
AbstractConsistentHash - Class in org.infinispan.distribution.ch.impl
 
AbstractConsistentHash(Hash, int, List<Address>, float[]) - Constructor for class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
AbstractConsistentHash(Hash, int, List<Address>, Map<Address, Float>) - Constructor for class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
AbstractConsistentHash(ScopedPersistentState) - Constructor for class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
AbstractConsistentHashFactory<CH extends ConsistentHash> - Class in org.infinispan.distribution.ch.impl
 
AbstractConsistentHashFactory() - Constructor for class org.infinispan.distribution.ch.impl.AbstractConsistentHashFactory
 
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() - Constructor for class org.infinispan.commands.read.AbstractDataCommand
 
AbstractDataCommand(Object, int, long) - 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, int, long, CommandInvocationId) - Constructor for class org.infinispan.commands.write.AbstractDataWriteCommand
 
AbstractDelegatingAdvancedCache<K,​V> - Class in org.infinispan
Deprecated.
Extend from AbstractDelegatingAdvancedCache instead. This class will be removed in the future.
AbstractDelegatingAdvancedCache<K,​V> - Class in org.infinispan.cache.impl
AbstractDelegatingAdvancedCache(AdvancedCache<K, V>) - Constructor for class org.infinispan.AbstractDelegatingAdvancedCache
Deprecated.
 
AbstractDelegatingAdvancedCache(AdvancedCache<K, V>) - Constructor for class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
AbstractDelegatingAdvancedCache(AdvancedCache<K, V>, AbstractDelegatingAdvancedCache.AdvancedCacheWrapper<K, V>) - Constructor for class org.infinispan.AbstractDelegatingAdvancedCache
Deprecated.
 
AbstractDelegatingAdvancedCache(AdvancedCache<K, V>, AbstractDelegatingAdvancedCache.AdvancedCacheWrapper<K, V>) - Constructor for class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
AbstractDelegatingAdvancedCache.AdvancedCacheWrapper<K,​V> - Interface in org.infinispan.cache.impl
 
AbstractDelegatingCache<K,​V> - Class in org.infinispan
Deprecated.
Extend from AbstractDelegatingCache instead. This class will be removed in the future.
AbstractDelegatingCache<K,​V> - Class in org.infinispan.cache.impl
This is a convenient base class for implementing a cache delegate.
AbstractDelegatingCache(Cache<K, V>) - Constructor for class org.infinispan.AbstractDelegatingCache
Deprecated.
 
AbstractDelegatingCache(Cache<K, V>) - Constructor for class org.infinispan.cache.impl.AbstractDelegatingCache
 
AbstractDelegatingCacheCollection<E> - Class in org.infinispan.util
 
AbstractDelegatingCacheCollection() - Constructor for class org.infinispan.util.AbstractDelegatingCacheCollection
 
AbstractDelegatingCacheSet<E> - Class in org.infinispan.util
Same as AbstractDelegatingCacheCollection except this method implements Set as well.
AbstractDelegatingCacheSet() - Constructor for class org.infinispan.util.AbstractDelegatingCacheSet
 
AbstractDelegatingCacheStream<R> - Class in org.infinispan.util
Delegate that forwards all the of the method calls to the underlying cache stream.
AbstractDelegatingCacheStream(CacheStream<R>) - Constructor for class org.infinispan.util.AbstractDelegatingCacheStream
 
AbstractDelegatingCloseableIteratorCollection<E> - Class in org.infinispan.util
Delegating collection that produces closeable iterators and spliterators from the collection returned from AbstractDelegatingCloseableIteratorCollection.delegate() method.
AbstractDelegatingCloseableIteratorCollection() - Constructor for class org.infinispan.util.AbstractDelegatingCloseableIteratorCollection
 
AbstractDelegatingCloseableIteratorSet<E> - Class in org.infinispan.util
 
AbstractDelegatingCloseableIteratorSet() - Constructor for class org.infinispan.util.AbstractDelegatingCloseableIteratorSet
 
AbstractDelegatingDataContainer<K,​V> - Class in org.infinispan.container.impl
Delegating data container that delegates all calls to the container returned from AbstractDelegatingDataContainer.delegate()
AbstractDelegatingDataContainer() - Constructor for class org.infinispan.container.impl.AbstractDelegatingDataContainer
 
AbstractDelegatingEmbeddedCacheManager - Class in org.infinispan.manager
Deprecated.
Extend from AbstractDelegatingEmbeddedCacheManager instead. This class will be removed in the future.
AbstractDelegatingEmbeddedCacheManager - Class in org.infinispan.manager.impl
This is a convenient base class for implementing a cache manager delegate.
AbstractDelegatingEmbeddedCacheManager(EmbeddedCacheManager) - Constructor for class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
Deprecated.
 
AbstractDelegatingEmbeddedCacheManager(EmbeddedCacheManager) - Constructor for class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
AbstractDelegatingEntryCacheSet<K,​V> - Class in org.infinispan.stream.impl.interceptor
Abstract cache entry set that delegates to the underlying cache for stream usage
AbstractDelegatingEntryCacheSet(Cache<K, V>, CacheSet<CacheEntry<K, V>>) - Constructor for class org.infinispan.stream.impl.interceptor.AbstractDelegatingEntryCacheSet
 
AbstractDelegatingHandler - Class in org.infinispan.remoting.inboundhandler
Class to be extended to allow some control over the PerCacheInboundInvocationHandler in tests.
AbstractDelegatingHandler(PerCacheInboundInvocationHandler) - Constructor for class org.infinispan.remoting.inboundhandler.AbstractDelegatingHandler
 
AbstractDelegatingInternalDataContainer<K,​V> - Class in org.infinispan.container.impl
 
AbstractDelegatingInternalDataContainer() - Constructor for class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
AbstractDelegatingKeyCacheSet<K,​V> - Class in org.infinispan.stream.impl.interceptor
Abstract cache key set that delegates to the underlying cache for stream usage
AbstractDelegatingKeyCacheSet(Cache<K, V>, CacheSet<K>) - Constructor for class org.infinispan.stream.impl.interceptor.AbstractDelegatingKeyCacheSet
 
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.impl
Base class for both Sync and XAResource enlistment adapters.
AbstractEnlistmentAdapter() - Constructor for class org.infinispan.transaction.impl.AbstractEnlistmentAdapter
 
AbstractEnlistmentAdapter(CacheTransaction) - Constructor for class org.infinispan.transaction.impl.AbstractEnlistmentAdapter
 
AbstractFlagAffectedCommand - Class in org.infinispan.commands
Base class for those commands that can carry flags.
AbstractFlagAffectedCommand() - Constructor for class org.infinispan.commands.AbstractFlagAffectedCommand
 
AbstractForEachDoubleOperation<Original,​K> - Class in org.infinispan.stream.impl.termop.primitive
Terminal rehash aware operation that handles for each where no flat map operations are defined on a DoubleStream.
AbstractForEachDoubleOperation(Iterable<IntermediateOperation>, Supplier<Stream<Original>>, Function<? super Original, ? extends K>, int) - Constructor for class org.infinispan.stream.impl.termop.primitive.AbstractForEachDoubleOperation
 
AbstractForEachIntOperation<Original,​K> - Class in org.infinispan.stream.impl.termop.primitive
Terminal rehash aware operation that handles for each where no flat map operations are defined on a IntStream.
AbstractForEachIntOperation(Iterable<IntermediateOperation>, Supplier<Stream<Original>>, Function<? super Original, ? extends K>, int) - Constructor for class org.infinispan.stream.impl.termop.primitive.AbstractForEachIntOperation
 
AbstractForEachLongOperation<Original,​K> - Class in org.infinispan.stream.impl.termop.primitive
Terminal rehash aware operation that handles for each where no flat map operations are defined on a LongStream.
AbstractForEachLongOperation(Iterable<IntermediateOperation>, Supplier<Stream<Original>>, Function<? super Original, ? extends K>, int) - Constructor for class org.infinispan.stream.impl.termop.primitive.AbstractForEachLongOperation
 
AbstractForEachOperation<Original,​K,​V,​S extends BaseStream<V,​S>> - Class in org.infinispan.stream.impl.termop
This is a base operation class for the use of the for each terminal operator.
AbstractForEachOperation(Iterable<IntermediateOperation>, Supplier<Stream<Original>>, Function<? super Original, ? extends K>, int) - Constructor for class org.infinispan.stream.impl.termop.AbstractForEachOperation
 
AbstractGlobalModuleConfigurationBuilder - 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
 
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
 
AbstractInternalDataContainer<K,​V> - Class in org.infinispan.container.impl
Abstract class implemenation for a segmented data container.
AbstractInternalDataContainer() - Constructor for class org.infinispan.container.impl.AbstractInternalDataContainer
 
AbstractInternalDataContainer.EntryIterator - Class in org.infinispan.container.impl
 
AbstractInternalDataContainer.Values - Class in org.infinispan.container.impl
Deprecated.
This is to removed when AbstractInternalDataContainer.entrySet() is removed
AbstractInvocationBuilder() - Constructor for class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
AbstractInvocationContext - Class in org.infinispan.context.impl
Common features of transaction and invocation contexts
AbstractInvocationContext(Address) - Constructor for class org.infinispan.context.impl.AbstractInvocationContext
 
AbstractInvocationContextFactory - Class in org.infinispan.context
Deprecated.
Since 9.0, this class is going to be moved to an internal package.
AbstractInvocationContextFactory() - Constructor for class org.infinispan.context.AbstractInvocationContextFactory
Deprecated.
 
AbstractJmxRegistration - Class in org.infinispan.jmx
Parent class for top level JMX component registration.
AbstractJmxRegistration() - Constructor for class org.infinispan.jmx.AbstractJmxRegistration
 
AbstractKeyValueFilterConverter<K,​V,​C> - Class in org.infinispan.filter
This is a base class that should be used when implementing a KeyValueFilterConverter that provides default implementations for the KeyValueFilter.accept(Object, Object, org.infinispan.metadata.Metadata) and Converter.convert(Object, Object, org.infinispan.metadata.Metadata) methods so they just call the KeyValueFilterConverter.filterAndConvert(Object, Object, org.infinispan.metadata.Metadata) method and then do the right thing.
AbstractKeyValueFilterConverter() - Constructor for class org.infinispan.filter.AbstractKeyValueFilterConverter
 
AbstractListenerImpl<T,​L extends ListenerInvocation<T>> - Class in org.infinispan.notifications.impl
Functionality common to both CacheManagerNotifierImpl and CacheNotifierImpl
AbstractListenerImpl() - Constructor for class org.infinispan.notifications.impl.AbstractListenerImpl
 
AbstractListenerImpl.AbstractInvocationBuilder - Class in org.infinispan.notifications.impl
 
AbstractListenerImpl.ListenerInvocationImpl<A> - Class in org.infinispan.notifications.impl
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.
AbstractLocalCacheStream<T,​S extends BaseStream<T,​S>,​S2 extends S> - Class in org.infinispan.stream.impl.local
Implements the base operations required for a local stream.
AbstractLocalCacheStream(AbstractLocalCacheStream.StreamSupplier<T, S>, boolean, ComponentRegistry) - Constructor for class org.infinispan.stream.impl.local.AbstractLocalCacheStream
 
AbstractLocalCacheStream.StreamSupplier<T,​S extends BaseStream<T,​S>> - Interface in org.infinispan.stream.impl.local
 
AbstractLocalCommand - Class in org.infinispan.commands.read
Abstract class
AbstractLocalCommand() - Constructor for class org.infinispan.commands.read.AbstractLocalCommand
 
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
 
AbstractMixedSiteStatus<E> - Class in org.infinispan.xsite.status
Abstract class to create mixed SiteStatus.
AbstractMixedSiteStatus(Collection<E>, Collection<E>) - Constructor for class org.infinispan.xsite.status.AbstractMixedSiteStatus
 
AbstractModuleConfigurationBuilder - Class in org.infinispan.configuration.cache
AbstractModuleConfigurationBuilder.
AbstractModuleConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
 
AbstractModuleLifecycle - Class in org.infinispan.lifecycle
Deprecated.
since 9.1. Just implement ModuleLifecycle instead.
AbstractModuleLifecycle() - Constructor for class org.infinispan.lifecycle.AbstractModuleLifecycle
Deprecated.
 
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
 
AbstractPersistenceConfigurationChildBuilder - Class in org.infinispan.configuration.cache
AbstractPersistenceConfigurationChildBuilder.
AbstractPersistenceConfigurationChildBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractPersistenceConfigurationChildBuilder
 
AbstractRehashPublisherDecorator<S> - Class in org.infinispan.stream.impl
Abstract publisher decorator that is used to notify segment listener of loss of segments while entries are being retrieved.
AbstractRequest<T> - Class in org.infinispan.remoting.transport
A remote invocation request.
AbstractRequest(long, ResponseCollector<T>, RequestRepository) - Constructor for class org.infinispan.remoting.transport.AbstractRequest
 
AbstractSegmentedAdvancedLoadWriteStore<K,​V> - Class in org.infinispan.persistence.support
Abstract segment loader writer that implements all the single key non segmented methods by invoking the segmented equivalent by passing in the segment returned from invoking AbstractSegmentedAdvancedLoadWriteStore.getKeyMapper().
AbstractSegmentedAdvancedLoadWriteStore() - Constructor for class org.infinispan.persistence.support.AbstractSegmentedAdvancedLoadWriteStore
 
AbstractSegmentedStoreConfiguration<T extends AbstractStoreConfiguration> - Class in org.infinispan.configuration.cache
Abstract store configuration that should be extended when the store configuration supports being segmented.
AbstractSegmentedStoreConfiguration(AttributeSet, AsyncStoreConfiguration, SingletonStoreConfiguration) - Constructor for class org.infinispan.configuration.cache.AbstractSegmentedStoreConfiguration
 
AbstractSiteStatusBuilder<E> - Class in org.infinispan.xsite.status
A SiteStatus builder based on its online and offline members.
AbstractSiteStatusBuilder() - Constructor for class org.infinispan.xsite.status.AbstractSiteStatusBuilder
 
AbstractStoreConfiguration - Class in org.infinispan.configuration.cache
 
AbstractStoreConfiguration(boolean, boolean, boolean, AsyncStoreConfiguration, SingletonStoreConfiguration, boolean, boolean, Properties) - Constructor for class org.infinispan.configuration.cache.AbstractStoreConfiguration
Deprecated.
AbstractStoreConfiguration(AttributeSet, AsyncStoreConfiguration, SingletonStoreConfiguration) - 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
AbstractStoreConfigurationBuilder(PersistenceConfigurationBuilder, AttributeSet) - 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
 
AbstractStoreSerializer - Class in org.infinispan.configuration.serializing
AbstractStoreSerializer.
AbstractStoreSerializer() - Constructor for class org.infinispan.configuration.serializing.AbstractStoreSerializer
 
AbstractTopologyAffectedCommand - Class in org.infinispan.commands
Base class for commands that carry topology id.
AbstractTopologyAffectedCommand() - Constructor for class org.infinispan.commands.AbstractTopologyAffectedCommand
 
AbstractTransactionBoundaryCommand - Class in org.infinispan.commands.tx
An abstract transaction boundary command that holds a reference to a GlobalTransaction
AbstractTransactionBoundaryCommand(ByteString) - Constructor for class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
AbstractTransport - Class in org.infinispan.remoting.transport
Deprecated.
Since 9.1, please implement Transport directly.
AbstractTransport() - Constructor for class org.infinispan.remoting.transport.AbstractTransport
Deprecated.
 
AbstractTransportConfigurationChildBuilder - Class in org.infinispan.configuration.cache
 
AbstractTransportConfigurationChildBuilder(TransactionConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractTransportConfigurationChildBuilder
 
AbstractTxInvocationContext<T extends AbstractCacheTransaction> - Class in org.infinispan.context.impl
Support class for TxInvocationContext.
AbstractTxInvocationContext(T, Address) - 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
 
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
 
AbstractWriteKeyCommand<K,​V> - Class in org.infinispan.commands.functional
 
AbstractWriteKeyCommand() - Constructor for class org.infinispan.commands.functional.AbstractWriteKeyCommand
 
AbstractWriteKeyCommand(Object, ValueMatcher, int, CommandInvocationId, Params, DataConversion, DataConversion) - Constructor for class org.infinispan.commands.functional.AbstractWriteKeyCommand
 
AbstractWriteManyCommand<K,​V> - Class in org.infinispan.commands.functional
 
AbstractWriteManyCommand() - Constructor for class org.infinispan.commands.functional.AbstractWriteManyCommand
 
AbstractWriteManyCommand(CommandInvocationId, Params, DataConversion, DataConversion) - Constructor for class org.infinispan.commands.functional.AbstractWriteManyCommand
 
AbstractWriteManyCommand(AbstractWriteManyCommand<K, V>) - Constructor for class org.infinispan.commands.functional.AbstractWriteManyCommand
 
accept(Object, Object, Metadata) - Method in class org.infinispan.filter.AcceptAllKeyValueFilter
 
accept(Object, Throwable) - Method in class org.infinispan.interceptors.impl.QueueAsyncInvocationStage
 
accept(Object, Throwable) - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor.LockTimeoutFuture
 
accept(Object, Throwable) - Method in interface org.infinispan.scattered.BiasManager.Revocation
 
accept(Supplier<PrimitiveIterator.OfInt>) - Method in interface org.infinispan.BaseCacheStream.SegmentCompletionListener
Invoked each time a given number of segments have completed and the terminal operation has consumed all entries in the given segment
accept(K) - Method in class org.infinispan.distribution.group.impl.GroupFilter
 
accept(K) - Method in class org.infinispan.filter.CollectionKeyFilter
 
accept(K) - Method in class org.infinispan.filter.CompositeKeyFilter
 
accept(K) - Method in interface org.infinispan.filter.KeyFilter
Deprecated.
 
accept(K) - Method in class org.infinispan.filter.KeyValueFilterAsKeyFilter
 
accept(K) - Method in class org.infinispan.persistence.PrimaryOwnerFilter
 
accept(K, Object, Metadata, Object, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.KeyFilterAsCacheEventFilter
 
accept(K, V, Metadata) - Method in class org.infinispan.filter.AbstractKeyValueFilterConverter
 
accept(K, V, Metadata) - Method in class org.infinispan.filter.CompositeKeyValueFilter
 
accept(K, V, Metadata) - Method in class org.infinispan.filter.KeyFilterAsKeyValueFilter
 
accept(K, V, Metadata) - Method in interface org.infinispan.filter.KeyValueFilter
 
accept(K, V, Metadata) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterAsKeyValueFilter
 
accept(K, V, Metadata, V, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.AbstractCacheEventFilterConverter
 
accept(K, V, Metadata, V, Metadata, EventType) - Method in interface org.infinispan.notifications.cachelistener.filter.CacheEventFilter
Whether or not this event should be raised to the listener it is attached to.
accept(K, V, Metadata, V, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.CompositeCacheEventFilter
 
accept(K, V, Metadata, V, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterAsCacheEventFilter
 
accept(K, V, Metadata, V, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter
 
accept(K, V, Metadata, V, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.PostCacheEventFilter
 
accept(InvocationContext, VisitableCommand, Object) - Method in interface org.infinispan.interceptors.InvocationSuccessAction
Process the result from a successful invocation stage and possibly throw an exception.
accept(InvocationContext, VisitableCommand, Object, Throwable) - Method in interface org.infinispan.interceptors.InvocationFinallyAction
Process the result or the exception from an invocation stage and possibly throw an exception.
accept(ScopedState) - Method in class org.infinispan.globalstate.ScopeFilter
 
accept(T, U, V) - Method in interface org.infinispan.util.function.TriConsumer
Performs this operation on the given arguments.
ACCEPT_ALL_FILTER - Static variable in interface org.infinispan.filter.KeyFilter
Deprecated.
 
AcceptAllKeyValueFilter - Class in org.infinispan.filter
A key value filter that accepts all entries found.
AcceptAllKeyValueFilter.Externalizer - Class in org.infinispan.filter
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.control.LockControlCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.functional.ReadOnlyKeyCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.functional.ReadOnlyManyCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.functional.ReadWriteKeyCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.functional.ReadWriteKeyValueCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.functional.ReadWriteManyCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.functional.WriteOnlyKeyCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.functional.WriteOnlyKeyValueCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.functional.WriteOnlyManyCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.functional.WriteOnlyManyEntriesCommand
 
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.GetAllCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.read.GetCacheEntryCommand
 
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.remote.GetKeysInGroupCommand
 
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
Deprecated.
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.write.ClearCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.write.ComputeCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.write.ComputeIfAbsentCommand
 
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.RemoveExpiredCommand
 
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.commands.write.ReplaceCommand
 
ack() - Method in class org.infinispan.commands.write.BackupAckCommand
 
ack() - Method in class org.infinispan.commands.write.BackupMultiKeyAckCommand
 
ack() - Method in class org.infinispan.commands.write.ExceptionAckCommand
 
acquire(Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.InfinispanLock
It tries to acquire this lock.
acquire(Object, Object, long, TimeUnit) - Method in interface org.infinispan.util.concurrent.locks.impl.LockContainer
 
acquire(Object, Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.PerKeyLockContainer
 
acquire(Object, Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.StripedLockContainer
 
ACQUIRE_TIMEOUT - org.infinispan.configuration.parsing.Attribute
 
acquireAllLocks(List<Object>, boolean) - Method in class org.infinispan.util.concurrent.locks.StripedLock
Acquires locks on keys passed in.
ACQUIRED - org.infinispan.util.concurrent.locks.LockState
The lock owner left the queue and it is available to acquire the lock.
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, 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
 
acquireSharedTopologyLock() - Method in interface org.infinispan.statetransfer.StateTransferLock
 
acquireSharedTopologyLock() - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
Action - Interface in org.infinispan.remoting.inboundhandler.action
An action represents a step in PerCacheInboundInvocationHandler.
ActionListener - Interface in org.infinispan.remoting.inboundhandler.action
A listener that is invoked when an Action is completed.
ActionState - Class in org.infinispan.remoting.inboundhandler.action
The state used by an Action.
ActionState(ReplicableCommand, int, long) - Constructor for class org.infinispan.remoting.inboundhandler.action.ActionState
 
ActionStatus - Enum in org.infinispan.remoting.inboundhandler.action
The status for an Action.
ActivationManager - Interface in org.infinispan.eviction
Controls activation of cache entries that have been passivated.
ActivationManagerImpl - Class in org.infinispan.eviction.impl
Concrete implementation of activation logic manager.
ActivationManagerImpl() - Constructor for class org.infinispan.eviction.impl.ActivationManagerImpl
 
ActivationManagerStub - Class in org.infinispan.eviction.impl
 
ActivationManagerStub() - Constructor for class org.infinispan.eviction.impl.ActivationManagerStub
 
activator - Variable in class org.infinispan.container.impl.AbstractInternalDataContainer
 
active - Variable in class org.infinispan.persistence.support.SingletonCacheWriter
Deprecated.
Whether the the current cache is the coordinator and therefore SingletonStore is active.
activeStatusChanged(boolean) - Method in class org.infinispan.persistence.support.SingletonCacheWriter
Deprecated.
Method called when the cache either becomes the coordinator or stops being the coordinator.
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
 
actual() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
 
actualNumOwners - Variable in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
add(Object) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
Deprecated.
 
add(Permission) - Method in class org.infinispan.security.CachePermissionCollection
 
add(List<Xid>) - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
 
add(Map.Entry<K, V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySet
 
add(CacheEntry<K, V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntrySet
 
add(Listeners.ReadWriteListeners.ReadWriteListener<K, V>) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
 
add(Listeners.ReadWriteListeners.ReadWriteListener<K, V>) - Method in interface org.infinispan.functional.Listeners.ReadWriteListeners
Add a read-write listener, and return an AutoCloseable instance that can be used to remove the listener registration.
add(Listeners.WriteListeners.WriteListener<K, V>) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
 
add(Listeners.WriteListeners.WriteListener<K, V>) - Method in interface org.infinispan.functional.Listeners.WriteListeners
Add a write-only listener, and return an AutoCloseable instance that can be used to remove the listener registration.
add(Param<?>) - Method in class org.infinispan.functional.impl.Params
 
add(R) - Method in class org.infinispan.util.CollectionMapper
 
add(R) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
 
add(T) - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
 
addAdvancedExternalizer(int, AdvancedExternalizer<T>) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
Helper method that allows for quick registration of an AdvancedExternalizer implementation alongside its corresponding identifier.
addAdvancedExternalizer(AdvancedExternalizer<T>) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
Helper method that allows for quick registration of an AdvancedExternalizer implementation alongside its corresponding identifier.
addAdvancedExternalizer(AdvancedExternalizer<T>...) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
Helper method that allows for quick registration of AdvancedExternalizer implementations.
addAffectedKey(Object) - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
addAffectedKey(Object) - Method in interface org.infinispan.context.impl.TxInvocationContext
 
addAffectedKey(Object) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
addAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
Deprecated.
 
addAll(Collection<? extends Map.Entry<K, V>>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySet
 
addAll(Collection<? extends CacheEntry<K, V>>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntrySet
 
addAll(Collection<? extends R>) - Method in class org.infinispan.util.CollectionMapper
 
addAll(Collection<? extends R>) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
 
addAll(Collection<? extends T>) - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
 
addAll(Params) - Method in class org.infinispan.functional.impl.Params
 
addAll(Param<?>...) - Method in class org.infinispan.functional.impl.Params
Adds all parameters and returns a new parameter collection.
addAllAffectedKeys(Collection<?>) - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
addAllAffectedKeys(Collection<?>) - Method in interface org.infinispan.context.impl.TxInvocationContext
Registers a new participant with the transaction.
addAllAffectedKeys(Collection<?>) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
addAllSynchronizedBlocks(Collection<TotalOrderLatch>) - Method in class org.infinispan.transaction.impl.TotalOrderRemoteTransactionState
 
addBackup() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
addBackupLockForKey(Object) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
addBackupLockForKey(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
addBackupOwner(int, Address) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
addBackupOwner(int, Address) - Method in class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory.Builder
 
addBackupOwners(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
 
addBackupOwners(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.TopologyAwareConsistentHashFactory
 
addCacheDependency(String, String) - Method in class org.infinispan.manager.DefaultCacheManager
 
addCacheDependency(String, String) - Method in interface org.infinispan.manager.EmbeddedCacheManager
Add a dependency between two caches.
addCacheDependency(String, String) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
AddCacheManagerListenerAction - Class in org.infinispan.security.actions
CacheManagerAddListenerAction.
AddCacheManagerListenerAction(EmbeddedCacheManager, Object) - Constructor for class org.infinispan.security.actions.AddCacheManagerListenerAction
 
addCacheName(String, SiteStatus) - Method in class org.infinispan.xsite.status.ContainerSiteStatusBuilder
Adds the cache with the SiteStatus connection to the site.
addCacheStoreFactory(CacheStoreFactory) - Method in class org.infinispan.persistence.factory.CacheStoreFactoryRegistry
Adds a new factory for processing.
addCallback(InvocationContext, VisitableCommand, InvocationCallback) - Method in class org.infinispan.interceptors.impl.QueueAsyncInvocationStage
 
addCallback(InvocationContext, VisitableCommand, InvocationCallback) - Method in class org.infinispan.interceptors.impl.SimpleAsyncInvocationStage
 
addCallback(InvocationContext, VisitableCommand, InvocationCallback) - Method in class org.infinispan.interceptors.InvocationStage
 
addCallback(InvocationContext, VisitableCommand, InvocationCallback) - Method in class org.infinispan.interceptors.SyncInvocationStage
 
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
 
addDataRead(boolean, long) - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
addDependency(T, T) - Method in class org.infinispan.util.DependencyGraph
Add a dependency between two elements
addDynamicDependency(String, String) - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
Add a dynamic dependency between two components.
addDynamicDependency(String, String) - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
 
addEvents(Address, UUID, Collection<ClusterEvent<K, V>>, boolean) - Method in interface org.infinispan.notifications.cachelistener.cluster.ClusterEventManager
Adds additional cluster events that need to be sent remotely for an event originating locally.
addEvents(Address, UUID, Collection<ClusterEvent<K, V>>, boolean) - Method in class org.infinispan.notifications.cachelistener.cluster.impl.BatchingClusterEventManagerImpl
 
addEvents(Address, UUID, Collection<ClusterEvent<K, V>>, boolean) - Method in class org.infinispan.notifications.cachelistener.cluster.impl.ClusterEventManagerStub
 
addEvictions(long) - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
addException(Address, Exception) - Method in class org.infinispan.remoting.transport.impl.FilterMapResponseCollector
 
addException(Address, Exception) - Method in class org.infinispan.remoting.transport.impl.MapResponseCollector
 
addException(Address, Exception) - Method in class org.infinispan.remoting.transport.impl.VoidResponseCollector
 
addException(Address, Exception) - Method in class org.infinispan.remoting.transport.ValidResponseCollector
Process an exception from a target.
addFailure(String, Throwable) - Method in exception org.infinispan.xsite.BackupFailureException
 
addFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
addFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.CacheImpl
 
addFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.EncoderCache
 
addFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
addFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in interface org.infinispan.notifications.FilteringListenable
Registers a listener limiting the cache-entry specific events only to annotations that are passed in as parameter.
addFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
addFilteredListener(ListenerHolder, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addFilteredListener(ListenerHolder, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in interface org.infinispan.notifications.DataConversionAwareListenable
 
addFlag(Flag) - Method in interface org.infinispan.commands.FlagAffectedCommand
Deprecated.
Since 9.0, please use FlagAffectedCommand.addFlags(long) with a FlagBitSets constant instead.
addFlags(long) - Method in interface org.infinispan.commands.FlagAffectedCommand
Add a set of flags to the command.
addFlags(Set<Flag>) - Method in interface org.infinispan.commands.FlagAffectedCommand
Deprecated.
Since 9.0, please use FlagAffectedCommand.addFlags(long) with a FlagBitSets constant instead.
addGrouper(Grouper<?>) - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
Add a grouper
addIndexedEntity(Class<?>) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
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(AsyncInterceptor, int) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Inserts the given interceptor at the specified position in the chain (0 based indexing).
addInterceptor(AsyncInterceptor, int) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
addInterceptor(AsyncInterceptor, int) - Method in class org.infinispan.interceptors.impl.AsyncInterceptorChainImpl
 
addInterceptor(CommandInterceptor, int) - Method in interface org.infinispan.AdvancedCache
Deprecated.
addInterceptor(CommandInterceptor, int) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
addInterceptor(CommandInterceptor, int) - Method in class org.infinispan.cache.impl.CacheImpl
 
addInterceptor(CommandInterceptor, int) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
addInterceptor(CommandInterceptor, int) - Method in class org.infinispan.interceptors.InterceptorChain
Deprecated.
Inserts the given interceptor at the specified position in the chain (o based indexing).
addInterceptor(CommandInterceptor, int) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
addInterceptorAfter(AsyncInterceptor, Class<? extends AsyncInterceptor>) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Adds a new interceptor in list after an interceptor of a given type.
addInterceptorAfter(AsyncInterceptor, Class<? extends AsyncInterceptor>) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
addInterceptorAfter(AsyncInterceptor, Class<? extends AsyncInterceptor>) - Method in class org.infinispan.interceptors.impl.AsyncInterceptorChainImpl
 
addInterceptorAfter(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in interface org.infinispan.AdvancedCache
Deprecated.
addInterceptorAfter(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
addInterceptorAfter(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.cache.impl.CacheImpl
 
addInterceptorAfter(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
addInterceptorAfter(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
Deprecated.
Adds a new interceptor in list after an interceptor of a given type.
addInterceptorAfter(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
addInterceptorBefore(AsyncInterceptor, Class<? extends AsyncInterceptor>) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Adds a new interceptor in list before an interceptor of a given type.
addInterceptorBefore(AsyncInterceptor, Class<? extends AsyncInterceptor>) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
addInterceptorBefore(AsyncInterceptor, Class<? extends AsyncInterceptor>) - Method in class org.infinispan.interceptors.impl.AsyncInterceptorChainImpl
 
addInterceptorBefore(AsyncInterceptor, Class<? extends AsyncInterceptor>, boolean) - Method in class org.infinispan.interceptors.impl.AsyncInterceptorChainImpl
Deprecated.
addInterceptorBefore(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in interface org.infinispan.AdvancedCache
Deprecated.
addInterceptorBefore(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
addInterceptorBefore(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.cache.impl.CacheImpl
 
addInterceptorBefore(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
addInterceptorBefore(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
Deprecated.
Adds a new interceptor in list after an interceptor of a given type.
addInterceptorBefore(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
addInterceptorBefore(CommandInterceptor, Class<? extends CommandInterceptor>, boolean) - Method in class org.infinispan.interceptors.InterceptorChain
addIntermediateOperation(Queue<IntermediateOperation>, IntermediateOperation<T, S, ?, ?>) - Method in class org.infinispan.stream.impl.AbstractCacheStream
 
addIntermediateOperation(IntermediateOperation<T, S, T, S>) - Method in class org.infinispan.stream.impl.AbstractCacheStream
 
addIntermediateOperationMap(IntermediateOperation<T, S, ?, ?>) - Method in class org.infinispan.stream.impl.AbstractCacheStream
 
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.impl.TotalOrderRemoteTransactionState
 
addListener() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
addListener(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
addListener(Object) - Method in class org.infinispan.cache.impl.CacheImpl
 
addListener(Object) - Method in class org.infinispan.cache.impl.DecoratedCache
 
addListener(Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
addListener(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
addListener(Object) - Method in class org.infinispan.manager.DefaultCacheManager
 
addListener(Object) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
addListener(Object) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addListener(Object) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
addListener(Object) - Method in interface org.infinispan.notifications.Listenable
Adds a listener to the component.
addListener(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
addListener(Object, ClassLoader) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
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<? super K>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
addListener(Object, KeyFilter<? super K>) - Method in class org.infinispan.cache.impl.CacheImpl
 
addListener(Object, KeyFilter<? super K>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
addListener(Object, KeyFilter<? super K>) - Method in class org.infinispan.cache.impl.EncoderCache
 
addListener(Object, KeyFilter<? super K>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
addListener(Object, KeyFilter<? super K>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addListener(Object, KeyFilter<? super K>) - Method in interface org.infinispan.notifications.FilteringListenable
Adds a listener to the component.
addListener(Object, KeyFilter<? super K>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
addListener(Object, KeyFilter<? super K>, ClassLoader) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addListener(Object, KeyFilter<? super K>, ClassLoader) - Method in interface org.infinispan.notifications.ClassLoaderAwareFilteringListenable
Adds a listener to the component.
addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.cache.impl.CacheImpl
 
addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.cache.impl.EncoderCache
 
addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in interface org.infinispan.notifications.FilteringListenable
Registers a listener that will be notified on events that pass the filter condition.
addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, ClassLoader) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
Adds the listener using the provided filter converter and class loader.
addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, ClassLoader) - Method in interface org.infinispan.notifications.ClassLoaderAwareFilteringListenable
Adds a listener with the provided filter and converter and using a given classloader when invoked.
addListener(ListenerHolder, KeyFilter<? super K>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addListener(ListenerHolder, KeyFilter<? super K>) - Method in interface org.infinispan.notifications.DataConversionAwareListenable
 
addListener(ListenerHolder, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, ClassLoader) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addListener(ListenerHolder, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, ClassLoader) - Method in interface org.infinispan.notifications.DataConversionAwareListenable
 
addListener(ActionListener) - Method in interface org.infinispan.remoting.inboundhandler.action.Action
Adds a listener to be invoked when this action is ready or canceled.
addListener(ActionListener) - Method in class org.infinispan.remoting.inboundhandler.action.CompositeAction
 
addListener(ActionListener) - Method in class org.infinispan.remoting.inboundhandler.action.DefaultReadyAction
 
addListener(ActionListener) - Method in class org.infinispan.remoting.inboundhandler.action.LockAction
 
addListener(ActionListener) - Method in class org.infinispan.remoting.inboundhandler.action.PendingTxAction
 
addListener(ActionListener) - Method in interface org.infinispan.remoting.inboundhandler.action.ReadyAction
It adds a listener that is invoked when this action is ready.
addListener(CacheTransaction.TransactionCompletedListener) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
addListener(CacheTransaction.TransactionCompletedListener) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
addListener(KeyAwareLockListener) - Method in interface org.infinispan.util.concurrent.locks.KeyAwareLockPromise
It adds the listener to this LockPromise.
addListener(LockListener) - Method in interface org.infinispan.util.concurrent.locks.LockPromise
Adds a LockListener to be invoked when the lock is available.
addListener(PendingLockListener) - Method in interface org.infinispan.util.concurrent.locks.PendingLockPromise
Adds a listener to this promise.
addLocalBias(Object, int) - Method in interface org.infinispan.scattered.BiasManager
Allow reading local data if the topology is still actual.
addLocalBias(Object, int) - Method in class org.infinispan.scattered.impl.BiasManagerImpl
 
addLockedKey(Object) - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
addLockedKey(Object) - Method in class org.infinispan.context.impl.ClearInvocationContext
 
addLockedKey(Object) - Method in class org.infinispan.context.impl.ImmutableContext
 
addLockedKey(Object) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
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
Deprecated.
 
addLockedKey(Object) - Method in class org.infinispan.transaction.impl.TotalOrderRemoteTransactionState
 
addMarshalledEntry(Object, MarshalledEntry) - Method in class org.infinispan.persistence.support.BatchModification
 
addMember(Address, boolean) - Method in class org.infinispan.xsite.status.CacheSiteStatusBuilder
Adds a member with an online/offline connection to the server based on the online parameter.
addMergePolicyFactory(EntryMergePolicyFactory) - Method in class org.infinispan.conflict.EntryMergePolicyFactoryRegistry
 
addModification(WriteCommand) - Method in class org.infinispan.transaction.impl.LocalTransaction
 
addModule(Class<T>) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
addModule(Class<T>) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
addOwner(int, Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
addOwner(Address) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
addOwnerNoCheck(int, Address) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
addOwners(int, Collection<Address>) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
addParsingCompleteListener(ParserContextListener) - Method in class org.infinispan.configuration.parsing.AbstractParserContext
 
addParsingCompleteListener(ParserContextListener) - Method in interface org.infinispan.configuration.parsing.ParserContext
 
addPartialCommit1PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, List<WriteCommand>) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
addPartialCommit1PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, List<WriteCommand>) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
Adds a partially committed transaction.
addPartialCommit1PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, List<WriteCommand>) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
addPartialCommit2PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, EntryVersionsMap) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
addPartialCommit2PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, EntryVersionsMap) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
Adds a partially committed transaction.
addPartialCommit2PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, EntryVersionsMap) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
addPartialRollbackTransaction(GlobalTransaction, Collection<Address>, Collection<Object>) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
addPartialRollbackTransaction(GlobalTransaction, Collection<Address>, Collection<Object>) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
Adds a partially aborted transaction.
addPartialRollbackTransaction(GlobalTransaction, Collection<Address>, Collection<Object>) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
addPendingAcks(boolean, Address[]) - Method in interface org.infinispan.interceptors.distribution.BiasedCollector
 
addPersistentAddressMapping(Address, PersistentUUID) - Method in interface org.infinispan.topology.PersistentUUIDManager
Adds a mapping between an Address and a PersistentUUID
addPersistentAddressMapping(Address, PersistentUUID) - Method in class org.infinispan.topology.PersistentUUIDManagerImpl
 
addPrimaryOwner(int, Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
addPrimaryOwner(int, Address) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
addPrimaryOwner(int, Address) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
addPrimaryOwners(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.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
Deprecated.
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.impl.LocalTransaction
 
addReadKey(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
Deprecated.
since 9.1 Use MVCCEntry.setRead() instead
addRemovalListener(Consumer<Iterable<InternalCacheEntry<K, V>>>) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
addRemovalListener(Consumer<Iterable<InternalCacheEntry<K, V>>>) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
addRemovalListener(Consumer<Iterable<InternalCacheEntry<K, V>>>) - Method in interface org.infinispan.container.impl.InternalDataContainer
Adds a listener that is invoked whenever InternalDataContainer.removeSegments(IntSet) is invoked providing a way for the listener to see what actual entries were removed from the container.
addRemovalListener(Consumer<Iterable<InternalCacheEntry<K, V>>>) - Method in class org.infinispan.container.impl.InternalDataContainerAdapter
 
addRequest(Request<?>) - Method in class org.infinispan.remoting.transport.impl.RequestRepository
 
addRequestor(Object, Address) - Method in class org.infinispan.distribution.impl.L1ManagerImpl
 
addRequestor(Object, Address) - Method in interface org.infinispan.distribution.L1Manager
Records a request that will be cached in another nodes L1
addResponse(long, Address, Response) - Method in class org.infinispan.remoting.transport.impl.RequestRepository
 
addResponse(Address, Response) - Method in interface org.infinispan.interceptors.distribution.BiasedCollector
 
addResponse(Address, Response) - Method in class org.infinispan.remoting.transport.impl.PassthroughMapResponseCollector
 
addResponse(Address, Response) - Method in class org.infinispan.remoting.transport.impl.PassthroughSingleResponseCollector
 
addResponse(Address, Response) - Method in class org.infinispan.remoting.transport.RemoteGetResponseCollector
 
addResponse(Address, Response) - Method in interface org.infinispan.remoting.transport.ResponseCollector
Called when a response is received, or when a target node becomes unavailable.
addResponse(Address, Response) - Method in class org.infinispan.remoting.transport.ValidResponseCollector
 
addResponse(Address, Response) - Method in class org.infinispan.remoting.transport.ValidSingleResponseCollector
 
address - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
address - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
Address - Interface in org.infinispan.remoting.transport
A destination for an Infinispan command or operation.
ADDRESS_COUNT - org.infinispan.configuration.parsing.Attribute
 
ADDRESS_COUNT - Static variable in class org.infinispan.configuration.cache.MemoryConfiguration
 
addressCount() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
The address pointer count
addressCount() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
How many address pointers are configured for the off heap storage.
addressCount(int) - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
Configuration setting when using off-heap that defines how many address pointers there are.
addressToPersistentUUID() - Method in interface org.infinispan.topology.PersistentUUIDManager
Provides a remapping operator which translates addresses to persistentuuids
addressToPersistentUUID() - Method in class org.infinispan.topology.PersistentUUIDManagerImpl
 
addSegments(IntSet) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
addSegments(IntSet) - Method in class org.infinispan.container.impl.DefaultDataContainer
 
addSegments(IntSet) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
addSegments(IntSet) - Method in interface org.infinispan.container.impl.InternalDataContainer
Sets what segments this data container should be using.
addSegments(IntSet) - Method in class org.infinispan.container.impl.InternalDataContainerAdapter
 
addSegments(IntSet) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
addSegments(IntSet) - Method in interface org.infinispan.persistence.manager.PersistenceManager
Notifies any underlying segmented stores that the segments provided are owned by this cache and to start/configure any underlying resources required to handle requests for entries on the given segments.
addSegments(IntSet) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
addSegments(IntSet) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
Invoked when a node becomes an owner of the given segments.
addSegments(IntSet) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
addShutdownHook() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
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.
addStatus(Set<Integer>) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
addStorageFormatFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
addStorageFormatFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.CacheImpl
 
addStorageFormatFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.EncoderCache
 
addStorageFormatFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
addStorageFormatFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addStorageFormatFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in interface org.infinispan.notifications.FilteringListenable
Same as FilteringListenable.addFilteredListener(Object, CacheEventFilter, CacheEventConverter, Set), but assumes the filter and/or the converter will be done in the same data format as it's stored in the cache.
addStorageFormatFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
addStore(Class<T>) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
Adds a cache loader that uses the specified builder class to build its configuration.
addStore(StoreConfigurationBuilder<?, ?>) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
Adds a cache loader that uses the specified builder instance to build its configuration.
addSynchronizedBlock(TotalOrderLatch) - Method in class org.infinispan.transaction.impl.TotalOrderRemoteTransactionState
 
addTargetNotFound(Address) - Method in class org.infinispan.remoting.transport.impl.FilterMapResponseCollector
 
addTargetNotFound(Address) - Method in class org.infinispan.remoting.transport.impl.VoidResponseCollector
 
addTargetNotFound(Address) - Method in class org.infinispan.remoting.transport.ValidResponseCollector
Process a target leaving the cluster or stopping the cache.
addTargets(Address, UUID, Collection<ClusterEvent<K, V>>, boolean) - Method in class org.infinispan.notifications.cachelistener.cluster.impl.BatchingClusterEventManagerImpl.UnicastEventContext
 
addToWhiteList(String) - Static method in class org.infinispan.marshall.core.ExternallyMarshallable
Adds package or class name to the externally marshallable white list.
addTransfer(InboundTransferTask, IntSet) - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
addTransfer(OutboundTransferTask) - Method in class org.infinispan.statetransfer.StateProviderImpl
 
addValidResponse(Address, ValidResponse) - Method in class org.infinispan.remoting.transport.impl.FilterMapResponseCollector
 
addValidResponse(Address, ValidResponse) - Method in class org.infinispan.remoting.transport.impl.MapResponseCollector
 
addValidResponse(Address, ValidResponse) - Method in class org.infinispan.remoting.transport.impl.VoidResponseCollector
 
addValidResponse(Address, ValidResponse) - Method in class org.infinispan.remoting.transport.ValidResponseCollector
Process a valid response from a target.
addVersionIfNeeded(MetadataAwareCommand) - Method in class org.infinispan.interceptors.impl.VersionInterceptor
 
addVersionRead(Object, EntryVersion) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
addVersionRead(Object, EntryVersion) - Method in interface org.infinispan.transaction.xa.CacheTransaction
Sets the version read for this key.
ADMIN - org.infinispan.security.AuthorizationPermission
Allows performing "administrative" operations on a cache
administration() - Method in interface org.infinispan.manager.CacheContainer
Provides access to administrative methods which affect the underlying cache container, such as cache creation and removal.
administration() - Method in class org.infinispan.manager.DefaultCacheManager
 
administration() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Provides an EmbeddedCacheManagerAdmin whose methods affect the entire cluster as opposed to a single node.
administration() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
ADVANCED_EXTERNALIZER - org.infinispan.configuration.parsing.Element
 
AdvancedAsyncCacheLoader<K,​V> - 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.
AdvancedCacheExpirationWriter<K,​V> - Interface in org.infinispan.persistence.spi
Defines functionality for advanced expiration techniques.
AdvancedCacheExpirationWriter.ExpirationPurgeListener<K,​V> - Interface in org.infinispan.persistence.spi
Callback to be notified when an entry is removed by the AdvancedCacheExpirationWriter.purge(Executor, ExpirationPurgeListener) method.
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
Deprecated.
since 9.3 The process method is deprecated and thus this class shouldn't be in use any more
AdvancedCacheLoader.TaskContext - Interface in org.infinispan.persistence.spi
Deprecated.
since 9.3 The process method is no longer suggested and thus this class shouldn't be in use any more
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
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
Deprecated.
this writer will be removed in 10.0. If it is desirable that all nodes don't write to the underlying store then a shared store should be used instead, as this only performs store writes at a key's primary owner.
AdvancedSingletonCacheWriter(CacheWriter, SingletonStoreConfiguration) - Constructor for class org.infinispan.persistence.support.AdvancedSingletonCacheWriter
Deprecated.
 
advanceExternalizerTypeClassesUndefined(String) - Method in class org.infinispan.util.logging.Log_$logger
 
advanceExternalizerTypeClassesUndefined(String) - Method in interface org.infinispan.util.logging.Log
 
advanceExternalizerTypeClassesUndefined$str() - Method in class org.infinispan.util.logging.Log_$logger
 
affectedKeys - Variable in class org.infinispan.transaction.impl.AbstractCacheTransaction
Holds all the locked keys that were acquired by the transaction allover the cluster.
AffectedKeysVisitor - Class in org.infinispan.statetransfer
Deprecated.
since 9.1
AffectedKeysVisitor() - Constructor for class org.infinispan.statetransfer.AffectedKeysVisitor
Deprecated.
 
AffinityPartitioner - Class in org.infinispan.distribution.ch.impl
Key partitioner that maps keys to segments using information contained in AffinityTaggedKey.
AffinityPartitioner() - Constructor for class org.infinispan.distribution.ch.impl.AffinityPartitioner
 
AffinityTaggedKey - Interface in org.infinispan.distribution.ch
 
after() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
after(Class<? extends AsyncInterceptor>) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
Dictates that the custom interceptor appears immediately after the specified interceptor.
AFTER - org.infinispan.configuration.parsing.Attribute
 
AFTER - org.infinispan.container.versioning.InequalVersionComparisonResult
Denotes a version that was created temporally after another version.
AFTER - Static variable in class org.infinispan.configuration.cache.InterceptorConfiguration
 
AFTER_FAILURES - Static variable in class org.infinispan.configuration.cache.TakeOfflineConfiguration
 
afterBackupRemotely(ReplicableCommand, BackupResponse) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
method invoked after a successful backup remote invocation.
afterCompletion(int) - Method in class org.infinispan.transaction.synchronization.SynchronizationAdapter
 
afterCompletion(LocalTransaction, int) - Method in class org.infinispan.transaction.impl.TransactionTable
 
afterCompletionFailed(Synchronization, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
afterCompletionFailed(Synchronization, Throwable) - Method in interface org.infinispan.util.logging.Log
 
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.
afterHandle(CacheRpcCommand, DeliverOrder, boolean) - Method in class org.infinispan.remoting.inboundhandler.AbstractDelegatingHandler
Invoked after the command is handled.
afterInvoke() - Method in class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
 
afterInvokeRemotely(ReplicableCommand, Map<Address, Response>) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
method invoked after a successful remote invocation.
AggregateBackupResponse - Class in org.infinispan.remoting.transport
 
AggregateBackupResponse(BackupResponse, BackupResponse) - Constructor for class org.infinispan.remoting.transport.AggregateBackupResponse
 
ALIASES - org.infinispan.configuration.parsing.Attribute
 
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 - org.infinispan.configuration.cache.Index
All cluster nodes will add the entry to the index.
ALL - org.infinispan.distexec.DistributedTaskExecutionPolicy
 
ALL - org.infinispan.functional.Param.ExecutionMode
Command is executed on its owners, in transactional mode in the context, too, but there it is not persisted.
ALL - org.infinispan.manager.ClusterExecutionPolicy
The command can be executed on any node in the cluster
ALL - org.infinispan.security.AuthorizationPermission
Aggregate permission which implies all of the others
ALL_KNOWN_COMPONENT_NAMES - Static variable in class org.infinispan.factories.KnownComponentNames
 
ALL_READ - org.infinispan.security.AuthorizationPermission
Aggregate permission which implies all read permissions
ALL_WRITE - org.infinispan.security.AuthorizationPermission
Aggregate permission which implies all write permissions
allBackups() - Method in class org.infinispan.configuration.cache.SitesConfiguration
Returns the list of all sites where this cache might back up its data.
allIndexingInNonReplicatedCache() - Method in class org.infinispan.util.logging.Log_$logger
 
allIndexingInNonReplicatedCache() - Method in interface org.infinispan.util.logging.Log
 
allIndexingInNonReplicatedCache$str() - Method in class org.infinispan.util.logging.Log_$logger
 
allMatch(DoublePredicate) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
allMatch(DoublePredicate) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
allMatch(DoublePredicate) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
allMatch(IntPredicate) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
allMatch(IntPredicate) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
allMatch(IntPredicate) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
allMatch(LongPredicate) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
allMatch(LongPredicate) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
allMatch(LongPredicate) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
allMatch(Predicate<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
allMatch(Predicate<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
allMatch(Predicate<? super R>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
allMatch(Predicate<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
allMatch(Predicate<? super T>) - Method in interface org.infinispan.functional.Traversable
A terminal operation that returns whether all elements of this traversable match the provided predicate.
allMatch(SerializableDoublePredicate) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleStream.allMatch(DoublePredicate) except that the DoublePredicate must also implement Serializable
allMatch(SerializableDoublePredicate) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
allMatch(SerializableIntPredicate) - Method in interface org.infinispan.IntCacheStream
Same as IntStream.allMatch(IntPredicate) except that the IntPredicate must also implement Serializable
allMatch(SerializableIntPredicate) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
allMatch(SerializableLongPredicate) - Method in interface org.infinispan.LongCacheStream
Same as LongStream.allMatch(LongPredicate) except that the LongPredicate must also implement Serializable.
allMatch(SerializableLongPredicate) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
allMatch(SerializablePredicate<? super R>) - Method in interface org.infinispan.CacheStream
Same as Stream.allMatch(Predicate) except that the Predicate must also implement Serializable
allNodeSubmission() - Method in interface org.infinispan.manager.ClusterExecutor
When a command is submitted it will submit this command to all of the available nodes that pass the provided filter.
allocate(long) - Method in interface org.infinispan.container.offheap.OffHeapMemoryAllocator
Allocates a new chunk of memory sized to the given length.
allocate(long) - Method in class org.infinispan.container.offheap.UnpooledOffHeapMemoryAllocator
 
allocator - Variable in class org.infinispan.container.offheap.OffHeapDataContainer
 
allocator - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
ALLOW - org.infinispan.security.AuditResponse
 
ALLOW_DUPLICATE_DOMAINS - org.infinispan.configuration.parsing.Attribute
 
ALLOW_DUPLICATE_DOMAINS - Static variable in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
ALLOW_READ_WRITES - org.infinispan.partitionhandling.PartitionHandling
Allow entries on each partition to diverge, with conflicts resolved during merge.
ALLOW_READS - org.infinispan.partitionhandling.PartitionHandling
Allows reads for a given key if it exists in this partition, but only allows writes if this partition contains all owners of a segment.
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.
allowedSegments - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
 
allowedSegments - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator
 
allowedSegments - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
 
allowInvocations() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
AllOwnersLostException - Exception in org.infinispan.statetransfer
Signals that all owners of a key have been lost.
allSubmissionExecutor(Predicate<? super Address>, EmbeddedCacheManager, JGroupsTransport, long, TimeUnit, Executor, ScheduledExecutorService) - Static method in class org.infinispan.manager.impl.ClusterExecutors
 
ALREADY_OFFLINE - org.infinispan.xsite.BackupSender.TakeSiteOfflineResponse
 
ALREADY_ONLINE - org.infinispan.xsite.BackupSender.BringSiteOnlineResponse
 
ALWAYS_TRUE_LOGIC - Static variable in class org.infinispan.transaction.impl.WriteSkewHelper
 
alwaysTruePredicate() - Static method in class org.infinispan.stream.StreamMarshalling
Predicate taht always returns true irrespective of the value provided
ambiguousConfigurationFiles(String) - Method in class org.infinispan.util.logging.Log_$logger
 
ambiguousConfigurationFiles(String) - Method in interface org.infinispan.util.logging.Log
 
ambiguousConfigurationFiles$str() - Method in class org.infinispan.util.logging.Log_$logger
 
amend(Integer, Long) - Method in class org.infinispan.xsite.OfflineStatus
 
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_TAKE_OFFLINE - org.infinispan.xsite.XSiteAdminCommand.AdminOperation
 
amendTakeOffline(String, int, long) - Method in class org.infinispan.xsite.XSiteAdminOperations
 
andExceptionally(InvocationContext, VisitableCommand, InvocationExceptionFunction) - Method in class org.infinispan.interceptors.InvocationStage
 
andFinally(InvocationContext, VisitableCommand, InvocationFinallyAction) - Method in class org.infinispan.interceptors.InvocationStage
 
andHandle(InvocationContext, VisitableCommand, InvocationFinallyFunction) - Method in class org.infinispan.interceptors.InvocationStage
 
annotation - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
annotation - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
anyMatch(DoublePredicate) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
anyMatch(DoublePredicate) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
anyMatch(DoublePredicate) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
anyMatch(IntPredicate) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
anyMatch(IntPredicate) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
anyMatch(IntPredicate) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
anyMatch(LongPredicate) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
anyMatch(LongPredicate) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
anyMatch(LongPredicate) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
anyMatch(Predicate<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
anyMatch(Predicate<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
anyMatch(Predicate<? super R>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
anyMatch(Predicate<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
anyMatch(Predicate<? super T>) - Method in interface org.infinispan.functional.Traversable
A terminal operation that returns whether any elements of this traversable match the provided predicate.
anyMatch(SerializableDoublePredicate) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleStream.anyMatch(DoublePredicate) except that the DoublePredicate must also implement Serializable
anyMatch(SerializableDoublePredicate) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
anyMatch(SerializableIntPredicate) - Method in interface org.infinispan.IntCacheStream
Same as IntStream.anyMatch(IntPredicate) except that the IntPredicate must also implement Serializable
anyMatch(SerializableIntPredicate) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
anyMatch(SerializableLongPredicate) - Method in interface org.infinispan.LongCacheStream
Same as LongStream.anyMatch(LongPredicate) except that the LongPredicate must also implement Serializable.
anyMatch(SerializableLongPredicate) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
anyMatch(SerializablePredicate<? super R>) - Method in interface org.infinispan.CacheStream
Same as Stream.anyMatch(Predicate) except that the Predicate must also implement Serializable
appendInterceptor(AsyncInterceptor, boolean) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Appends at the end.
appendInterceptor(AsyncInterceptor, boolean) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
appendInterceptor(AsyncInterceptor, boolean) - Method in class org.infinispan.interceptors.impl.AsyncInterceptorChainImpl
 
appendInterceptor(CommandInterceptor, boolean) - Method in class org.infinispan.interceptors.InterceptorChain
Deprecated.
Appends at the end.
apply(Object) - Method in class org.infinispan.compat.FunctionMapper
 
apply(Object, Object) - Method in class org.infinispan.compat.BiFunctionMapper
 
apply(Object, EntryView.ReadWriteEntryView<K, Object>) - Method in class org.infinispan.atomic.impl.ApplyDelta
 
apply(K) - Method in class org.infinispan.cache.impl.EncoderKeyMapper
 
apply(CacheMode) - Method in enum org.infinispan.configuration.parsing.Parser.Mode
 
apply(InvocationContext, VisitableCommand, Object) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadOnlyManyHelper
 
apply(InvocationContext, VisitableCommand, Object) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
 
apply(InvocationContext, VisitableCommand, Object) - Method in class org.infinispan.interceptors.impl.MultiSubCommandInvoker
 
apply(InvocationContext, VisitableCommand, Object) - Method in interface org.infinispan.interceptors.InvocationSuccessFunction
Process the result from a successful invocation stage and either return a simple value, return a new InvocationStage, or throw an exception.
apply(InvocationContext, VisitableCommand, Object, Throwable) - Method in class org.infinispan.interceptors.impl.QueueAsyncInvocationStage
 
apply(InvocationContext, VisitableCommand, Object, Throwable) - Method in interface org.infinispan.interceptors.InvocationCallback
Process the result or the exception from an invocation stage and either return a simple value, return a new InvocationStage, or throw an exception.
apply(InvocationContext, VisitableCommand, Object, Throwable) - Method in interface org.infinispan.interceptors.InvocationExceptionFunction
 
apply(InvocationContext, VisitableCommand, Object, Throwable) - Method in interface org.infinispan.interceptors.InvocationFinallyAction
 
apply(InvocationContext, VisitableCommand, Object, Throwable) - Method in interface org.infinispan.interceptors.InvocationSuccessAction
 
apply(InvocationContext, VisitableCommand, Object, Throwable) - Method in interface org.infinispan.interceptors.InvocationSuccessFunction
 
apply(InvocationContext, VisitableCommand, Throwable) - Method in interface org.infinispan.interceptors.InvocationExceptionFunction
Process the result from a successful invocation stage and either return a simple value, return a new InvocationStage, or throw an exception.
apply(EntryView.ReadWriteEntryView<K, V>) - Method in class org.infinispan.commands.functional.functions.MergeFunction
 
apply(EntryView.ReadWriteEntryView<K, V>) - Method in interface org.infinispan.commands.functional.Mutation
Mutate the view
apply(T) - Method in class org.infinispan.cache.impl.EncoderEntryMapper
 
apply(V) - Method in class org.infinispan.cache.impl.EncoderValueMapper
 
applyAsInt(Object) - Method in interface org.infinispan.distribution.ch.KeyPartitioner
 
applyDelta(K, Delta, Object...) - Method in interface org.infinispan.AdvancedCache
Deprecated.
since 9.1
applyDelta(K, Delta, Object...) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
applyDelta(K, Delta, Object...) - Method in class org.infinispan.cache.impl.CacheImpl
 
applyDelta(K, Delta, Object...) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
applyDelta(K, Delta, Object...) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
ApplyDelta<K> - Class in org.infinispan.atomic.impl
Replacement for ApplyDeltaCommand and Flag.DELTA_WRITE.
ApplyDelta(Marshaller) - Constructor for class org.infinispan.atomic.impl.ApplyDelta
 
ApplyDelta.Externalizer - Class in org.infinispan.atomic.impl
Deprecated.
ApplyDeltaCommand - Class in org.infinispan.commands.write
Deprecated.
since 9.1
ApplyDeltaCommand() - Constructor for class org.infinispan.commands.write.ApplyDeltaCommand
Deprecated.
 
ApplyDeltaCommand(Object, Delta, Collection<Object>, CommandInvocationId) - Constructor for class org.infinispan.commands.write.ApplyDeltaCommand
Deprecated.
 
applyListener(Caffeine<K, InternalCacheEntry<K, V>>, EvictionListener<K, InternalCacheEntry<K, V>>, CacheWriter<K, InternalCacheEntry<K, V>>) - Static method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
applyLocalResult(MergingCompletableFuture, Object) - Method in interface org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadManyCommandHelper
 
applyLocalResult(MergingCompletableFuture, Object) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadOnlyManyHelper
 
applyModificationsSync(List<Modification>) - Method in class org.infinispan.persistence.async.AsyncCacheWriter
 
applyState(Address, int, boolean, Collection<StateChunk>) - Method in interface org.infinispan.statetransfer.StateConsumer
 
applyState(Address, int, boolean, Collection<StateChunk>) - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
applyState(XSiteState[]) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateConsumer
It applies state from other site.
applyState(XSiteState[]) - Method in class org.infinispan.xsite.statetransfer.XSiteStateConsumerImpl
 
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.
areLocksReleased() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
areLocksReleased() - Method in interface org.infinispan.transaction.xa.CacheTransaction
Deprecated.
asCompletionException(Throwable) - Static method in class org.infinispan.util.concurrent.CompletableFutures
 
AsDoubleIntOperation - Class in org.infinispan.stream.impl.intops.primitive.i
Performs as double operation on a IntStream
AsDoubleLongOperation - Class in org.infinispan.stream.impl.intops.primitive.l
Performs as double operation on a LongStream
asDoubleStream() - Method in interface org.infinispan.IntCacheStream
asDoubleStream() - Method in interface org.infinispan.LongCacheStream
asDoubleStream() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
asDoubleStream() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
asDoubleStream() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
asDoubleStream() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
asDoubleStream() - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
asDoubleStream() - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
asIterator(Traversable<T>) - Static method in class org.infinispan.functional.impl.Traversables
 
asList() - Method in class org.infinispan.interceptors.InterceptorChain
Deprecated.
Returns an unmofiable list with all the interceptors in sequence.
AsLongIntOperation - Class in org.infinispan.stream.impl.intops.primitive.i
Performs as long operation on a IntStream
asLongStream() - Method in interface org.infinispan.IntCacheStream
asLongStream() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
asLongStream() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
asLongStream() - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
assertAllowInvocation() - Method in class org.infinispan.xsite.BaseBackupReceiver
 
assertBatchingSupported(Configuration) - Static method in class org.infinispan.batch.AutoBatchSupport
 
assertTypeConstructable(Class<?>, Class<?>...) - Method in class org.infinispan.factories.AbstractComponentFactory
 
async - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
async() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
Configuration for the async cache loader.
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 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 - org.infinispan.configuration.cache.BackupConfiguration.BackupStrategy
 
ASYNC - org.infinispan.configuration.parsing.Element
 
ASYNC - org.infinispan.configuration.parsing.Parser.Mode
 
ASYNC - org.infinispan.functional.Param.ReplicationMode
Invoking node does not know when the owners are updated nor if the command fails.
ASYNC - org.infinispan.persistence.manager.PersistenceManager.AccessMode
The operation is performed only in a CacheWriter or CacheLoader that has async write behind.
ASYNC_EXECUTOR - org.infinispan.configuration.parsing.Attribute
 
ASYNC_MARSHALLING - org.infinispan.configuration.parsing.Attribute
Deprecated.
ASYNC_NOTIFICATION_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
ASYNC_OPERATIONS_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
ASYNC_REPLICATION_QUEUE_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
Deprecated.
Since 9.0, no longer used.
ASYNC_TRANSPORT_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
AsyncCacheLoader<K,​V> - 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 - Variable in class org.infinispan.persistence.async.AsyncCacheWriter
 
asyncExecutor - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
ASYNCHRONOUS - org.infinispan.remoting.rpc.ResponseMode
 
asyncInterceptor() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
AsyncInterceptor - Interface in org.infinispan.interceptors
Interface for sequential interceptors.
AsyncInterceptorChain - Interface in org.infinispan.interceptors
Interceptor chain using AsyncInterceptors.
AsyncInterceptorChainImpl - Class in org.infinispan.interceptors.impl
Knows how to build and manage a chain of interceptors.
AsyncInterceptorChainImpl(ComponentMetadataRepo) - Constructor for class org.infinispan.interceptors.impl.AsyncInterceptorChainImpl
 
asyncInvokeNext(InvocationContext, VisitableCommand, Collection<? extends CompletionStage<?>>) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
Suspend invocation until all delays complete, then if successful invoke the next interceptor.
asyncInvokeNext(InvocationContext, VisitableCommand, CompletionStage<?>) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
Suspend the invocation until delay completes, then if successful invoke the next interceptor.
asyncInvokeNext(InvocationContext, VisitableCommand, InvocationStage) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
Suspend the invocation until invocationStage completes, then if successful invoke the next interceptor.
asyncListenerExecutor() - Method in class org.infinispan.configuration.global.GlobalConfiguration
Deprecated.
This method always returns null now. Look for a thread pool named as GlobalConfiguration.listenerThreadPool() instead.
asyncProcessor - Variable in class org.infinispan.notifications.impl.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.
asyncThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
asyncThreadPool() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
Configuration for the asynchronous operations thread pool
asyncTransportExecutor() - Method in class org.infinispan.configuration.global.GlobalConfiguration
Deprecated.
This method always returns null now. Look for a thread pool named as TransportConfiguration.transportThreadPool() instead.
asyncValue(CompletionStage<?>) - Static method in class org.infinispan.interceptors.BaseAsyncInterceptor
Suspend the invocation until valueFuture completes, then return its result without running the remaining interceptors.
atomicFineGrainedNeedsExplicitTxOrAutoCommit() - Method in class org.infinispan.util.logging.Log_$logger
 
atomicFineGrainedNeedsExplicitTxOrAutoCommit() - Method in interface org.infinispan.util.logging.Log
 
atomicFineGrainedNeedsExplicitTxOrAutoCommit$str() - Method in class org.infinispan.util.logging.Log_$logger
 
atomicFineGrainedNeedsGroups() - Method in class org.infinispan.util.logging.Log_$logger
 
atomicFineGrainedNeedsGroups() - Method in interface org.infinispan.util.logging.Log
 
atomicFineGrainedNeedsGroups$str() - Method in class org.infinispan.util.logging.Log_$logger
 
atomicFineGrainedNeedsTransactions() - Method in class org.infinispan.util.logging.Log_$logger
 
atomicFineGrainedNeedsTransactions() - Method in interface org.infinispan.util.logging.Log
 
atomicFineGrainedNeedsTransactions$str() - Method in class org.infinispan.util.logging.Log_$logger
 
AtomicKeySetImpl<K> - Class in org.infinispan.atomic.impl
This class is expected to be modified without locking, and results merged using the AtomicKeySetImpl.merge(Object) method when committing to DC.
AtomicKeySetImpl.Externalizer - Class in org.infinispan.atomic.impl
 
AtomicKeySetImpl.FunctionExternalizer - Class in org.infinispan.atomic.impl
 
AtomicMap<K,​V> - Interface in org.infinispan.atomic
This is a special type of Map geared for use in Infinispan.
atomicMapDoesNotExist() - Method in class org.infinispan.util.logging.Log_$logger
 
atomicMapDoesNotExist() - Method in interface org.infinispan.util.logging.Log
 
atomicMapDoesNotExist$str() - Method in class org.infinispan.util.logging.Log_$logger
 
atomicMapHasWrongType(Object, Class<?>) - Method in class org.infinispan.util.logging.Log_$logger
 
atomicMapHasWrongType(Object, Class<?>) - Method in interface org.infinispan.util.logging.Log
 
atomicMapHasWrongType$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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
 
AtomicMapProxyImpl<K,​V,​MK> - Class in org.infinispan.atomic.impl
This is the proxy class driving access to the entry in cache using functional API.
AtomicMapProxyImpl(Cache<MK, Object>, FunctionalMap.ReadWriteMap<MK, Object>, MK) - Constructor for class org.infinispan.atomic.impl.AtomicMapProxyImpl
 
AtomicMapProxyImpl.Externalizer - Class in org.infinispan.atomic.impl
 
Attribute - Enum in org.infinispan.configuration.parsing
Enumerates the attributes used in Infinispan
attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.ClusterLoaderConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.Configuration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.ContentTypeConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.CustomStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.DataContainerConfiguration
Deprecated.
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.MemoryConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.SingletonStoreConfiguration
Deprecated.
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.ExecutorFactoryConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.GlobalStateConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfiguration
 
attributeNotAllowedInInvalidationMode(String) - Method in class org.infinispan.util.logging.Log_$logger
 
attributeNotAllowedInInvalidationMode(String) - Method in interface org.infinispan.util.logging.Log
 
attributeNotAllowedInInvalidationMode$str() - Method in class org.infinispan.util.logging.Log_$logger
 
attributes - Variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
attributes - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.AuthorizationConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.BackupConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.BackupForConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.CompatibilityModeConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.Configuration
 
attributes() - Method in class org.infinispan.configuration.cache.ContentTypeConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.DataContainerConfiguration
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfiguration
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.cache.EvictionConfiguration
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.cache.ExpirationConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.GroupsConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.HashConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.L1Configuration
 
attributes() - Method in class org.infinispan.configuration.cache.LockingConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.RecoveryConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.SingletonStoreConfiguration
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.cache.SitesConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.cache.SyncConfiguration
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.cache.TakeOfflineConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.UnsafeConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.VersioningConfiguration
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.SerializationConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
attributes() - Method in class org.infinispan.configuration.internal.PrivateGlobalConfiguration
 
audit(Subject, AuditContext, String, AuthorizationPermission, AuditResponse) - Method in interface org.infinispan.security.AuditLogger
 
audit(Subject, AuditContext, String, AuthorizationPermission, AuditResponse) - Method in class org.infinispan.security.impl.LoggingAuditLogger
 
audit(Subject, AuditContext, String, AuthorizationPermission, AuditResponse) - Method in class org.infinispan.security.impl.NullAuditLogger
 
AUDIT_LOGGER - org.infinispan.configuration.parsing.Attribute
 
AUDIT_LOGGER - Static variable in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
AuditContext - Enum in org.infinispan.security
AuditContext.
auditLogger() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
auditLogger(AuditLogger) - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
The instance of an AuditLogger to be used to track operations performed on caches and cachemanagers.
AuditLogger - Interface in org.infinispan.security
AuditLogger.
auditMessage(AuditResponse, Principal, AuthorizationPermission, AuditContext, String) - Method in class org.infinispan.security.impl.AuditMessages_$logger
 
auditMessage(AuditResponse, Principal, AuthorizationPermission, AuditContext, String) - Method in interface org.infinispan.security.impl.AuditMessages
 
auditMessage$str() - Method in class org.infinispan.security.impl.AuditMessages_$logger
 
AuditMessages - Interface in org.infinispan.security.impl
AuditMessages.
AuditMessages_$logger - Class in org.infinispan.security.impl
Warning this class consists of generated code.
AuditMessages_$logger(Logger) - Constructor for class org.infinispan.security.impl.AuditMessages_$logger
 
AuditResponse - Enum in org.infinispan.security
 
authorization() - Method in class org.infinispan.configuration.cache.SecurityConfiguration
 
authorization() - Method in class org.infinispan.configuration.cache.SecurityConfigurationBuilder
 
authorization() - Method in interface org.infinispan.configuration.cache.SecurityConfigurationChildBuilder
 
authorization() - Method in class org.infinispan.configuration.global.GlobalSecurityConfiguration
 
authorization() - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
 
authorization() - Method in interface org.infinispan.configuration.global.GlobalSecurityConfigurationChildBuilder
Defines global roles as groups of permissions
AUTHORIZATION - org.infinispan.configuration.parsing.Element
 
AuthorizationConfiguration - Class in org.infinispan.configuration.cache
AuthorizationConfiguration.
AuthorizationConfigurationBuilder - Class in org.infinispan.configuration.cache
AuthorizationConfigurationBuilder.
AuthorizationConfigurationBuilder(SecurityConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
authorizationEnabledWithoutSecurityManager() - Method in class org.infinispan.util.logging.Log_$logger
 
authorizationEnabledWithoutSecurityManager() - Method in interface org.infinispan.util.logging.Log
 
authorizationEnabledWithoutSecurityManager$str() - Method in class org.infinispan.util.logging.Log_$logger
 
AuthorizationHelper - Class in org.infinispan.security.impl
AuthorizationHelper.
AuthorizationHelper(GlobalSecurityConfiguration, AuditContext, String) - Constructor for class org.infinispan.security.impl.AuthorizationHelper
 
AuthorizationHelper(GlobalSecurityConfiguration, AuditContext, String, ConcurrentMap<CachePrincipalPair, SubjectACL>) - Constructor for class org.infinispan.security.impl.AuthorizationHelper
 
AuthorizationManager - Interface in org.infinispan.security
The AuthorizationManager is a cache-scoped component which verifies that the Subject associated with the current AccessControlContext, or explicitly specified, has the requested permissions.
AuthorizationManagerFactory - Class in org.infinispan.factories
 
AuthorizationManagerFactory() - Constructor for class org.infinispan.factories.AuthorizationManagerFactory
 
AuthorizationManagerImpl - Class in org.infinispan.security.impl
AuthorizationManagerImpl.
AuthorizationManagerImpl() - Constructor for class org.infinispan.security.impl.AuthorizationManagerImpl
 
AuthorizationPermission - Enum in org.infinispan.security
AuthorizationPermission.
AUTO_COMMIT - org.infinispan.configuration.parsing.Attribute
 
AUTO_COMMIT - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
 
AUTO_CONFIG - org.infinispan.configuration.parsing.Attribute
 
AUTO_CONFIG - Static variable in class org.infinispan.configuration.cache.IndexingConfiguration
 
AutoBatchSupport - Class in org.infinispan.batch
Enables for automatic batching.
AutoBatchSupport() - Constructor for class org.infinispan.batch.AutoBatchSupport
 
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.
autoConfig() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
Determines if autoconfig is enabled for this IndexingConfiguration
autoConfig() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
autoConfig(boolean) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
When enabled, applies to properties default configurations based on the cache type
AutoInstantiableFactory - Interface in org.infinispan.factories
Component factories that implement this interface can be instantiated automatically by component registries when looking up components.
AVAILABILITY_INTERVAL - org.infinispan.configuration.parsing.Attribute
 
AVAILABILITY_INTERVAL - Static variable in class org.infinispan.configuration.cache.PersistenceConfiguration
 
AVAILABILITY_MODE_CHANGE - org.infinispan.topology.CacheTopologyControlCommand.Type
 
AvailabilityException - Exception in org.infinispan.partitionhandling
Thrown when a partition happened and the key that an operation tries to access is not available.
AvailabilityException() - Constructor for exception org.infinispan.partitionhandling.AvailabilityException
 
AvailabilityException(String) - Constructor for exception org.infinispan.partitionhandling.AvailabilityException
 
AvailabilityException(String, Throwable) - Constructor for exception org.infinispan.partitionhandling.AvailabilityException
 
AvailabilityException(Throwable) - Constructor for exception org.infinispan.partitionhandling.AvailabilityException
 
availabilityInterval() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
 
availabilityInterval(int) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
AvailabilityMode - Enum in org.infinispan.partitionhandling
 
AvailabilityMode.Externalizer - Class in org.infinispan.partitionhandling
 
AvailabilityStrategy - Interface in org.infinispan.partitionhandling.impl
Implementations decide what to do when the cache membership changes, either because new nodes joined, nodes left, or there was a merge.
AvailabilityStrategyContext - Interface in org.infinispan.partitionhandling.impl
Contains information about the current state of the cache.
available() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfiguration
If set to false, statistics gathering cannot be enabled during runtime.
available() - Method in class org.infinispan.io.GridInputStream
 
available() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
available(boolean) - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
If set to false, statistics gathering cannot be enabled during runtime.
AVAILABLE - org.infinispan.partitionhandling.AvailabilityMode
Regular operation mode
AVAILABLE - Static variable in class org.infinispan.configuration.cache.JMXStatisticsConfiguration
 
AvailablePartitionHandlingManager - Class in org.infinispan.partitionhandling.impl
PartitionHandlingManager implementation when the cluster is always available.
average() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
average() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
average() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
average() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
average() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
average() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
average() - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
average() - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
average() - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
await() - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
await(long, TimeUnit) - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
await(CompletableFuture<?>, long, TimeUnit) - Static method in class org.infinispan.util.concurrent.CompletableFutures
It waits until the CompletableFuture is completed.
await(CompletableFuture<T>) - Static method in class org.infinispan.util.concurrent.CompletableFutures
Wait for a long time until the CompletableFuture is completed.
AWAIT_INITIAL_TRANSFER - org.infinispan.configuration.parsing.Attribute
 
AWAIT_INITIAL_TRANSFER - Static variable in class org.infinispan.configuration.cache.StateTransferConfiguration
 
awaitCompletion(Object, long, TimeUnit) - Method in interface org.infinispan.stream.impl.ClusterStreamManager
Awaits completion of the given request.
awaitCompletion(Object, long, TimeUnit) - Method in class org.infinispan.stream.impl.ClusterStreamManagerImpl
 
awaitCompletion(Object, long, TimeUnit) - Method in class org.infinispan.stream.impl.PartitionAwareClusterStreamManager
 
awaitCompletion(Object, long, TimeUnit) - Method in class org.infinispan.stream.impl.tx.TxClusterStreamManager
 
awaitForPushToFinish(Future<?>, long, TimeUnit) - Method in class org.infinispan.persistence.support.SingletonCacheWriter
Deprecated.
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).
awaitInitialTransferOnlyForDistOrRepl() - Method in class org.infinispan.util.logging.Log_$logger
 
awaitInitialTransferOnlyForDistOrRepl() - Method in interface org.infinispan.util.logging.Log
 
awaitInitialTransferOnlyForDistOrRepl$str() - Method in class org.infinispan.util.logging.Log_$logger
 
awaitPendingTransactionsForAllKeys(TxInvocationContext<?>, Collection<Object>, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultPendingLockManager
 
awaitPendingTransactionsForAllKeys(TxInvocationContext<?>, Collection<Object>, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.NoOpPendingLockManager
 
awaitPendingTransactionsForAllKeys(TxInvocationContext<?>, Collection<Object>, long, TimeUnit) - Method in interface org.infinispan.util.concurrent.locks.PendingLockManager
It waits for any transaction with older topology id to complete that may have the lock for any key in keys acquired.
awaitPendingTransactionsForKey(TxInvocationContext<?>, Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultPendingLockManager
 
awaitPendingTransactionsForKey(TxInvocationContext<?>, Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.NoOpPendingLockManager
 
awaitPendingTransactionsForKey(TxInvocationContext<?>, Object, long, TimeUnit) - Method in interface org.infinispan.util.concurrent.locks.PendingLockManager
It waits for any transaction with older topology id to complete that may have the lock for key acquired.
awaitTermination(long, TimeUnit) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
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.impl.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

backgroundTaskFinished(Callable<T>) - Method in class org.infinispan.executors.SemaphoreCompletionService
Signal that a task that called SemaphoreCompletionService.continueTaskInBackground() has finished and optionally execute another task on the just-freed thread.
BackingKeySet(Cache<K, V>, CacheSet<K>, FlagAffectedCommand) - Constructor for class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingKeySet
 
backup() - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
backup() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
 
BACKUP - org.infinispan.configuration.parsing.Element
 
BACKUP - org.infinispan.distribution.Ownership
this node is the backup owner.
BACKUP_FAILURE_POLICY - org.infinispan.configuration.parsing.Attribute
 
BACKUP_FOR - org.infinispan.configuration.parsing.Element
 
backupAck(long, Address, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
Acknowledges a write operation completion in the backup owner.
BackupAckCommand - Class in org.infinispan.commands.write
A command that represents an acknowledge sent by a backup owner to the originator.
BackupAckCommand() - Constructor for class org.infinispan.commands.write.BackupAckCommand
 
BackupAckCommand(ByteString) - Constructor for class org.infinispan.commands.write.BackupAckCommand
 
BackupAckCommand(ByteString, long, int) - Constructor for class org.infinispan.commands.write.BackupAckCommand
 
backupAddress - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
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(AttributeSet, TakeOfflineConfiguration, XSiteStateTransferConfiguration) - 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() - Constructor for exception org.infinispan.xsite.BackupFailureException
 
BackupFailureException(String) - 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 - 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(AttributeSet) - Constructor for class org.infinispan.configuration.cache.BackupForConfiguration
 
backupForMissingParameters() - Method in class org.infinispan.util.logging.Log_$logger
 
backupForMissingParameters() - Method in interface org.infinispan.util.logging.Log
 
backupForMissingParameters$str() - Method in class org.infinispan.util.logging.Log_$logger
 
backupForNullCache() - Method in class org.infinispan.util.logging.Log_$logger
 
backupForNullCache() - Method in interface org.infinispan.util.logging.Log
 
backupForNullCache$str() - Method in class org.infinispan.util.logging.Log_$logger
 
backupFrom(CommandsFactory, ReadWriteKeyCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, ReadWriteKeyValueCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, ReadWriteManyCommand<K, V, R>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, ReadWriteManyEntriesCommand<K, V, T, R>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, WriteOnlyKeyCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, WriteOnlyKeyValueCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, WriteOnlyManyCommand<K, V>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, WriteOnlyManyEntriesCommand<K, V, T>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, ComputeCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, ComputeIfAbsentCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, PutKeyValueCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, PutMapCommand, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, RemoveCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, ReplaceCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupMissingSite() - Method in class org.infinispan.util.logging.Log_$logger
 
backupMissingSite() - Method in interface org.infinispan.util.logging.Log
 
backupMissingSite$str() - Method in class org.infinispan.util.logging.Log_$logger
 
BackupMultiKeyAckCommand - Class in org.infinispan.commands.write
A command that represents an acknowledge sent by a backup owner to the originator.
BackupMultiKeyAckCommand() - Constructor for class org.infinispan.commands.write.BackupMultiKeyAckCommand
 
BackupMultiKeyAckCommand(ByteString) - Constructor for class org.infinispan.commands.write.BackupMultiKeyAckCommand
 
BackupMultiKeyAckCommand(ByteString, long, int, int) - Constructor for class org.infinispan.commands.write.BackupMultiKeyAckCommand
 
backupPrepare(PrepareCommand, AbstractCacheTransaction) - Method in interface org.infinispan.xsite.BackupSender
Prepares a transaction on the remote site.
backupPrepare(PrepareCommand, AbstractCacheTransaction) - Method in class org.infinispan.xsite.BackupSenderImpl
 
backupQueue - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
BackupReceiver - Interface in org.infinispan.xsite
Component present on a backup site that manages the backup information and logic.
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>, XSiteReplicateCommand) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
backupRemotely(Collection<XSiteBackup>, XSiteReplicateCommand) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
backupRemotely(Collection<XSiteBackup>, XSiteReplicateCommand) - 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
 
BACKUPS - org.infinispan.configuration.parsing.Element
 
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
 
backupWrite(WriteCommand) - Method in interface org.infinispan.xsite.BackupSender
 
backupWrite(WriteCommand) - Method in class org.infinispan.xsite.BackupSenderImpl
 
BackupWriteCommand - Class in org.infinispan.commands.triangle
A write operation sent from the primary owner to the backup owners.
BaseAsyncInterceptor - Class in org.infinispan.interceptors
Base class for an interceptor in the new asynchronous invocation chain.
BaseAsyncInterceptor() - Constructor for class org.infinispan.interceptors.BaseAsyncInterceptor
 
BaseBackupInterceptor - Class in org.infinispan.interceptors.xsite
 
BaseBackupInterceptor() - Constructor for class org.infinispan.interceptors.xsite.BaseBackupInterceptor
 
BaseBackupReceiver - Class in org.infinispan.xsite
Common implementation logic for BackupReceiver
BaseBackupReceiver(Cache<Object, Object>) - Constructor for class org.infinispan.xsite.BaseBackupReceiver
 
BaseBlockingRunnable - Class in org.infinispan.remoting.inboundhandler
Common logic to handle CacheRpcCommand.
BaseBlockingRunnable(BasePerCacheInboundInvocationHandler, CacheRpcCommand, Reply, boolean) - Constructor for class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
 
BaseCacheEntryListenerInvocation(ListenerInvocation<Event<K, V>>, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, ?>, Class<? extends Annotation>, boolean, boolean, UUID, boolean, Listener.Observation, Set<Class<? extends Annotation>>, DataConversion, DataConversion, boolean) - Constructor for class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
BaseCacheStream<T,​S extends BaseStream<T,​S>> - Interface in org.infinispan
Interface that defines the base methods of all streams returned from a Cache.
BaseCacheStream.SegmentCompletionListener - Interface in org.infinispan
Functional interface that is used as a callback when segments are completed.
BaseClusteredReadCommand - Class in org.infinispan.commands.remote
 
BaseClusteredReadCommand(ByteString, long) - Constructor for class org.infinispan.commands.remote.BaseClusteredReadCommand
 
BaseCustomAsyncInterceptor - Class in org.infinispan.interceptors
Anyone using the AsyncInterceptorChain.addInterceptor(AsyncInterceptor, 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.
BaseCustomAsyncInterceptor() - Constructor for class org.infinispan.interceptors.BaseCustomAsyncInterceptor
 
BaseCustomInterceptor - Class in org.infinispan.interceptors.base
Deprecated.
Since 9.0, use BaseCustomAsyncInterceptor instead.
BaseCustomInterceptor() - Constructor for class org.infinispan.interceptors.base.BaseCustomInterceptor
Deprecated.
 
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
 
BaseDistributionInterceptor.ReadManyCommandHelper<C> - Interface in org.infinispan.interceptors.distribution
 
BaseDistributionInterceptor.ReadOnlyManyHelper - Class in org.infinispan.interceptors.distribution
 
BaseDistributionInterceptor.RemoteGetAllHandler - Interface in org.infinispan.interceptors.distribution
 
BaseLockingAction - Class in org.infinispan.remoting.inboundhandler.action
A base Action implementation for locking.
BaseLockingAction(DistributionManager) - Constructor for class org.infinispan.remoting.inboundhandler.action.BaseLockingAction
 
BaseLockingAction.InternalState - Enum in org.infinispan.remoting.inboundhandler.action
 
BasePerCacheInboundInvocationHandler - Class in org.infinispan.remoting.inboundhandler
Implementation with the default handling methods and utilities methods.
BasePerCacheInboundInvocationHandler() - Constructor for class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
 
BaseRpcCommand - Class in org.infinispan.commands.remote
 
BaseRpcCommand(ByteString) - Constructor for class org.infinispan.commands.remote.BaseRpcCommand
 
BaseRpcInterceptor - Class in org.infinispan.interceptors.impl
Acts as a base for all RPC calls
BaseRpcInterceptor() - Constructor for class org.infinispan.interceptors.impl.BaseRpcInterceptor
 
BaseRpcInvokingCommand - Class in org.infinispan.commands.remote
Deprecated.
Since 9.0, it will be removed soon
BaseRpcInvokingCommand(ByteString) - Constructor for class org.infinispan.commands.remote.BaseRpcInvokingCommand
Deprecated.
 
BaseStateTransferInterceptor - Class in org.infinispan.interceptors.impl
A base class for a state transfer interceptor.
BaseStateTransferInterceptor() - Constructor for class org.infinispan.interceptors.impl.BaseStateTransferInterceptor
 
BaseStateTransferInterceptor.LostDataVisitor - Class in org.infinispan.interceptors.impl
 
BaseTerminalOperation<Original> - Class in org.infinispan.stream.impl.termop
Abstract instance that provides common code needed for all terminal operations.
BaseTerminalOperation(Iterable<IntermediateOperation>, Supplier<Stream<Original>>) - Constructor for class org.infinispan.stream.impl.termop.BaseTerminalOperation
 
basicComponentRegistry - Variable in class org.infinispan.factories.AbstractNamedCacheComponentFactory
 
BasicComponentRegistry - Interface in org.infinispan.factories.impl
Basic dependency injection container.
BasicComponentRegistryImpl - Class in org.infinispan.factories.impl
 
BasicComponentRegistryImpl(ClassLoader, ComponentMetadataRepo, Scopes, BasicComponentRegistry) - Constructor for class org.infinispan.factories.impl.BasicComponentRegistryImpl
 
BasicEventLogger - Class in org.infinispan.util.logging.events.impl
BasicEventLogger.
BasicEventLogger() - Constructor for class org.infinispan.util.logging.events.impl.BasicEventLogger
 
BATCH - org.infinispan.configuration.parsing.Parser.TransactionMode
 
batchContainer - Variable in class org.infinispan.batch.AutoBatchSupport
 
batchContainer - Variable in class org.infinispan.cache.impl.CacheImpl
 
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
 
BatchingClusterEventManagerImpl<K,​V> - Class in org.infinispan.notifications.cachelistener.cluster.impl
 
BatchingClusterEventManagerImpl() - Constructor for class org.infinispan.notifications.cachelistener.cluster.impl.BatchingClusterEventManagerImpl
 
BatchingClusterEventManagerImpl.UnicastEventContext<K,​V> - Class in org.infinispan.notifications.cachelistener.cluster.impl
 
BatchingInterceptor - Class in org.infinispan.interceptors.impl
Interceptor that captures batched calls and attaches contexts.
BatchingInterceptor() - Constructor for class org.infinispan.interceptors.impl.BatchingInterceptor
 
BatchModeTransactionManager - Class in org.infinispan.transaction.tm
Not really a transaction manager in the truest sense of the word.
BatchModification - Class in org.infinispan.persistence.support
A simple wrapper class, necessary for Transactional stores, which allows MarshalledEntries and Object keys to be passed to a store implementation in order.
BatchModification(Set<Object>) - Constructor for class org.infinispan.persistence.support.BatchModification
 
batchSize - Variable in class org.infinispan.stream.impl.StreamIteratorNextCommand
 
becomeCoordinator(String) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
Makes this node the coordinator for the state transfer to the site name.
becomeCoordinator(String) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
before() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
before(Class<? extends AsyncInterceptor>) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
Dictates that the custom interceptor appears immediately before the specified interceptor.
BEFORE - org.infinispan.configuration.parsing.Attribute
 
BEFORE - org.infinispan.container.versioning.InequalVersionComparisonResult
Denotes a version that was created temporally before another version.
BEFORE - Static variable in class org.infinispan.configuration.cache.InterceptorConfiguration
 
beforeBackupRemotely(XSiteReplicateCommand) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
method invoked before a backup remote invocation.
beforeCompletion() - Method in class org.infinispan.transaction.synchronization.SynchronizationAdapter
 
beforeCompletion(LocalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
 
beforeCompletionFailed(Synchronization, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
beforeCompletionFailed(Synchronization, Throwable) - Method in interface org.infinispan.util.logging.Log
 
beforeCompletionFailed$str() - Method in class org.infinispan.util.logging.Log_$logger
 
beforeConfirmRebalancePhase(String, int, Throwable) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
beforeHandle(CacheRpcCommand, Reply, DeliverOrder) - Method in class org.infinispan.remoting.inboundhandler.AbstractDelegatingHandler
Invoked before the command is handled by the real PerCacheInboundInvocationHandler.
beforeHandleRebalance(String, CacheTopology, int) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
beforeHandleTopologyUpdate(String, CacheTopology, int) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
beforeInvalidation(IntSet, IntSet) - Method in interface org.infinispan.statetransfer.StateConsumerImpl.KeyInvalidationListener
 
beforeInvoke() - Method in class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
 
beforeInvoke() - Method in class org.infinispan.remoting.inboundhandler.DefaultTopologyRunnable
 
beforeInvokeRemotely(ReplicableCommand) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
method invoked before a remote invocation.
beforeTopologyInstalled(int, boolean, ConsistentHash, ConsistentHash) - Method in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
beforeTopologyInstalled(int, boolean, ConsistentHash, ConsistentHash) - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
begin() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Deprecated.
Starts a new transaction, and associate it with the calling thread.
begin() - Method in class org.infinispan.transaction.tm.DummyUserTransaction
Deprecated.
Starts a new transaction, and associate it with the calling thread.
begin() - Method in class org.infinispan.transaction.tm.EmbeddedUserTransaction
 
BIAS_ACQUISITION - Static variable in class org.infinispan.configuration.cache.ClusteringConfiguration
 
BIAS_LIFESPAN - Static variable in class org.infinispan.configuration.cache.ClusteringConfiguration
 
biasAcquisition() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
For scattered cache, specifies if the nodes is allowed to cache the entry, serving reads locally.
biasAcquisition(BiasAcquisition) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
Used in scattered cache.
BiasAcquisition - Enum in org.infinispan.configuration.cache
Specifies when is a node allowed to acquire a bias on an entry, serving further reads to the same key locally (despite not being an owner).
biased() - Method in interface org.infinispan.scattered.BiasManager.Revocation
 
BiasedCollector - Interface in org.infinispan.interceptors.distribution
 
BiasedEntryWrappingInterceptor - Class in org.infinispan.interceptors.impl
 
BiasedEntryWrappingInterceptor() - Constructor for class org.infinispan.interceptors.impl.BiasedEntryWrappingInterceptor
 
biasedReadsAppliesOnlyToScattered() - Method in class org.infinispan.util.logging.Log_$logger
 
biasedReadsAppliesOnlyToScattered() - Method in interface org.infinispan.util.logging.Log
 
biasedReadsAppliesOnlyToScattered$str() - Method in class org.infinispan.util.logging.Log_$logger
 
BiasedScatteredDistributionInterceptor - Class in org.infinispan.interceptors.distribution
 
BiasedScatteredDistributionInterceptor() - Constructor for class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor
 
biasLifespan() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
For scattered cache, specifies how long is the node allowed to read the cached entry locally.
biasLifespan(long, TimeUnit) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
Used in scattered cache.
biasManager - Variable in class org.infinispan.commands.write.InvalidateVersionsCommand
 
BiasManager - Interface in org.infinispan.scattered
This component tracks if this node can read the data stored locally despite not being an owner and which nodes will read the local data that is primary-owned by this node.
BiasManager.Revocation - Interface in org.infinispan.scattered
 
BiasManagerImpl - Class in org.infinispan.scattered.impl
 
BiasManagerImpl() - Constructor for class org.infinispan.scattered.impl.BiasManagerImpl
 
BiasRevocationResponse - Class in org.infinispan.remoting.responses
 
BiasRevocationResponse(Object, Address[]) - Constructor for class org.infinispan.remoting.responses.BiasRevocationResponse
 
BiasRevocationResponse.Externalizer - Class in org.infinispan.remoting.responses
 
BiFunctionMapper - Class in org.infinispan.compat
 
BiFunctionMapper(BiFunction, DataConversion, DataConversion) - Constructor for class org.infinispan.compat.BiFunctionMapper
 
BiFunctionMapper.Externalizer - Class in org.infinispan.compat
 
BINARY - org.infinispan.configuration.cache.StorageType
Entries are stored in Java heap but as byte[] instances.
BINARY - org.infinispan.configuration.parsing.Element
 
binaryParam() - Method in interface org.infinispan.filter.ParamKeyValueFilterConverterFactory
 
Bits - Class in org.infinispan.container.offheap
Utility method for inserting and retrieving values from to/from a byte[]
Bits() - Constructor for class org.infinispan.container.offheap.Bits
 
BLOCKED - org.infinispan.scattered.ScatteredVersionManager.SegmentState
 
blocking(CompletionStage<T>) - Method in interface org.infinispan.remoting.rpc.RpcManager
Block on a request and return its result.
blocking(CompletionStage<T>) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
BLOCKING_BOUNDED_QUEUE_THREAD_POOL - org.infinispan.configuration.parsing.Element
 
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
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(String, ExecutorService, TimeService) - Constructor for class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
 
bootstrapComponents() - Method in class org.infinispan.factories.ComponentRegistry
Invoked before any ModuleCommandInitializer.
BOTH - org.infinispan.notifications.Listener.Observation
Observation level used to be notified of an operation before and after it occurs
BOTH - org.infinispan.persistence.manager.PersistenceManager.AccessMode
The operation is performed in all CacheWriter or CacheLoader
boundedDataContainer(int, long, EntrySizeCalculator<? super K, ? super V>) - Static method in class org.infinispan.container.impl.DefaultDataContainer
 
boundedDataContainer(int, long, EvictionType) - Static method in class org.infinispan.container.impl.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
 
BoundedOffHeapDataContainer - Class in org.infinispan.container.offheap
 
BoundedOffHeapDataContainer(int, long, EvictionType) - Constructor for class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
BoundedSegmentedDataContainer<K,​V> - Class in org.infinispan.container.impl
Bounded implementation of segmented data container.
BoundedSegmentedDataContainer(int, long, EntrySizeCalculator<? super K, ? super InternalCacheEntry<K, V>>) - Constructor for class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
BoundedSegmentedDataContainer(int, long, EvictionType) - Constructor for class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
boxed() - Method in interface org.infinispan.DoubleCacheStream
boxed() - Method in interface org.infinispan.IntCacheStream
boxed() - Method in interface org.infinispan.LongCacheStream
boxed() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
boxed() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
boxed() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
boxed() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
boxed() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
boxed() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
boxed() - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
boxed() - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
boxed() - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
BoxedDoubleOperation - Class in org.infinispan.stream.impl.intops.primitive.d
Performs boxed operation on a DoubleStream
BoxedIntOperation - Class in org.infinispan.stream.impl.intops.primitive.i
Performs boxed operation on a IntStream
BoxedLongOperation - Class in org.infinispan.stream.impl.intops.primitive.l
Performs boxed operation on a LongStream
BRING_ONLINE - org.infinispan.xsite.XSiteAdminCommand.AdminOperation
 
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.GlobalXSiteAdminOperations
 
bringSiteOnline(String) - Method in class org.infinispan.xsite.XSiteAdminOperations
 
broadcastRebalanceStart(String, CacheTopology, boolean, boolean) - Method in interface org.infinispan.topology.ClusterTopologyManager
 
broadcastRebalanceStart(String, CacheTopology, boolean, boolean) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
broadcastShutdownCache(String, CacheTopology, boolean, boolean) - Method in interface org.infinispan.topology.ClusterTopologyManager
 
broadcastShutdownCache(String, CacheTopology, boolean, boolean) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
broadcastStableTopologyUpdate(String, CacheTopology, boolean, boolean) - Method in interface org.infinispan.topology.ClusterTopologyManager
 
broadcastStableTopologyUpdate(String, CacheTopology, boolean, boolean) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
broadcastTopologyUpdate(String, CacheTopology, AvailabilityMode, boolean, boolean) - Method in interface org.infinispan.topology.ClusterTopologyManager
 
broadcastTopologyUpdate(String, CacheTopology, AvailabilityMode, boolean, boolean) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
BROUGHT_ONLINE - org.infinispan.xsite.BackupSender.BringSiteOnlineResponse
 
build() - 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
Builds a GlobalConfiguration object using the settings applied to this builder
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.impl.DefaultConsistentHashFactory.Builder
 
build() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
build() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata.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 class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
build() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.DelegatingCacheInvocationBuilder
 
build() - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl.DefaultBuilder
 
build() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
build() - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
Deprecated.
 
build() - Method in class org.infinispan.xsite.status.AbstractSiteStatusBuilder
 
build(boolean) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
build(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
build(Publisher<T>, int, Publisher<T>, int) - Static method in class org.infinispan.stream.impl.PriorityMergingProcessor
 
buildApplyDeltaCommand(Object, Delta, Collection) - Method in interface org.infinispan.commands.CommandsFactory
Deprecated.
since 9.1
buildBackupAckCommand(long, int) - Method in interface org.infinispan.commands.CommandsFactory
 
buildBackupAckCommand(long, int) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildBackupMultiKeyAckCommand(long, int, int) - Method in interface org.infinispan.commands.CommandsFactory
 
buildBackupMultiKeyAckCommand(long, int, int) - 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(long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ClearCommand
buildClearCommand(long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildClusteredGetAllCommand(List<?>, long, GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ClusteredGetAllCommand, which is a remote lookup command
buildClusteredGetAllCommand(List<?>, long, GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildClusteredGetCommand(Object, int, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ClusteredGetCommand, which is a remote lookup command
buildClusteredGetCommand(Object, int, long) - 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
 
buildComputeCommand(Object, BiFunction, boolean, int, Metadata, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ComputeCommand
buildComputeCommand(Object, BiFunction, boolean, int, Metadata, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildComputeIfAbsentCommand(Object, Function, int, Metadata, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ComputeIfAbsentCommand
buildComputeIfAbsentCommand(Object, Function, int, Metadata, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildCreateCacheCommand(String, String) - Method in interface org.infinispan.commands.CommandsFactory
Same as buildCreateCacheCommand(cacheName, cacheConfigurationName, false, 0).
buildCreateCacheCommand(String, String) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildCreateCacheCommand(String, String, int) - Method in interface org.infinispan.commands.CommandsFactory
Builds a CreateCacheCommand used to create/start cache around Infinispan cluster
buildCreateCacheCommand(String, String, 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(long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a EntrySetCommand
buildEntrySetCommand(long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
builder() - Method in class org.infinispan.container.entries.RemoteMetadata
 
builder() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
 
builder() - Method in class org.infinispan.metadata.EmbeddedMetadata
 
builder() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
 
builder() - Method in class org.infinispan.metadata.impl.L1Metadata
 
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.
builder() - Static method in class org.infinispan.stream.impl.PriorityMergingProcessor
 
Builder() - Constructor for class org.infinispan.functional.impl.MetaParamsInternalMetadata.Builder
 
Builder() - Constructor for class org.infinispan.metadata.EmbeddedMetadata.Builder
 
Builder() - Constructor for class org.infinispan.stream.impl.PriorityMergingProcessor.Builder
 
Builder(Iterator<? extends T>) - Constructor for class org.infinispan.stream.impl.spliterators.IteratorAsSpliterator.Builder
 
Builder(Hash, int, int, List<Address>, Map<Address, Float>) - Constructor for class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
Builder(Hash, int, int, List<Address>, Map<Address, Float>) - Constructor for class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
Builder(Hash, int, int, List<Address>, Map<Address, Float>) - Constructor for class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory.Builder
 
Builder(Hash, int, List<Address>, Map<Address, Float>) - Constructor for class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
Builder(CloseableIterator<? extends T>) - Constructor for class org.infinispan.stream.impl.spliterators.IteratorAsSpliterator.Builder
 
Builder(DefaultConsistentHash) - Constructor for class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
Builder(DefaultConsistentHashFactory.Builder) - Constructor for class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
Builder(DefaultConsistentHash, List<Address>, Map<Address, Float>) - Constructor for class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
Builder(ScatteredConsistentHash) - Constructor for class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
Builder(ScatteredConsistentHashFactory.Builder) - Constructor for class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
Builder(ScatteredConsistentHash, List<Address>, Map<Address, Float>) - Constructor for class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
buildEvictCommand(Object, int, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds an EvictCommand
buildEvictCommand(Object, int, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildExceptionAckCommand(long, Throwable, int) - Method in interface org.infinispan.commands.CommandsFactory
 
buildExceptionAckCommand(long, Throwable, int) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildGetAllCommand(Collection<?>, long, boolean) - Method in interface org.infinispan.commands.CommandsFactory
Builds a GetAllCommand
buildGetAllCommand(Collection<?>, long, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildGetCacheEntryCommand(Object, int, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a GetCacheEntryCommand
buildGetCacheEntryCommand(Object, int, long) - 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
 
buildGetKeysInGroupCommand(long, Object) - Method in interface org.infinispan.commands.CommandsFactory
Builds GetKeysInGroupCommand used to fetch all the keys belonging to a group.
buildGetKeysInGroupCommand(long, Object) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildGetKeyValueCommand(Object, int, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a GetKeyValueCommand
buildGetKeyValueCommand(Object, int, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildInjectionFieldsList() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
Deprecated.
 
buildInjectionMethodsList() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
Deprecated.
 
buildInterceptorChain() - Method in class org.infinispan.factories.InterceptorChainFactory
 
buildInvalidateCommand(long, Object...) - Method in interface org.infinispan.commands.CommandsFactory
Builds an InvalidateCommand
buildInvalidateCommand(long, Object...) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildInvalidateFromL1Command(long, Collection<Object>) - Method in interface org.infinispan.commands.CommandsFactory
Builds an InvalidateFromL1Command
buildInvalidateFromL1Command(long, Collection<Object>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildInvalidateFromL1Command(Address, long, Collection<Object>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildInvalidateFromL1Command(Address, long, Collection<Object>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildInvalidateVersionsCommand(int, Object[], int[], long[], boolean) - Method in interface org.infinispan.commands.CommandsFactory
 
buildInvalidateVersionsCommand(int, Object[], int[], long[], boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildKeySetCommand(long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a KeySetCommand
buildKeySetCommand(long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildLockControlCommand(Object, long, GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Same as CommandsFactory.buildLockControlCommand(Object, long, GlobalTransaction) but for locking a single key vs a collection of keys.
buildLockControlCommand(Object, long, GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildLockControlCommand(Collection<?>, long) - Method in interface org.infinispan.commands.CommandsFactory
 
buildLockControlCommand(Collection<?>, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildLockControlCommand(Collection<?>, long, GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Builds a LockControlCommand to control explicit remote locking
buildLockControlCommand(Collection<?>, long, GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildMultiEntriesFunctionalBackupWriteCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildMultiEntriesFunctionalBackupWriteCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildMultiKeyFunctionalBackupWriteCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildMultiKeyFunctionalBackupWriteCommand() - 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, int, Metadata, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a PutKeyValueCommand
buildPutKeyValueCommand(Object, Object, int, Metadata, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildPutMapBackupWriteCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildPutMapBackupWriteCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildPutMapCommand(Map<?, ?>, Metadata, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a PutMapCommand
buildPutMapCommand(Map<?, ?>, Metadata, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReadOnlyKeyCommand(Object, Function<EntryView.ReadEntryView<K, V>, R>, int, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildReadOnlyKeyCommand(Object, Function<EntryView.ReadEntryView<K, V>, R>, int, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReadOnlyManyCommand(Collection<?>, Function<EntryView.ReadEntryView<K, V>, R>, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildReadOnlyManyCommand(Collection<?>, Function<EntryView.ReadEntryView<K, V>, R>, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReadWriteKeyCommand(Object, Function<EntryView.ReadWriteEntryView<K, V>, R>, int, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildReadWriteKeyCommand(Object, Function<EntryView.ReadWriteEntryView<K, V>, R>, int, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReadWriteKeyValueCommand(Object, Object, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>, int, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildReadWriteKeyValueCommand(Object, Object, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>, int, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReadWriteManyCommand(Collection<?>, Function<EntryView.ReadWriteEntryView<K, V>, R>, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildReadWriteManyCommand(Collection<?>, Function<EntryView.ReadWriteEntryView<K, V>, R>, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReadWriteManyEntriesCommand(Map<?, ?>, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildReadWriteManyEntriesCommand(Map<?, ?>, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRegistrar() - Method in class org.infinispan.jmx.AbstractJmxRegistration
 
buildRegistrar() - Method in class org.infinispan.jmx.CacheJmxRegistration
 
buildRegistrar() - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
 
buildRemoveCommand(Object, Object, int, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a RemoveCommand
buildRemoveCommand(Object, Object, int, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRemoveExpiredCommand(Object, Object, int, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds an expired remove command that is used to remove only a specific entry when it expires via maxIdle
buildRemoveExpiredCommand(Object, Object, int, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRemoveExpiredCommand(Object, Object, int, Long, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds an expired remove command that is used to remove only a specific entry when it expires via lifespan
buildRemoveExpiredCommand(Object, Object, int, Long, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRenewBiasCommand(Object[]) - Method in interface org.infinispan.commands.CommandsFactory
 
buildRenewBiasCommand(Object[]) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReplaceCommand(Object, Object, Object, int, Metadata, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ReplaceCommand
buildReplaceCommand(Object, Object, Object, int, Metadata, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRetrieveLastAccessCommand(Object, Object, int) - Method in interface org.infinispan.commands.CommandsFactory
Builds a retrieve max idle command that is used to get the last access time for a given key.
buildRetrieveLastAccessCommand(Object, Object, int) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRevokeBiasCommand(Address, long, int, Collection<Object>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildRevokeBiasCommand(Address, long, int, Collection<Object>) - 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
 
buildSingleKeyBackupWriteCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildSingleKeyBackupWriteCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildSingleKeyFunctionalBackupWriteCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildSingleKeyFunctionalBackupWriteCommand() - 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
 
buildSingleXSiteRpcCommand(VisitableCommand) - Method in interface org.infinispan.commands.CommandsFactory
Builds SingleRpcCommand used to perform VisitableCommand on the backup site,
buildSingleXSiteRpcCommand(VisitableCommand) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildSizeCommand(long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a SizeCommand
buildSizeCommand(long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildStateRequestCommand(StateRequestCommand.Type, Address, int, IntSet) - 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, IntSet) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildStateResponseCommand(Address, int, Collection<StateChunk>, boolean, boolean) - 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>, boolean, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildStream(IntSet, Set<?>, boolean) - Method in interface org.infinispan.stream.impl.local.AbstractLocalCacheStream.StreamSupplier
 
buildStream(IntSet, Set<?>, boolean) - Method in class org.infinispan.stream.impl.local.EntryStreamSupplier
 
buildStream(IntSet, Set<?>, boolean) - Method in class org.infinispan.stream.impl.local.KeyStreamSupplier
 
buildStream(IntSet, Set<?>, boolean) - Method in class org.infinispan.stream.impl.local.PersistenceEntryStreamSupplier
 
buildStream(IntSet, Set<?>, boolean) - Method in class org.infinispan.stream.impl.local.PersistenceKeyStreamSupplier
 
buildStream(IntSet, Set<?>, boolean) - Method in class org.infinispan.stream.impl.local.SegmentedEntryStreamSupplier
 
buildStream(IntSet, Set<?>, boolean) - Method in class org.infinispan.stream.impl.local.SegmentedKeyStreamSupplier
 
buildStreamIteratorCloseCommand(Object) - Method in interface org.infinispan.commands.CommandsFactory
 
buildStreamIteratorCloseCommand(Object) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildStreamIteratorNextCommand(Object, long) - Method in interface org.infinispan.commands.CommandsFactory
 
buildStreamIteratorNextCommand(Object, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildStreamIteratorRequestCommand(Object, boolean, IntSet, Set<K>, Set<K>, boolean, boolean, Iterable<IntermediateOperation>, long) - Method in interface org.infinispan.commands.CommandsFactory
 
buildStreamIteratorRequestCommand(Object, boolean, IntSet, Set<K>, Set<K>, boolean, boolean, Iterable<IntermediateOperation>, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildStreamRequestCommand(Object, boolean, StreamRequestCommand.Type, IntSet, Set<K>, Set<K>, boolean, boolean, Object) - Method in interface org.infinispan.commands.CommandsFactory
 
buildStreamRequestCommand(Object, boolean, StreamRequestCommand.Type, IntSet, Set<K>, Set<K>, boolean, boolean, Object) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildStreamResponseCommand(Object, boolean, IntSet, R) - Method in interface org.infinispan.commands.CommandsFactory
Builds StreamResponseCommand used to send back a response either intermediate or complete to the originating node with the information for the stream request.
buildStreamResponseCommand(Object, boolean, IntSet, R) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildTxCompletionNotificationCommand(long) - Method in interface org.infinispan.commands.CommandsFactory
 
buildTxCompletionNotificationCommand(long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildTxCompletionNotificationCommand(Xid, GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
buildTxCompletionNotificationCommand(Xid, GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildUpdateLastAccessCommand(Object, int, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds an update last access command that is used to update the last access time for a given key.
buildUpdateLastAccessCommand(Object, int, long) - 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
 
buildWriteOnlyKeyCommand(Object, Consumer<EntryView.WriteEntryView<K, V>>, int, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildWriteOnlyKeyCommand(Object, Consumer<EntryView.WriteEntryView<K, V>>, int, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildWriteOnlyKeyValueCommand(Object, Object, BiConsumer<T, EntryView.WriteEntryView<K, V>>, int, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildWriteOnlyKeyValueCommand(Object, Object, BiConsumer<T, EntryView.WriteEntryView<K, V>>, int, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildWriteOnlyManyCommand(Collection<?>, Consumer<EntryView.WriteEntryView<K, V>>, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildWriteOnlyManyCommand(Collection<?>, Consumer<EntryView.WriteEntryView<K, V>>, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildWriteOnlyManyEntriesCommand(Map<?, ?>, BiConsumer<T, EntryView.WriteEntryView<K, V>>, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildWriteOnlyManyEntriesCommand(Map<?, ?>, BiConsumer<T, EntryView.WriteEntryView<K, V>>, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteAdminCommand(String, XSiteAdminCommand.AdminOperation, Integer, Long) - Method in interface org.infinispan.commands.CommandsFactory
Builds XSiteAdminCommand used to perform system administrator operations.
buildXSiteAdminCommand(String, XSiteAdminCommand.AdminOperation, Integer, Long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteStatePushCommand(XSiteState[], long) - Method in interface org.infinispan.commands.CommandsFactory
Builds XSiteStatePushCommand used to transfer a single chunk of data between sites.
buildXSiteStatePushCommand(XSiteState[], long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteStateTransferControlCommand(XSiteStateTransferControlCommand.StateTransferControl, String) - Method in interface org.infinispan.commands.CommandsFactory
Builds XSiteStateTransferControlCommand used to control the-cross site state transfer.
buildXSiteStateTransferControlCommand(XSiteStateTransferControlCommand.StateTransferControl, String) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
BULK_READ - org.infinispan.security.AuthorizationPermission
Allows bulk-read operations (e.g.
BULK_WRITE - org.infinispan.security.AuthorizationPermission
Allows bulk-write operations (e.g.
ByteBufferImpl - Class in org.infinispan.io
Deprecated.
ByteBufferImpl(byte[], int, int) - Constructor for class org.infinispan.io.ByteBufferImpl
Deprecated.
 
ByteString - Class in org.infinispan.util
A simple class which encapsulates a byte[] representation of a String using a predefined encoding (currently UTF-8).

C

cache - Variable in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
cache - Variable in class org.infinispan.commands.read.AbstractCloseableIteratorCollection
 
cache - Variable in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
cache - Variable in class org.infinispan.interceptors.base.BaseCustomInterceptor
Deprecated.
 
cache - Variable in class org.infinispan.interceptors.BaseCustomAsyncInterceptor
 
cache - Variable in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
cache - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
cache - Variable in class org.infinispan.stream.impl.PartitionAwareClusterStreamManager
 
cache - Variable in class org.infinispan.xsite.AbstractCustomFailurePolicy
 
cache - Variable in class org.infinispan.xsite.BaseBackupReceiver
 
Cache<K,​V> - Interface in org.infinispan
The central interface of Infinispan.
CACHE - org.infinispan.configuration.parsing.ParserScope
The cache scope
CACHE - org.infinispan.security.AuditContext
 
CACHE_CONTAINER - org.infinispan.configuration.parsing.Element
 
CACHE_CONTAINER - org.infinispan.configuration.parsing.ParserScope
The cache-container scope
CACHE_DELIMITER - Static variable in class org.infinispan.xsite.GlobalXSiteAdminOperations
 
CACHE_DEPENDENCY_GRAPH - Static variable in class org.infinispan.factories.KnownComponentNames
 
CACHE_ENTRY_ACTIVATED - org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_ENTRY_CREATED - org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_ENTRY_EVICTED - org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_ENTRY_EXPIRED - org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_ENTRY_INVALIDATED - org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_ENTRY_LOADED - org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_ENTRY_MODIFIED - org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_ENTRY_PASSIVATED - org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_ENTRY_REMOVED - org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_ENTRY_VISITED - org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_JMX_GROUP - Static variable in class org.infinispan.jmx.CacheJmxRegistration
 
CACHE_MANAGER_JMX_GROUP - Static variable in class org.infinispan.jmx.CacheManagerJmxRegistration
 
CACHE_MANAGER_NAME - Static variable in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
CACHE_MODE - Static variable in class org.infinispan.configuration.cache.ClusteringConfiguration
 
CACHE_MODE_LOCAL - org.infinispan.context.Flag
Forces LOCAL mode operation, even if the cache is configured to use a clustered mode like replication, invalidation or distribution.
CACHE_MODE_LOCAL - Static variable in class org.infinispan.context.impl.FlagBitSets
 
CACHE_NAME - Static variable in class org.infinispan.factories.KnownComponentNames
 
CACHE_SCOPE - Static variable in class org.infinispan.globalstate.impl.GlobalConfigurationManagerImpl
 
CACHE_STARTED - org.infinispan.notifications.cachemanagerlistener.event.Event.Type
 
CACHE_STOP_TIMEOUT - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
 
CACHE_STOPPED - org.infinispan.notifications.cachemanagerlistener.event.Event.Type
 
CACHE_STOPPED_TOPOLOGY_ID - Static variable in class org.infinispan.transaction.impl.TransactionTable
 
CACHE_TEMPLATE - org.infinispan.configuration.parsing.ParserScope
The cache template scope
cacheAvailabilityModeChange(AvailabilityMode, int) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
cacheAvailabilityModeChange(AvailabilityMode, int) - Method in interface org.infinispan.util.logging.events.Messages
 
cacheAvailabilityModeChange$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
CacheAware<K,​V> - Interface in org.infinispan.stream
Interface that describes how a cache can be injected into another object.
cacheBackupsDataToSameSite(String) - Method in class org.infinispan.util.logging.Log_$logger
 
cacheBackupsDataToSameSite(String) - Method in interface org.infinispan.util.logging.Log
 
cacheBackupsDataToSameSite$str() - Method in class org.infinispan.util.logging.Log_$logger
 
CacheCollection<E> - Interface in org.infinispan
A collection type that returns special Cache based streams that have additional options to tweak behavior.
CacheCollectionMapper<E,​R> - Class in org.infinispan.util
Deprecated.
since 9.2.1 It is recommended to use WriteableCacheCollectionMapper instead as it allows for constant time contains and other operations
CacheCollectionMapper(CacheCollection<E>, Function<? super E, ? extends R>) - Constructor for class org.infinispan.util.CacheCollectionMapper
Deprecated.
CacheCollection that maps entries to new type that takes a key filter that is Function.identity()
CacheCollectionMapper(CacheCollection<E>, Function<? super E, ? extends R>, InjectiveFunction<Object, ?>) - Constructor for class org.infinispan.util.CacheCollectionMapper
Deprecated.
CacheCollection that maps entries to new type that takes a provided key filter.
CacheCollectors - Class in org.infinispan.stream
Helper class designed to be used to create a serializable Collector for use with CacheStream.collect(Collector) from a supplier of a collector.
cacheComponents() - Method in class org.infinispan.factories.ComponentRegistry
Invoked last after all services are wired
cacheConfiguration - Variable in class org.infinispan.interceptors.base.CommandInterceptor
Deprecated.
 
cacheConfiguration - Variable in class org.infinispan.interceptors.BaseAsyncInterceptor
 
CacheConfigurationMBean - Class in org.infinispan.cache.impl
CacheConfigurationMBeanImpl.
CacheConfigurationMBean() - Constructor for class org.infinispan.cache.impl.CacheConfigurationMBean
 
CacheContainer - Interface in org.infinispan.manager
 
CacheContainerStats - Interface in org.infinispan.stats
Similar to Stats but in the scope of a single per node CacheContainer
CacheContainerStatsImpl - Class in org.infinispan.stats.impl
Cache container statistics needed for admin console
CacheContainerStatsImpl(EmbeddedCacheManager) - Constructor for class org.infinispan.stats.impl.CacheContainerStatsImpl
 
CACHED_THREAD_POOL - org.infinispan.configuration.parsing.Element
 
CACHED_VALUES - Static variable in enum org.infinispan.functional.Param.ReplicationMode
 
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<K,​V> - 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.
CacheEntryChange() - Constructor for class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntryChange
 
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.
CacheEntryExpired - 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 expired
CacheEntryExpiredEvent<K,​V> - Interface in org.infinispan.notifications.cachelistener.event
This event subtype is passed in to any method annotated with CacheEntryExpired.
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.
CacheEntryListenerInvocation<K,​V> - Interface in org.infinispan.notifications.cachelistener
Additional listener methods specific to caches.
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
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.
cacheEntrySet() - Method in interface org.infinispan.AdvancedCache
Identical to Cache.entrySet() but is typed to return CacheEntries instead of Entries.
cacheEntrySet() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
cacheEntrySet() - Method in class org.infinispan.cache.impl.CacheImpl
 
cacheEntrySet() - Method in class org.infinispan.cache.impl.DecoratedCache
 
cacheEntrySet() - Method in class org.infinispan.cache.impl.EncoderCache
 
cacheEntrySet() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
cacheEntrySet() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
CacheEntrySet() - Constructor for class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntrySet
 
CacheEntrySizeCalculator<K,​V> - Class in org.infinispan.container.entries
Implementation of a size calculator that calcultes only the size of the value assuming it is an InternalCacheEntry.
CacheEntrySizeCalculator(EntrySizeCalculator<? super K, ? super V>) - Constructor for class org.infinispan.container.entries.CacheEntrySizeCalculator
 
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.
CacheEventConverter<K,​V,​C> - Interface in org.infinispan.notifications.cachelistener.filter
A converter that can be used to convert the value given for an event.
CacheEventConverterAsConverter<K,​V,​C> - Class in org.infinispan.notifications.cachelistener.filter
Converter that is implemented by using the provided CacheEventConverter.
CacheEventConverterAsConverter(CacheEventConverter<K, V, C>) - Constructor for class org.infinispan.notifications.cachelistener.filter.CacheEventConverterAsConverter
 
CacheEventConverterAsConverter.Externalizer - Class in org.infinispan.notifications.cachelistener.filter
 
CacheEventConverterFactory - Interface in org.infinispan.notifications.cachelistener.filter
Factory that can produce CacheEventConverters
CacheEventFilter<K,​V> - Interface in org.infinispan.notifications.cachelistener.filter
A filter that can be used to tell if an event should be raised or not.
CacheEventFilterAsKeyValueFilter<K,​V> - Class in org.infinispan.notifications.cachelistener.filter
KeyValueFilter that is implemented by using the provided CacheEventFilter.
CacheEventFilterAsKeyValueFilter(CacheEventFilter<K, V>) - Constructor for class org.infinispan.notifications.cachelistener.filter.CacheEventFilterAsKeyValueFilter
 
CacheEventFilterAsKeyValueFilter.Externalizer - Class in org.infinispan.notifications.cachelistener.filter
 
CacheEventFilterConverter<K,​V,​C> - Interface in org.infinispan.notifications.cachelistener.filter
This interface is an optimization that can be used when an event filter and converter are most efficiently used as the same object composing the filtering and conversion in the same method invocation.
CacheEventFilterConverterAsKeyValueFilterConverter<K,​V,​C> - Class in org.infinispan.notifications.cachelistener.filter
 
CacheEventFilterConverterAsKeyValueFilterConverter(CacheEventFilterConverter<K, V, C>) - Constructor for class org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverterAsKeyValueFilterConverter
 
CacheEventFilterConverterAsKeyValueFilterConverter.Externalizer - Class in org.infinispan.notifications.cachelistener.filter
 
CacheEventFilterConverterFactory - Interface in org.infinispan.notifications.cachelistener.filter
Factory that can produce CacheEventFilterConverter instances.
CacheEventFilterFactory - Interface in org.infinispan.notifications.cachelistener.filter
Factory that can produce CacheEventFilters
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).
cacheExists(String) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
cacheExists(String) - Method in class org.infinispan.util.logging.Log_$logger
 
cacheExists(String) - Method in interface org.infinispan.util.logging.Log
 
cacheExists$str() - Method in class org.infinispan.util.logging.Log_$logger
 
CacheFilters - Class in org.infinispan.filter
Static factory class that contains utility methods that can be used for performing proper transformations from KeyValueFilter, Converter & KeyValueFilterConverter to appropriate distributed stream instances.
CacheFilters.CacheFiltersExternalizer - Class in org.infinispan.filter
 
CacheFiltersExternalizer() - Constructor for class org.infinispan.filter.CacheFilters.CacheFiltersExternalizer
 
CacheHealth - Interface in org.infinispan.health
Cache health information.
CacheHealthImpl - Class in org.infinispan.health.impl
 
CacheHealthImpl(Cache<?, ?>) - Constructor for class org.infinispan.health.impl.CacheHealthImpl
 
CacheImpl<K,​V> - Class in org.infinispan.cache.impl
 
CacheImpl(String) - Constructor for class org.infinispan.cache.impl.CacheImpl
 
CacheInvocationBuilder() - Constructor for class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
cacheIsStopping(String) - Method in class org.infinispan.util.logging.Log_$logger
 
cacheIsStopping(String) - Method in interface org.infinispan.util.logging.Log
 
cacheIsStopping$str() - Method in class org.infinispan.util.logging.Log_$logger
 
cacheIsTerminated(String, String) - Method in class org.infinispan.util.logging.Log_$logger
 
cacheIsTerminated(String, String) - Method in interface org.infinispan.util.logging.Log
 
cacheIsTerminated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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
 
CacheJoinException - Exception in org.infinispan.topology
Thrown when a cache fails to join a cluster
CacheJoinException() - Constructor for exception org.infinispan.topology.CacheJoinException
 
CacheJoinException(String) - Constructor for exception org.infinispan.topology.CacheJoinException
 
CacheJoinException(String, Throwable) - Constructor for exception org.infinispan.topology.CacheJoinException
 
CacheJoinException(Throwable) - Constructor for exception org.infinispan.topology.CacheJoinException
 
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, CacheMode, float, PersistentUUID, Optional<Integer>) - Constructor for class org.infinispan.topology.CacheJoinInfo
 
CacheJoinInfo.Externalizer - Class in org.infinispan.topology
 
CacheLoader<K,​V> - Interface in org.infinispan.persistence.spi
Defines the logic for loading data from an external storage.
CacheLoaderInterceptor<K,​V> - Class in org.infinispan.interceptors.impl
 
CacheLoaderInterceptor() - Constructor for class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
cacheManager - Variable in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
 
cacheManager - Variable in class org.infinispan.xsite.BackupReceiverRepositoryImpl
 
CACHEMANAGER - org.infinispan.security.AuditContext
 
cacheManagerIsStopping() - Method in class org.infinispan.util.logging.Log_$logger
 
cacheManagerIsStopping() - Method in interface org.infinispan.util.logging.Log
 
cacheManagerIsStopping$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 - Variable in class org.infinispan.cache.impl.CacheImpl
 
cacheManagerNotifier - Variable in class org.infinispan.xsite.BackupReceiverRepositoryImpl
 
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
 
CacheManagerNotifierImpl.DefaultBuilder - Class in org.infinispan.notifications.cachemanagerlistener
 
cacheManagerStarted(GlobalComponentRegistry) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
Deprecated.
 
cacheManagerStarted(GlobalComponentRegistry) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
Deprecated.
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheManagerStopped(GlobalComponentRegistry) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
Deprecated.
 
cacheManagerStopped(GlobalComponentRegistry) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheManagerStopping(GlobalComponentRegistry) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
Deprecated.
 
cacheManagerStopping(GlobalComponentRegistry) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheMembersUpdated(Collection<Address>, int) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
cacheMembersUpdated(Collection<Address>, int) - Method in interface org.infinispan.util.logging.events.Messages
 
cacheMembersUpdated$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
CacheMgmtInterceptor - Class in org.infinispan.interceptors.impl
Captures cache management statistics
CacheMgmtInterceptor() - Constructor for class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
CacheMixedSiteStatus - Class in org.infinispan.xsite.status
A mixed SiteStatus.
CacheMixedSiteStatus(List<Address>, List<Address>) - Constructor for class org.infinispan.xsite.status.CacheMixedSiteStatus
 
cacheMode() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
Cache mode.
cacheMode() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
cacheMode(CacheMode) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
Cache mode.
CacheMode - Enum in org.infinispan.configuration.cache
Cache replication mode.
cacheModeString() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
 
cacheName - Variable in class org.infinispan.commands.remote.BaseRpcCommand
 
cacheName - Variable in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
cacheName - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
cacheName - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
cacheName - Variable in class org.infinispan.statetransfer.StateProviderImpl
 
cacheName - Variable in class org.infinispan.statetransfer.StateTransferManagerImpl
 
cacheName - Variable in class org.infinispan.transaction.xa.XaTransactionTable
 
cacheName - Variable in class org.infinispan.xsite.BaseBackupReceiver
 
CacheNotFoundResponse - Class in org.infinispan.remoting.responses
A response that signals the named cache is not running on the target node.
CacheNotFoundResponse.Externalizer - Class in org.infinispan.remoting.responses
 
cacheNotifier - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
cacheNotifier - Variable in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
cacheNotifier - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
CacheNotifier<K,​V> - Interface in org.infinispan.notifications.cachelistener
Public interface with all allowed notifications.
CacheNotifierImpl<K,​V> - Class in org.infinispan.notifications.cachelistener
Helper class that handles all notifications to registered listeners.
CacheNotifierImpl() - Constructor for class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
CacheNotifierImpl.BaseCacheEntryListenerInvocation<K,​V> - Class in org.infinispan.notifications.cachelistener
 
CacheNotifierImpl.CacheInvocationBuilder - Class in org.infinispan.notifications.cachelistener
 
CacheNotifierImpl.ClusteredListenerInvocation<K,​V> - Class in org.infinispan.notifications.cachelistener
This class is to be used with cluster listener invocations only when they have included current state.
CacheNotifierImpl.DelegatingCacheInvocationBuilder - Class in org.infinispan.notifications.cachelistener
 
cacheNotStarted() - Method in class org.infinispan.util.logging.Log_$logger
 
cacheNotStarted() - Method in interface org.infinispan.util.logging.Log
 
cacheNotStarted$str() - Method in class org.infinispan.util.logging.Log_$logger
 
CachePermission - Class in org.infinispan.security
CachePermission.
CachePermission(String) - Constructor for class org.infinispan.security.CachePermission
 
CachePermission(AuthorizationPermission) - Constructor for class org.infinispan.security.CachePermission
 
CachePermissionCollection - Class in org.infinispan.security
CachePermissionCollection.
CachePermissionCollection() - Constructor for class org.infinispan.security.CachePermissionCollection
 
CachePrincipalPair - Class in org.infinispan.security.impl
CachePrincipalPair.
cacheRebalancePhaseChange(CacheTopology.Phase, int) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
cacheRebalancePhaseChange(CacheTopology.Phase, int) - Method in interface org.infinispan.util.logging.events.Messages
 
cacheRebalancePhaseChange$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
cacheRebalanceStart(Collection<Address>, CacheTopology.Phase, int) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
cacheRebalanceStart(Collection<Address>, CacheTopology.Phase, int) - Method in interface org.infinispan.util.logging.events.Messages
 
cacheRebalanceStart$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
cacheRecoveredAfterMerge(String, CacheTopology, AvailabilityMode) - Method in class org.infinispan.util.logging.Log_$logger
 
cacheRecoveredAfterMerge(String, CacheTopology, AvailabilityMode) - Method in interface org.infinispan.util.logging.Log
 
cacheRecoveredAfterMerge(Collection<Address>, int) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
cacheRecoveredAfterMerge(Collection<Address>, int) - Method in interface org.infinispan.util.logging.events.Messages
 
cacheRecoveredAfterMerge$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
cacheRecoveredAfterMerge$str() - Method in class org.infinispan.util.logging.Log_$logger
 
cacheRef - Variable in class org.infinispan.expiration.impl.ClusterExpirationManager
 
CacheRoleImpl - Class in org.infinispan.security.impl
CacheRoleImpl.
CacheRoleImpl(String, Set<AuthorizationPermission>) - Constructor for class org.infinispan.security.impl.CacheRoleImpl
 
CacheRoleImpl(String, AuthorizationPermission...) - Constructor for class org.infinispan.security.impl.CacheRoleImpl
 
CacheRpcCommand - Interface in org.infinispan.commands.remote
The RpcManager only replicates commands wrapped in a CacheRpcCommand.
CacheRpcCommandExternalizer - Class in org.infinispan.marshall.exts
Externalizer in charge of marshalling cache specific commands.
CacheRpcCommandExternalizer(GlobalComponentRegistry, ReplicableCommandExternalizer) - Constructor for class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
 
Caches - Class in org.infinispan.cache.impl
Utility methods for dealing with caches.
CacheSet<E> - Interface in org.infinispan
A set that also must implement the various CacheCollection methods for streams.
CacheSetMapper<E,​R> - Class in org.infinispan.util
A CacheSet that allows for a different set to be mapped as a different instance wtih values replaced on request.
CacheSetMapper(CacheSet<E>, Function<? super E, ? extends R>) - Constructor for class org.infinispan.util.CacheSetMapper
 
cacheShutdown(String) - Method in interface org.infinispan.topology.LocalTopologyManager
Initiates a cluster-wide cache shutdown for the specified cache
cacheShutdown(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
cacheShutdown(String) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
CacheSiteStatusBuilder - Class in org.infinispan.xsite.status
A per-cache SiteStatus builder.
CacheSiteStatusBuilder() - Constructor for class org.infinispan.xsite.status.CacheSiteStatusBuilder
 
cacheStarted(ComponentRegistry, String) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
Deprecated.
 
cacheStarted(ComponentRegistry, String) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheStarted(Event) - Method in class org.infinispan.persistence.support.SingletonCacheWriter.SingletonStoreListener
Deprecated.
Cache started, check whether the cache is the coordinator and set the singleton store's active status.
CacheStarted - Annotation Type in org.infinispan.notifications.cachemanagerlistener.annotation
This annotation should be used on methods that need to be notified when a cache is started.
CacheStartedEvent - Interface in org.infinispan.notifications.cachemanagerlistener.event
This event is passed in to any method annotated with CacheStarted.
cacheStarting(ComponentRegistry, Configuration, String) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
Deprecated.
 
cacheStarting(ComponentRegistry, Configuration, String) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
CacheState - Class in org.infinispan.globalstate.impl
Cache State information stored in a cluster-wide cache
CacheState.Externalizer - Class in org.infinispan.globalstate.impl
 
CacheStatusResponse - Class in org.infinispan.topology
 
CacheStatusResponse(CacheJoinInfo, CacheTopology, CacheTopology, AvailabilityMode) - Constructor for class org.infinispan.topology.CacheStatusResponse
 
CacheStatusResponse.Externalizer - Class in org.infinispan.topology
 
cacheStopped(ComponentRegistry, String) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
Deprecated.
 
cacheStopped(ComponentRegistry, String) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheStopped(CacheStoppedEvent) - Method in class org.infinispan.xsite.BackupReceiverRepositoryImpl
 
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.
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
Deprecated.
 
cacheStopping(ComponentRegistry, String) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
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.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.
CacheStoreFactory - Interface in org.infinispan.persistence.factory
Creates Cache Store instances.
CacheStoreFactoryRegistry - Class in org.infinispan.persistence.factory
Registry for multiple CacheStoreFactory objects.
CacheStoreFactoryRegistry() - Constructor for class org.infinispan.persistence.factory.CacheStoreFactoryRegistry
 
CacheStoreFactoryRegistryFactory - Class in org.infinispan.factories
 
CacheStoreFactoryRegistryFactory() - Constructor for class org.infinispan.factories.CacheStoreFactoryRegistryFactory
 
cacheStream() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
cacheStream() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
cacheStream() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
cacheStream() - Method in class org.infinispan.stream.impl.tx.TxDistributedDoubleCacheStream
 
cacheStream() - Method in class org.infinispan.stream.impl.tx.TxDistributedIntCacheStream
 
cacheStream() - Method in class org.infinispan.stream.impl.tx.TxDistributedLongCacheStream
 
CacheStream<R> - Interface in org.infinispan
A Stream that has additional operations to monitor or control behavior when used from a Cache.
CacheSupport<K,​V> - Class in org.infinispan.cache.impl
 
CacheSupport() - Constructor for class org.infinispan.cache.impl.CacheSupport
 
CacheSupport(long, long) - Constructor for class org.infinispan.cache.impl.CacheSupport
 
cacheTopology - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
CacheTopology - Class in org.infinispan.topology
The status of a cache from a distribution/state transfer point of view.
CacheTopology(int, int, ConsistentHash, ConsistentHash, ConsistentHash, CacheTopology.Phase, List<Address>, List<PersistentUUID>) - Constructor for class org.infinispan.topology.CacheTopology
 
CacheTopology(int, int, ConsistentHash, ConsistentHash, CacheTopology.Phase, List<Address>, List<PersistentUUID>) - Constructor for class org.infinispan.topology.CacheTopology
 
CacheTopology.Externalizer - Class in org.infinispan.topology
 
CacheTopology.Phase - Enum in org.infinispan.topology
Phase of the rebalance process.
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, int, int, Throwable, int) - Constructor for class org.infinispan.topology.CacheTopologyControlCommand
 
CacheTopologyControlCommand(String, CacheTopologyControlCommand.Type, Address, AvailabilityMode, 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, CacheTopology, AvailabilityMode, 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.
CacheTransaction.TransactionCompletedListener - Interface in org.infinispan.transaction.xa
 
CacheUnreachableException - Exception in org.infinispan.remoting
Signals a backup site was unreachable.
CacheUnreachableException(String) - Constructor for exception org.infinispan.remoting.CacheUnreachableException
 
CacheUnreachableException(UnreachableException) - Constructor for exception org.infinispan.remoting.CacheUnreachableException
 
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.impl
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.impl.CacheWriterInterceptor
 
calculateAverageReadTime() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
calculateAverageReadTimeNanos() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
calculateAverageRemoveTime() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
calculateAverageRemoveTimeNanos() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
calculateAverageWriteTime() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
calculateAverageWriteTimeNanos() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
calculateConflictHash(ConsistentHash, Set<ConsistentHash>, List<Address>) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
 
calculateConflictHash(ConsistentHash, Set<ConsistentHash>, List<Address>) - Method in class org.infinispan.topology.ClusterCacheStatus
 
calculateDataMemoryUsed() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
calculateEvictions() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
calculateHitRatio() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
calculateHits() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
calculateMisses() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
calculateOffHeapUsed() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
calculateRank(ViewChangedEvent) - Method in class org.infinispan.container.versioning.NumericVersionGenerator.RankCalculator
 
calculateReadWriteRatio() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
calculateRemoveHits() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
calculateRemoveMisses() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
calculateRequiredMinimumNumberOfNodes(AdvancedCache<?, ?>) - Static method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
calculateSize(Object, Object) - Method in class org.infinispan.container.entries.PrimitiveEntrySizeCalculator
 
calculateSize(K, InternalCacheEntry<K, V>) - Method in class org.infinispan.container.entries.CacheEntrySizeCalculator
 
calculateSize(K, V) - Method in class org.infinispan.marshall.core.WrappedByteArraySizeCalculator
 
calculateSize(K, V, Metadata) - Method in class org.infinispan.container.entries.CacheEntrySizeCalculator
 
calculateSize(K, V, Metadata) - Method in interface org.infinispan.container.impl.KeyValueMetadataSizeCalculator
Method used to calculate how much memory in size the key, value and metadata use.
calculateSize(WrappedBytes, WrappedBytes, Metadata) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
Method used to calculate how much memory in size the key, value and metadata use.
calculateSize(WrappedBytes, WrappedBytes, Metadata) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
 
calculateStores() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
calculateTimeSinceStart() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
call() - Method in class org.infinispan.distexec.RunnableAdapter
 
call() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEventCallable
 
call() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerRemoveCallable
 
call() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerReplicateCallable
 
call() - Method in class org.infinispan.notifications.cachelistener.cluster.MultiClusterEventCallable
 
call() - Method in class org.infinispan.remoting.LocalInvocation
 
call() - Method in class org.infinispan.remoting.transport.AbstractRequest
 
callable(Callable<T>) - Method in interface org.infinispan.distexec.DistributedTaskBuilder
Provide relevant Callable for the DistributedTask
CallInterceptor - Class in org.infinispan.interceptors.impl
Always at the end of the chain, directly in front of the cache.
CallInterceptor() - Constructor for class org.infinispan.interceptors.impl.CallInterceptor
 
CALLTIME - org.infinispan.jmx.annotations.DataType
 
canAddOwners(List<Address>) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
canAddOwners(List<Address>) - Method in class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory.Builder
 
canApply(Set<Class<? extends Annotation>>, Class<? extends Annotation>) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
 
canBlock() - Method in class org.infinispan.commands.CreateCacheCommand
 
canBlock() - Method in class org.infinispan.commands.functional.AbstractWriteManyCommand
 
canBlock() - Method in class org.infinispan.commands.functional.ReadOnlyManyCommand
 
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.GetAllCommand
 
canBlock() - Method in class org.infinispan.commands.remote.BaseRpcCommand
 
canBlock() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
canBlock() - Method in class org.infinispan.commands.remote.GetKeysInGroupCommand
 
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
Deprecated.
 
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.triangle.BackupWriteCommand
 
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.BackupAckCommand
 
canBlock() - Method in class org.infinispan.commands.write.BackupMultiKeyAckCommand
 
canBlock() - Method in class org.infinispan.commands.write.ClearCommand
 
canBlock() - Method in class org.infinispan.commands.write.ExceptionAckCommand
 
canBlock() - Method in class org.infinispan.commands.write.InvalidateCommand
 
canBlock() - Method in class org.infinispan.commands.write.InvalidateVersionsCommand
 
canBlock() - Method in class org.infinispan.commands.write.PutMapCommand
 
canBlock() - Method in class org.infinispan.manager.impl.ReplicableCommandManagerFunction
 
canBlock() - Method in class org.infinispan.manager.impl.ReplicableCommandRunnable
 
canBlock() - Method in class org.infinispan.statetransfer.StateRequestCommand
 
canBlock() - Method in class org.infinispan.statetransfer.StateResponseCommand
 
canBlock() - Method in class org.infinispan.stream.impl.StreamIteratorCloseCommand
 
canBlock() - Method in class org.infinispan.stream.impl.StreamIteratorNextCommand
 
canBlock() - Method in class org.infinispan.stream.impl.StreamIteratorRequestCommand
 
canBlock() - Method in class org.infinispan.stream.impl.StreamRequestCommand
 
canBlock() - Method in class org.infinispan.stream.impl.StreamResponseCommand
 
canBlock() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
canBlock() - Method in class org.infinispan.topology.HeartBeatCommand
 
canBlock() - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
 
cancel() - Method in class org.infinispan.statetransfer.InboundTransferTask
Cancels all the segments and marks them as finished, sends a cancel command, then completes the task.
cancel() - Method in class org.infinispan.statetransfer.OutboundTransferTask
Cancel the whole task.
cancel(boolean) - Method in class org.infinispan.remoting.transport.AbstractRequest
 
cancel(Exception) - Method in class org.infinispan.remoting.transport.AbstractRequest
 
cancel(Exception) - Method in interface org.infinispan.remoting.transport.impl.Request
Complete the request with an exception and release its resources.
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(LockState) - Method in interface org.infinispan.util.concurrent.locks.ExtendedLockPromise
It cancels the LockPromise if possible.
CANCEL_CONSISTENCY_CHECK - org.infinispan.statetransfer.StateRequestCommand.Type
 
CANCEL_SEND - org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand.StateTransferControl
 
CANCEL_STATE_TRANSFER - org.infinispan.statetransfer.StateRequestCommand.Type
 
CancelCommand - Class in org.infinispan.commands
Command to cancel commands executing in remote VM
CancelCommand(ByteString) - Constructor for class org.infinispan.commands.CancelCommand
 
CancelCommand(ByteString, UUID) - Constructor for class org.infinispan.commands.CancelCommand
 
cancelConflictResolution() - Method in class org.infinispan.conflict.impl.DefaultConflictManager
 
cancelConflictResolution() - Method in interface org.infinispan.conflict.impl.InternalConflictManager
 
CANCELED - org.infinispan.remoting.inboundhandler.action.ActionStatus
The action is completed unsuccessfully.
CANCELED - org.infinispan.remoting.inboundhandler.action.BaseLockingAction.InternalState
 
CancellableCommand - Interface in org.infinispan.commands
CancellableCommand is a command whose execution in remote VM can be canceled (if needed)
cancellationService - Variable in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
CancellationService - Interface in org.infinispan.commands
CancellationService manages association of Thread executing CancellableCommand in a remote VM and if needed cancels command execution
CancellationServiceImpl - Class in org.infinispan.commands
CancellationServiceImpl is a default implementation of CancellationService
CancellationServiceImpl() - Constructor for class org.infinispan.commands.CancellationServiceImpl
 
cancelledConflictResolution(String, CacheTopology) - Method in class org.infinispan.util.logging.Log_$logger
 
cancelledConflictResolution(String, CacheTopology) - Method in interface org.infinispan.util.logging.Log
 
cancelledConflictResolution$str() - Method in class org.infinispan.util.logging.Log_$logger
 
cancelOutboundTransfer(Address, int, IntSet) - Method in interface org.infinispan.statetransfer.StateProvider
Cancel sending of cache entries that belong to the given set of segments.
cancelOutboundTransfer(Address, int, IntSet) - Method in class org.infinispan.statetransfer.StateProviderImpl
 
cancelPushState(String) - Method in class org.infinispan.xsite.GlobalXSiteAdminOperations
 
cancelPushState(String) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
It cancels a running state transfer.
cancelPushState(String) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
cancelPushState(String) - Method in class org.infinispan.xsite.XSiteAdminOperations
 
cancelQueuedTasks() - Method in class org.infinispan.executors.SemaphoreCompletionService
When stopping, cancel any queued tasks.
cancelReceive(String) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
Sets the cluster to normal state.
cancelReceive(String) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
cancelReceiveState(String) - Method in class org.infinispan.xsite.XSiteAdminOperations
 
cancelRequests() - Method in interface org.infinispan.conflict.impl.StateReceiver
Cancels all ongoing replica requests.
cancelRequests() - Method in class org.infinispan.conflict.impl.StateReceiverImpl
 
cancelSegments(IntSet) - Method in class org.infinispan.statetransfer.InboundTransferTask
Cancels a set of segments and marks them as finished.
cancelSegments(IntSet) - Method in class org.infinispan.statetransfer.OutboundTransferTask
Cancel some of the segments.
cancelStateTransfer(String) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateProvider
It cancels the state transfer for the remote site.
cancelStateTransfer(String) - Method in class org.infinispan.xsite.statetransfer.XSiteStateProviderImpl
 
cancelTransfers(IntSet) - Method in class org.infinispan.statetransfer.StateConsumerImpl
Cancel transfers for segments we no longer own.
cancelVersionRequests() - Method in class org.infinispan.conflict.impl.DefaultConflictManager
 
cancelVersionRequests() - Method in interface org.infinispan.conflict.impl.InternalConflictManager
 
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.impl.CacheLoaderInterceptor
 
canLoad(Object) - Method in class org.infinispan.interceptors.impl.ClusteredCacheLoaderInterceptor
 
CANNOT_ASSUME_DENOM_IS_POWER_OF_TWO - Static variable in class org.infinispan.io.ModularArithmetic
 
cannotConvertContent(Object, MediaType, MediaType) - Method in class org.infinispan.util.logging.Log_$logger
 
cannotConvertContent(Object, MediaType, MediaType) - Method in interface org.infinispan.util.logging.Log
 
cannotConvertContent$str() - Method in class org.infinispan.util.logging.Log_$logger
 
cannotFindTranscoder(MediaType, MediaType) - Method in class org.infinispan.util.logging.Log_$logger
 
cannotFindTranscoder(MediaType, MediaType) - Method in interface org.infinispan.util.logging.Log
 
cannotFindTranscoder$str() - Method in class org.infinispan.util.logging.Log_$logger
 
cannotRenamePersistentFile(String, File, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
cannotRenamePersistentFile(String, File, Throwable) - Method in interface org.infinispan.util.logging.Log
 
cannotRenamePersistentFile$str() - Method in class org.infinispan.util.logging.Log_$logger
 
cannotRespondToCommit(GlobalTransaction, String) - Method in class org.infinispan.util.logging.Log_$logger
 
cannotRespondToCommit(GlobalTransaction, String) - Method in interface org.infinispan.util.logging.Log
 
cannotRespondToCommit$str() - Method in class org.infinispan.util.logging.Log_$logger
 
cannotRespondToRollback(GlobalTransaction, String) - Method in class org.infinispan.util.logging.Log_$logger
 
cannotRespondToRollback(GlobalTransaction, String) - Method in interface org.infinispan.util.logging.Log
 
cannotRespondToRollback$str() - Method in class org.infinispan.util.logging.Log_$logger
 
cannotSelectRandomMembers(int, List<Address>) - Method in class org.infinispan.util.logging.Log_$logger
 
cannotSelectRandomMembers(int, List<Address>) - Method in interface org.infinispan.util.logging.Log
 
cannotSelectRandomMembers$str() - Method in class org.infinispan.util.logging.Log_$logger
 
canRead() - Method in class org.infinispan.io.GridFile
 
canRead(DataCommand) - Method in class org.infinispan.interceptors.impl.BiasedEntryWrappingInterceptor
 
canRead(DataCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
canReadKey(Object) - Method in class org.infinispan.interceptors.impl.BiasedEntryWrappingInterceptor
 
canReadKey(Object) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
canRollbackTransactionAfterOriginatorLeave(GlobalTransaction) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
canRollbackTransactionAfterOriginatorLeave(GlobalTransaction) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
It checks if the transaction can be aborted when the originator leaves the cluster.
canRollbackTransactionAfterOriginatorLeave(GlobalTransaction) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
canWrite() - Method in class org.infinispan.io.GridFile
 
capacity() - Method in interface org.infinispan.container.DataContainer
Returns the capacity of the underlying container.
capacity() - Method in class org.infinispan.container.impl.AbstractDelegatingDataContainer
 
capacity() - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
capacity() - Method in class org.infinispan.container.impl.DefaultDataContainer
 
capacity() - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
CAPACITY_FACTOR - org.infinispan.configuration.parsing.Attribute
 
CAPACITY_FACTOR - Static variable in class org.infinispan.configuration.cache.HashConfiguration
 
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.
capacityFactors - Variable in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
capacityFactors - Variable in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
cas(BaseLockingAction.InternalState, BaseLockingAction.InternalState) - Method in class org.infinispan.remoting.inboundhandler.action.BaseLockingAction
 
Casting - Class in org.infinispan.util
 
Casting() - Constructor for class org.infinispan.util.Casting
 
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.L1NonTxInterceptor
 
cdl - Variable in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
cdl - Variable in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
cf - Variable in class org.infinispan.expiration.impl.ClusterExpirationManager
 
cf - Variable in class org.infinispan.interceptors.impl.ClusteringInterceptor
 
ch - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
 
ch - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator
 
ch - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
 
CH_UPDATE - org.infinispan.topology.CacheTopologyControlCommand.Type
 
CHANGED - org.infinispan.container.entries.ReadCommittedEntry.Flags
 
channel - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
CHANNEL_LOOKUP - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
characteristics() - Method in class org.infinispan.stream.impl.spliterators.IteratorAsSpliterator
 
check(ActionState) - Method in interface org.infinispan.remoting.inboundhandler.action.Action
It checks this action.
check(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.BaseLockingAction
 
check(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.CheckTopologyAction
 
check(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.TriangleOrderAction
 
check(ActionState) - Method in class org.infinispan.remoting.inboundhandler.TrianglePerCacheInboundInvocationHandler
 
checkBulkRead() - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
checkBulkRead() - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
 
checkBulkRead() - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
checkCapacityFactors(List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHashFactory
 
checkCapacityFactors(List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory
 
checkClear() - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
checkClear() - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
 
checkClear() - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
checkExpiration(InternalCacheEntry<K, V>, long) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
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 this ExecutorService.
checkForReadyTasks() - Method in class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
 
checking(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.BaseLockingAction
 
checking(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.LockAction
 
checking(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.PendingTxAction
 
CHECKING - org.infinispan.remoting.inboundhandler.action.BaseLockingAction.InternalState
 
checkLockAndStore(Object, EntryVersion, Function<CompletableFuture<?>, CompletableFuture<?>>, Consumer<Object>) - Method in interface org.infinispan.persistence.manager.OrderedUpdatesManager
 
checkLockAndStore(Object, EntryVersion, Function<CompletableFuture<?>, CompletableFuture<?>>, Consumer<Object>) - Method in class org.infinispan.persistence.manager.OrderedUpdatesManagerImpl
 
checkParentDirs(String, boolean) - Method in class org.infinispan.io.GridFile
Checks whether the parent directories are present (and are directories).
checkPendingTransactionsForKey(TxInvocationContext<?>, Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultPendingLockManager
 
checkPendingTransactionsForKey(TxInvocationContext<?>, Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.NoOpPendingLockManager
 
checkPendingTransactionsForKey(TxInvocationContext<?>, Object, long, TimeUnit) - Method in interface org.infinispan.util.concurrent.locks.PendingLockManager
checkPendingTransactionsForKeys(TxInvocationContext<?>, Collection<Object>, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultPendingLockManager
 
checkPendingTransactionsForKeys(TxInvocationContext<?>, Collection<Object>, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.NoOpPendingLockManager
 
checkPendingTransactionsForKeys(TxInvocationContext<?>, Collection<Object>, long, TimeUnit) - Method in interface org.infinispan.util.concurrent.locks.PendingLockManager
checkPermission(Subject, AuthorizationPermission) - Method in interface org.infinispan.security.AuthorizationManager
Verifies that the Subject has the requested permission.
checkPermission(Subject, AuthorizationPermission) - Method in class org.infinispan.security.impl.AuthorizationManagerImpl
 
checkPermission(Subject, AuthorizationPermission, String) - Method in interface org.infinispan.security.AuthorizationManager
Verifies that the Subject has the requested permission and role.
checkPermission(Subject, AuthorizationPermission, String) - Method in class org.infinispan.security.impl.AuthorizationManagerImpl
 
checkPermission(AuthorizationConfiguration, Subject, AuthorizationPermission, String) - Method in class org.infinispan.security.impl.AuthorizationHelper
 
checkPermission(AuthorizationConfiguration, AuthorizationPermission) - Method in class org.infinispan.security.impl.AuthorizationHelper
 
checkPermission(AuthorizationPermission) - Method in interface org.infinispan.security.AuthorizationManager
Verifies that the Subject associated with the current AccessControlContext has the requested permission.
checkPermission(AuthorizationPermission) - Method in class org.infinispan.security.impl.AuthorizationHelper
 
checkPermission(AuthorizationPermission) - Method in class org.infinispan.security.impl.AuthorizationManagerImpl
 
checkPermission(AuthorizationPermission, String) - Method in interface org.infinispan.security.AuthorizationManager
Verifies that the Subject associated with the current AccessControlContext has the requested permission and role.
checkPermission(AuthorizationPermission, String) - Method in class org.infinispan.security.impl.AuthorizationHelper
 
checkPermission(AuthorizationPermission, String) - Method in class org.infinispan.security.impl.AuthorizationManagerImpl
 
checkPermission(CachePermission) - Static method in class org.infinispan.security.Security
 
checkRead(Object, long) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
checkRead(Object, long) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
 
checkRead(Object, long) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
checkResponse(Object, Address, boolean) - Method in class org.infinispan.remoting.transport.AbstractTransport
Deprecated.
 
checkSameHashAndSegments(AbstractConsistentHash) - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
checkStatisticsUsed() - Method in class org.infinispan.interceptors.impl.JmxStatsCommandInterceptor
 
CheckTopologyAction - Class in org.infinispan.remoting.inboundhandler.action
An Action implementation that checks if the command topology id is valid.
CheckTopologyAction(BasePerCacheInboundInvocationHandler) - Constructor for class org.infinispan.remoting.inboundhandler.action.CheckTopologyAction
 
checkTopologyId(TopologyAffectedCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
checkTopologyId(TopologyAffectedCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderDistributionInterceptor
 
checkTopologyId(TopologyAffectedCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedDistributionInterceptor
 
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.
checkTxCommandResponses(Map<Address, Response>, TransactionBoundaryCommand, TxInvocationContext<LocalTransaction>, Collection<Address>) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
checkWrite(Object) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
checkWrite(Object) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
 
checkWrite(Object) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
CHUNK_SIZE - org.infinispan.configuration.parsing.Attribute
 
CHUNK_SIZE - Static variable in class org.infinispan.configuration.cache.StateTransferConfiguration
 
CHUNK_SIZE - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
chunkCounter - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
chunkSize - Variable in class org.infinispan.statetransfer.StateProviderImpl
 
chunkSize() - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
The state will be transferred in batches of chunkSize cache entries.
chunkSize() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
chunkSize(int) - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
The state will be transferred in batches of chunkSize cache entries.
chunkSize(int) - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
If > 0, the state will be transferred in batches of chunkSize cache entries.
CLASS - org.infinispan.configuration.parsing.Attribute
 
CLASS_LOADER - Static variable in class org.infinispan.factories.KnownComponentNames
 
CLASS_RESOLVER - Static variable in class org.infinispan.configuration.global.SerializationConfiguration
 
classes() - Method in annotation type org.infinispan.factories.annotations.DefaultFactoryFor
Components that may be constructed by a factory annotated with this annotation.
classLoader - Variable in class org.infinispan.factories.GlobalComponentRegistry
 
classLoader - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
classLoader - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl.ListenerInvocationImpl
 
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
 
ClassLoaderAwareFilteringListenable<K,​V> - 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
classNotFound(String) - Method in class org.infinispan.util.logging.Log_$logger
 
classNotFound(String) - Method in interface org.infinispan.util.logging.Log
 
classNotFound$str() - Method in class org.infinispan.util.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 unmarshalling objects.
cleanup() - Static method in class org.infinispan.transaction.lookup.DummyTransactionManagerLookup
Deprecated.
 
cleanup() - Static method in class org.infinispan.transaction.lookup.EmbeddedTransactionManagerLookup
 
CLEANUP_TASK_FREQUENCY - Static variable in class org.infinispan.configuration.cache.L1Configuration
 
cleanupBackupLocks() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
cleanupBackupLocks() - Method in interface org.infinispan.transaction.xa.CacheTransaction
It cleans up the backup locks for this transaction.
cleanupLeaverTransactions(List<Address>) - Method in class org.infinispan.transaction.impl.TransactionTable
 
cleanupLeaverTransactions(List<Address>) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
First moves the prepared transactions originated on the leavers into the recovery cache and then cleans up the transactions that are not yet prepared.
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.atomic.impl.AtomicMapProxyImpl
 
clear() - Method in class org.infinispan.atomic.impl.FineGrainedAtomicMapProxyImpl
 
clear() - Method in interface org.infinispan.Cache
Removes all mappings from the cache.
clear() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
clear() - Method in class org.infinispan.cache.impl.CacheImpl
 
clear() - Method in class org.infinispan.cache.impl.DecoratedCache
 
clear() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
clear() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySetBase
 
clear() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.KeySet
 
clear() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.Values
 
clear() - Method in class org.infinispan.commands.read.AbstractCloseableIteratorCollection
 
clear() - Method in interface org.infinispan.container.DataContainer
Removes all entries in the container
clear() - Method in class org.infinispan.container.impl.AbstractDelegatingDataContainer
 
clear() - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
clear() - Method in class org.infinispan.container.impl.DefaultDataContainer
 
clear() - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
clear() - Method in class org.infinispan.container.impl.L1SegmentedDataContainer
 
clear() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
clear() - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
clear() - Method in class org.infinispan.persistence.async.AdvancedAsyncCacheWriter
 
clear() - Method in class org.infinispan.persistence.file.SingleFileStore
 
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
Deprecated.
 
clear() - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
clear() - Method in interface org.infinispan.scattered.BiasManager
The cache has been cleared and therefore all biases are forgotten.
clear() - Method in class org.infinispan.scattered.impl.BiasManagerImpl
 
clear() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
clear() - Method in class org.infinispan.util.CollectionMapper
 
clear() - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
 
clear() - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
Deprecated.
 
clear() - Method in class org.infinispan.util.WriteableCacheCollectionMapper
 
clear(IntSet) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
clear(IntSet) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
clear(IntSet) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
clear(IntSet) - Method in class org.infinispan.container.impl.DefaultDataContainer
 
clear(IntSet) - Method in interface org.infinispan.container.impl.InternalDataContainer
Removes entries from the container whose key maps to one of the provided segments
clear(IntSet) - Method in class org.infinispan.container.impl.InternalDataContainerAdapter
 
clear(IntSet) - Method in class org.infinispan.container.impl.L1SegmentedDataContainer
Removes all entries that map to the given segments
clear(IntSet) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
Removes all the data that maps to the given segments from the storage.
clear(IntSet) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
Clear - Class in org.infinispan.persistence.modifications
 
Clear() - Constructor for class org.infinispan.persistence.modifications.Clear
 
CLEAR - org.infinispan.persistence.modifications.Modification.Type
 
CLEAR_STATUS - org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand.StateTransferControl
 
clearAll() - Method in class org.infinispan.util.DependencyGraph
 
clearAllStores(Predicate<? super StoreConfiguration>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
Invokes AdvancedCacheWriter.clear() on all the stores that aloes it.
clearAllStores(Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
clearAllStores(Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
clearAsync() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
clearAsync() - Method in class org.infinispan.cache.impl.CacheImpl
 
clearAsync() - Method in class org.infinispan.cache.impl.DecoratedCache
 
clearAsync() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
clearAsync() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
ClearCacheEntry<K,​V> - Class in org.infinispan.container.entries
Used in ClearInvocationContext to process the ClearCommand.
clearClusterStatus() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
Clears the completed state transfer status in all the cluster.
clearClusterStatus() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
ClearCommand - Class in org.infinispan.commands.write
 
ClearCommand() - Constructor for class org.infinispan.commands.write.ClearCommand
 
ClearCommand(CacheNotifier<Object, Object>, DataContainer<?, ?>, long) - Constructor for class org.infinispan.commands.write.ClearCommand
 
clearDisallowedWhilePartitioned() - Method in class org.infinispan.util.logging.Log_$logger
 
clearDisallowedWhilePartitioned() - Method in interface org.infinispan.util.logging.Log
 
clearDisallowedWhilePartitioned$str() - Method in class org.infinispan.util.logging.Log_$logger
 
clearFactories() - Method in class org.infinispan.persistence.factory.CacheStoreFactoryRegistry
Removes all factories associated to this registry.
clearGroupers() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
Clear the groupers
clearInvalidations() - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
clearInvalidations() - Method in interface org.infinispan.scattered.ScatteredVersionManager
Forget all non-processed invalidations scheduled through ScatteredVersionManager.scheduleKeyInvalidation(Object, EntryVersion, boolean)
ClearInvocationContext - Class in org.infinispan.context.impl
Implementation of InvocationContext used by the ClearCommand.
ClearInvocationContext(Address) - Constructor for class org.infinispan.context.impl.ClearInvocationContext
 
clearLockedKeys() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
clearLockedKeys() - Method in class org.infinispan.context.impl.ClearInvocationContext
 
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
Deprecated.
 
clearLockedKeys() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
clearLockedKeys() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
clearLookedUpEntries() - Method in class org.infinispan.transaction.impl.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() - Method in class org.infinispan.cache.impl.CacheImpl
 
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
clearPushStateStatus() - Method in class org.infinispan.xsite.XSiteAdminOperations
 
clearRemoteLocksAcquired() - Method in class org.infinispan.transaction.impl.LocalTransaction
 
clearStatus() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
Clears the completed state transfer status.
clearStatus() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
clearStore() - Method in class org.infinispan.persistence.async.AdvancedAsyncCacheWriter
 
clearStore() - Method in class org.infinispan.persistence.async.AsyncCacheWriter
 
clearStores() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
Removes any configured stores from this builder.
clearThreadLocal() - Method in interface org.infinispan.context.InvocationContextContainer
Deprecated.
Remove the stored InvocationContext from the calling thread.
clearThreadLocal(InvocationContext) - Method in interface org.infinispan.context.InvocationContextContainer
Deprecated.
 
clone() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
clone() - Method in interface org.infinispan.container.entries.CacheEntry
 
clone() - Method in class org.infinispan.container.entries.ClearCacheEntry
 
clone() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
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 interface org.infinispan.container.entries.MVCCEntry
 
clone() - Method in class org.infinispan.container.entries.NullCacheEntry
 
clone() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
clone() - Method in class org.infinispan.container.entries.RepeatableReadEntry
 
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.container.entries.VersionedRepeatableReadEntry
 
clone() - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
clone() - Method in class org.infinispan.context.impl.ClearInvocationContext
 
clone() - Method in class org.infinispan.context.impl.ImmutableContext
 
clone() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
clone() - Method in interface org.infinispan.context.InvocationContext
Clones the invocation context.
clone() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
Deprecated.
 
clone() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
clone() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
clone() - Method in class org.infinispan.transaction.impl.RemoteTransaction
 
clone() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
clone(Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
close() - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
close() - Method in class org.infinispan.functional.impl.FunctionalMapImpl
 
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.manager.DefaultCacheManager
 
close() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
close() - Method in class org.infinispan.persistence.util.PersistenceManagerCloseableSupplier
Deprecated.
 
close() - Method in class org.infinispan.stream.impl.AbstractCacheStream
 
close() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
close() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
close() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
close() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
close() - Method in class org.infinispan.stream.impl.local.AbstractLocalCacheStream
 
close() - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
close() - Method in class org.infinispan.stream.impl.PriorityMergingProcessor
 
close() - Method in class org.infinispan.stream.impl.spliterators.IteratorAsSpliterator
 
close() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
close() - Method in class org.infinispan.util.CloseableSuppliedIterator
 
close() - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
close() - Method in interface org.infinispan.util.function.CloseableSupplier
 
close() - Method in class org.infinispan.util.LazyConcatIterator
 
close(InputStream) - Static method in class org.infinispan.util.stream.Streams
Attempt to close an InputStream.
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 OutputStream.
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 InputStream or OutputStream.
close(Object[]) - Static method in class org.infinispan.util.stream.Streams
Attempt to close an array of InputStreama and/or OutputStreams.
Closeables - Class in org.infinispan.util
This class is used solely for the purpose of converting classes only in core to corresponding closeable variants.
CloseableSuppliedIterator<E> - Class in org.infinispan.util
 
CloseableSuppliedIterator(CloseableSupplier<? extends E>) - Constructor for class org.infinispan.util.CloseableSuppliedIterator
 
CloseableSupplier<T> - Interface in org.infinispan.util.function
 
closeChannel - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
closeIterator(Address, Object) - Method in class org.infinispan.stream.impl.IteratorHandler
Invoked to have handler forget about given iterator they requested.
closeRunnable - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
CLUSTER - org.infinispan.configuration.parsing.Attribute
 
CLUSTER - org.infinispan.util.logging.events.EventLogCategory
 
CLUSTER - Static variable in class org.infinispan.util.logging.LogFactory
 
CLUSTER_LOADER - org.infinispan.configuration.parsing.Element
 
CLUSTER_NAME - Static variable in class org.infinispan.configuration.global.TransportConfiguration
 
CLUSTER_RECOVERY_ATTEMPTS - Static variable in class org.infinispan.topology.ClusterTopologyManagerImpl
 
CLUSTER_ROLE_MAPPER - org.infinispan.configuration.parsing.Element
 
CLUSTER_STORE - org.infinispan.configuration.parsing.Element
 
ClusterCacheNotifier<K,​V> - Interface in org.infinispan.notifications.cachelistener.cluster
This interface describes methods required for a cluster listener to be able to be bootstrapped and properly notified when a new event has been raised from the cluster.
ClusterCacheStats - Interface in org.infinispan.stats
Similar to Stats but cluster wide.
ClusterCacheStatsFactory - Class in org.infinispan.stats.impl
ClusterCacheStatsFactory is a default factory class for ClusterCacheStats.
ClusterCacheStatsFactory() - Constructor for class org.infinispan.stats.impl.ClusterCacheStatsFactory
 
ClusterCacheStatsImpl - Class in org.infinispan.stats.impl
 
ClusterCacheStatsImpl() - Constructor for class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
ClusterCacheStatus - Class in org.infinispan.topology
Keeps track of a cache's status: members, current/pending consistent hashes, and rebalance status
ClusterCacheStatus(EmbeddedCacheManager, String, AvailabilityStrategy, RebalanceType, ClusterTopologyManager, Transport, PersistentUUIDManager, EventLogManager, Optional<ScopedPersistentState>, boolean) - Constructor for class org.infinispan.topology.ClusterCacheStatus
 
clusterCommitType(FlagAffectedCommand, InvocationContext, int, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
ClusterContainerStats - Interface in org.infinispan.stats
Cluster wide container statistics
ClusterContainerStatsFactory - Class in org.infinispan.stats.impl
 
ClusterContainerStatsFactory() - Constructor for class org.infinispan.stats.impl.ClusterContainerStatsFactory
 
ClusterContainerStatsImpl - Class in org.infinispan.stats.impl
 
ClusterContainerStatsImpl() - Constructor for class org.infinispan.stats.impl.ClusterContainerStatsImpl
 
clustered - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
clustered - Variable in class org.infinispan.transaction.impl.TransactionTable
 
clustered() - Method in annotation type org.infinispan.notifications.Listener
Defines whether the annotated listener is clustered or not.
clustered(boolean) - Method in class org.infinispan.container.versioning.NumericVersionGenerator
 
ClusteredCacheBackupReceiver - Class in org.infinispan.xsite
BackupReceiver implementation for clustered caches.
ClusteredCacheBackupReceiver(Cache<Object, Object>) - Constructor for class org.infinispan.xsite.ClusteredCacheBackupReceiver
 
ClusteredCacheLoaderInterceptor - Class in org.infinispan.interceptors.impl
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.impl.ClusteredCacheLoaderInterceptor
 
clusteredDefault() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
Helper method that gets you a default constructed GlobalConfiguration, preconfigured to use the default clustering stack.
ClusteredGetAllCommand<K,​V> - Class in org.infinispan.commands.remote
Issues a remote getAll call.
ClusteredGetAllCommand(ByteString) - Constructor for class org.infinispan.commands.remote.ClusteredGetAllCommand
 
ClusteredGetAllCommand(ByteString, List<?>, long, GlobalTransaction) - Constructor for class org.infinispan.commands.remote.ClusteredGetAllCommand
 
ClusteredGetAllFuture(int) - Constructor for class org.infinispan.interceptors.impl.ClusteringInterceptor.ClusteredGetAllFuture
 
ClusteredGetCommand - Class in org.infinispan.commands.remote
Issues a remote get call.
ClusteredGetCommand(Object, ByteString, int, long) - Constructor for class org.infinispan.commands.remote.ClusteredGetCommand
 
ClusteredGetCommand(ByteString) - 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
 
ClusteredListenerInvocation(ListenerInvocation<Event<K, V>>, QueueingSegmentListener<K, V, CacheEntryEvent<K, V>>, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, ?>, Class<? extends Annotation>, boolean, UUID, boolean, Listener.Observation, Set<Class<? extends Annotation>>, DataConversion, DataConversion, boolean) - Constructor for class org.infinispan.notifications.cachelistener.CacheNotifierImpl.ClusteredListenerInvocation
 
clusteredTransactionalStoreMustBeShared(String) - Method in class org.infinispan.util.logging.Log_$logger
 
clusteredTransactionalStoreMustBeShared(String) - Method in interface org.infinispan.util.logging.Log
 
clusteredTransactionalStoreMustBeShared$str() - Method in class org.infinispan.util.logging.Log_$logger
 
ClusteredTransactionOriginatorChecker - Class in org.infinispan.transaction.impl
A TransactionOriginatorChecker implementation for clustered caches.
ClusteredTransactionOriginatorChecker() - Constructor for class org.infinispan.transaction.impl.ClusteredTransactionOriginatorChecker
 
ClusterEvent<K,​V> - Class in org.infinispan.notifications.cachelistener.cluster
This is an event designed for use with cluster listeners solely.
ClusterEvent.Externalizer - Class in org.infinispan.notifications.cachelistener.cluster
 
ClusterEventCallable<K,​V> - Class in org.infinispan.notifications.cachelistener.cluster
This DistributedCallable is used to invoke a raised notification on the cluster listener that registered to listen for this event.
ClusterEventCallable(UUID, Collection<? extends ClusterEvent<K, V>>) - Constructor for class org.infinispan.notifications.cachelistener.cluster.ClusterEventCallable
 
ClusterEventCallable(UUID, ClusterEvent<K, V>) - Constructor for class org.infinispan.notifications.cachelistener.cluster.ClusterEventCallable
 
ClusterEventCallable.Externalizer - Class in org.infinispan.notifications.cachelistener.cluster
 
ClusterEventManager<K,​V> - Interface in org.infinispan.notifications.cachelistener.cluster
 
ClusterEventManagerFactory - Class in org.infinispan.notifications.cachelistener.cluster
Constructs the data container
ClusterEventManagerFactory() - Constructor for class org.infinispan.notifications.cachelistener.cluster.ClusterEventManagerFactory
 
ClusterEventManagerStub<K,​V> - Class in org.infinispan.notifications.cachelistener.cluster.impl
 
ClusterEventManagerStub() - Constructor for class org.infinispan.notifications.cachelistener.cluster.impl.ClusterEventManagerStub
 
ClusterExecutionPolicy - Enum in org.infinispan.manager
ClusterExecutionPolicy controls how which nodes commands submitted via ClusterExecutor.
ClusterExecutor - Interface in org.infinispan.manager
A cluster executor that can be used to invoke a given command across the cluster.
ClusterExecutors - Class in org.infinispan.manager.impl
Static factory methods to construct a ClusterExecutor
ClusterExpirationManager<K,​V> - Class in org.infinispan.expiration.impl
Allows for cluster based expirations to occur.
ClusterExpirationManager() - Constructor for class org.infinispan.expiration.impl.ClusterExpirationManager
 
ClusterHealth - Interface in org.infinispan.health
Cluster health information.
ClusterHealthImpl - Class in org.infinispan.health.impl
 
ClusterHealthImpl(EmbeddedCacheManager) - Constructor for class org.infinispan.health.impl.ClusterHealthImpl
 
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
 
CLUSTERING - org.infinispan.configuration.parsing.Element
 
ClusteringConfiguration - Class in org.infinispan.configuration.cache
Defines clustered characteristics of the cache.
ClusteringConfigurationBuilder - Class in org.infinispan.configuration.cache
Defines clustered characteristics of the cache.
ClusteringConfigurationChildBuilder - Interface in org.infinispan.configuration.cache
 
ClusteringDependentLogic - Interface in org.infinispan.interceptors.locking
Abstractization for logic related to different clustering modes: replicated or distributed.
ClusteringDependentLogic.AbstractClusteringDependentLogic - Class in org.infinispan.interceptors.locking
 
ClusteringDependentLogic.Commit - Enum 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.
ClusteringDependentLogic.ScatteredLogic - Class in org.infinispan.interceptors.locking
 
ClusteringInterceptor - Class in org.infinispan.interceptors.impl
Base class for distribution interceptors.
ClusteringInterceptor() - Constructor for class org.infinispan.interceptors.impl.ClusteringInterceptor
 
ClusteringInterceptor.ClusteredGetAllFuture - Class in org.infinispan.interceptors.impl
ClusteringInterceptor.ClusteredGetAllFuture.completeExceptionally(Throwable) must be called from synchronized block since we must not complete the future (exceptionally) when we're accessing the context - if there was an exception and we would retry, the context could be accessed concurrently by dangling handlers and retry execution (that does not synchronize on the same future).
clusterListenerInstallationFailure(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
clusterListenerInstallationFailure(Throwable) - Method in interface org.infinispan.util.logging.Log
 
clusterListenerInstallationFailure$str() - Method in class org.infinispan.util.logging.Log_$logger
 
clusterListenerRegisteredWithOnlyPreEvents(Class<?>) - Method in class org.infinispan.util.logging.Log_$logger
 
clusterListenerRegisteredWithOnlyPreEvents(Class<?>) - Method in interface org.infinispan.util.logging.Log
 
clusterListenerRegisteredWithOnlyPreEvents$str() - Method in class org.infinispan.util.logging.Log_$logger
 
ClusterListenerRemoveCallable<K,​V> - Class in org.infinispan.notifications.cachelistener.cluster
This DistributedCallable is used to remove registered RemoteClusterListener on each of the various nodes when a cluster listener is unregistered from the cache.
ClusterListenerRemoveCallable(UUID) - Constructor for class org.infinispan.notifications.cachelistener.cluster.ClusterListenerRemoveCallable
 
ClusterListenerRemoveCallable.Externalizer - Class in org.infinispan.notifications.cachelistener.cluster
 
ClusterListenerReplicateCallable<K,​V> - Class in org.infinispan.notifications.cachelistener.cluster
This DistributedCallable is used to install a RemoteClusterListener on the resulting node.
ClusterListenerReplicateCallable(UUID, Address, CacheEventFilter<K, V>, CacheEventConverter<K, V, ?>, boolean, Set<Class<? extends Annotation>>, DataConversion, DataConversion, boolean) - Constructor for class org.infinispan.notifications.cachelistener.cluster.ClusterListenerReplicateCallable
 
ClusterListenerReplicateCallable.Externalizer - Class in org.infinispan.notifications.cachelistener.cluster
 
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(AttributeSet, AsyncStoreConfiguration, SingletonStoreConfiguration) - 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
 
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.
clusterRecoveryFailed(Collection<Address>) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
clusterRecoveryFailed(Collection<Address>) - Method in interface org.infinispan.util.logging.events.Messages
 
clusterRecoveryFailed$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
ClusterRoleMapper - Class in org.infinispan.security.impl
ClusterRoleMapper.
ClusterRoleMapper() - Constructor for class org.infinispan.security.impl.ClusterRoleMapper
 
clusterStatus() - Method in class org.infinispan.xsite.XSiteAdminOperations
 
ClusterStreamManager<Original,​K> - Interface in org.infinispan.stream.impl
Manages distribution of various stream operations that are sent to remote nodes.
ClusterStreamManager.RemoteIteratorPublisher<K> - Interface in org.infinispan.stream.impl
ClusterStreamManager.ResultsCallback<R> - Interface in org.infinispan.stream.impl
A callback that is used for result processing from the remote nodes.
ClusterStreamManagerImpl<Original,​K> - Class in org.infinispan.stream.impl
Cluster stream manager that sends all requests using the RpcManager to do the underlying communications.
ClusterStreamManagerImpl() - Constructor for class org.infinispan.stream.impl.ClusterStreamManagerImpl
 
ClusterTopologyManager - Interface in org.infinispan.topology
Maintains the topology for all the caches in the cluster.
ClusterTopologyManager.ClusterManagerStatus - Enum in org.infinispan.topology
 
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
 
clusterView - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
ClusterView - Class in org.infinispan.remoting.transport.jgroups
Information about the JGroups cluster.
ClusterViewListener() - Constructor for class org.infinispan.topology.ClusterTopologyManagerImpl.ClusterViewListener
 
cm - Variable in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
collect(Supplier<Collector<? super R, ?, R1>>) - Method in interface org.infinispan.CacheStream
Performs a mutable reduction operation on the elements of this stream using a Collector that is lazily created from the Supplier provided.
collect(Supplier<Collector<? super R, ?, R1>>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
collect(Supplier<Collector<? super R, ?, R1>>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
collect(Supplier<R>, BiConsumer<R, ? super T>, BiConsumer<R, R>) - Method in interface org.infinispan.functional.Traversable
A terminal operation that transforms the traversable into a result container, first constructed with the given supplier, and then accumulating elements over it with the given consumer.
collect(Supplier<R>, ObjDoubleConsumer<R>, BiConsumer<R, R>) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
collect(Supplier<R>, ObjDoubleConsumer<R>, BiConsumer<R, R>) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
collect(Supplier<R>, ObjDoubleConsumer<R>, BiConsumer<R, R>) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
collect(Supplier<R>, ObjIntConsumer<R>, BiConsumer<R, R>) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
collect(Supplier<R>, ObjIntConsumer<R>, BiConsumer<R, R>) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
collect(Supplier<R>, ObjIntConsumer<R>, BiConsumer<R, R>) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
collect(Supplier<R>, ObjLongConsumer<R>, BiConsumer<R, R>) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
collect(Supplier<R>, ObjLongConsumer<R>, BiConsumer<R, R>) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
collect(Supplier<R>, ObjLongConsumer<R>, BiConsumer<R, R>) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
collect(Supplier<R1>, BiConsumer<R1, ? super R>, BiConsumer<R1, R1>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
Note: this method doesn't pay attention to ordering constraints and any sorting performed on the stream will be ignored by this terminal operator.
collect(Supplier<R1>, BiConsumer<R1, ? super R>, BiConsumer<R1, R1>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
collect(Supplier<R1>, BiConsumer<R1, ? super R>, BiConsumer<R1, R1>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
collect(Supplier<R1>, BiConsumer<R1, ? super R>, BiConsumer<R1, R1>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
collect(Collector<? super R, A, R1>) - Method in interface org.infinispan.CacheStream
collect(Collector<? super R, A, R1>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
collect(Collector<? super R, A, R1>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
collect(Collector<? super R, A, R1>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
collect(Collector<? super R, A, R1>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
collect(Collector<? super T, A, R>) - Method in interface org.infinispan.functional.Traversable
A terminal operation that transforms the traversable into a result container using a Collector.
collect(SerializableSupplier<Collector<? super R, ?, R1>>) - Method in interface org.infinispan.CacheStream
Performs a mutable reduction operation on the elements of this stream using a Collector that is lazily created from the SerializableSupplier provided.
collect(SerializableSupplier<Collector<? super R, ?, R1>>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
collect(SerializableSupplier<Collector<? super R, ?, R1>>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
collect(SerializableSupplier<R>, SerializableObjDoubleConsumer<R>, SerializableBiConsumer<R, R>) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleStream.collect(Supplier, ObjDoubleConsumer, BiConsumer) except that the arguments must also implement Serializable
collect(SerializableSupplier<R>, SerializableObjDoubleConsumer<R>, SerializableBiConsumer<R, R>) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
collect(SerializableSupplier<R>, SerializableObjIntConsumer<R>, SerializableBiConsumer<R, R>) - Method in interface org.infinispan.IntCacheStream
Same as IntStream.collect(Supplier, ObjIntConsumer, BiConsumer) except that the arguments must also implement Serializable
collect(SerializableSupplier<R>, SerializableObjIntConsumer<R>, SerializableBiConsumer<R, R>) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
collect(SerializableSupplier<R>, SerializableObjLongConsumer<R>, SerializableBiConsumer<R, R>) - Method in interface org.infinispan.LongCacheStream
Same as LongStream.collect(Supplier, ObjLongConsumer, BiConsumer) except that the arguments must also implement Serializable.
collect(SerializableSupplier<R>, SerializableObjLongConsumer<R>, SerializableBiConsumer<R, R>) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
collect(SerializableSupplier<R1>, SerializableBiConsumer<R1, ? super R>, SerializableBiConsumer<R1, R1>) - Method in interface org.infinispan.CacheStream
Same as Stream.collect(Supplier, BiConsumer, BiConsumer) except that the various arguments must also implement Serializable
CollectionExternalizer - Class in org.infinispan.marshall.exts
 
CollectionExternalizer() - Constructor for class org.infinispan.marshall.exts.CollectionExternalizer
 
CollectionKeyFilter<K> - Class in org.infinispan.filter
Filter based on accepting/rejecting the keys that are present in a supplied collection.
CollectionKeyFilter(Collection<? extends K>) - Constructor for class org.infinispan.filter.CollectionKeyFilter
 
CollectionKeyFilter(Collection<? extends K>, boolean) - Constructor for class org.infinispan.filter.CollectionKeyFilter
 
CollectionKeyFilter.Externalizer - Class in org.infinispan.filter
 
CollectionMapper<E,​R> - Class in org.infinispan.util
A collection that maps another one to a new one of a possibly different type.
CollectionMapper(Collection<E>, Function<? super E, ? extends R>) - Constructor for class org.infinispan.util.CollectionMapper
 
collector(Supplier<Collector<T, ?, R>>) - Static method in class org.infinispan.stream.CacheCollectors
Similar to CacheCollectors.serializableCollector(SerializableSupplier) except that the supplier provided must be marshable through ISPN marshalling techniques.
Collector<T> - Interface in org.infinispan.interceptors.distribution
Represents the ack collector for a write operation in triangle algorithm.
collectorFor(Address) - Method in interface org.infinispan.util.concurrent.CommandAckCollector.MultiTargetCollector
 
combinePredicate(IntSet, KeyPartitioner, Predicate<? super K>) - Static method in class org.infinispan.persistence.internal.PersistenceUtil
 
command - Variable in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingEntrySet
 
command - Variable in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingKeySet
 
command - Variable in class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
 
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.functional.ReadOnlyKeyCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.functional.ReadOnlyManyCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.functional.ReadWriteKeyCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.functional.ReadWriteKeyValueCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.functional.ReadWriteManyCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.functional.TxReadOnlyKeyCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.functional.TxReadOnlyManyCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.functional.WriteOnlyKeyCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.functional.WriteOnlyKeyValueCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.functional.WriteOnlyManyCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.functional.WriteOnlyManyEntriesCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.read.DistributedExecuteCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.read.GetAllCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.read.GetCacheEntryCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.read.GetKeyValueCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.remote.ClusteredGetAllCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.remote.ClusteredGetCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.remote.expiration.RetrieveLastAccessCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.remote.expiration.UpdateLastAccessCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.remote.GetKeysInGroupCommand
 
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.RenewBiasCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.remote.RevokeBiasCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.remote.SingleRpcCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.RemoveCacheCommand
Deprecated.
 
COMMAND_ID - Static variable in class org.infinispan.commands.triangle.MultiEntriesFunctionalBackupWriteCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.triangle.MultiKeyFunctionalBackupWriteCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.triangle.PutMapBackupWriteCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.triangle.SingleKeyBackupWriteCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.triangle.SingleKeyFunctionalBackupWriteCommand
 
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
Deprecated.
 
COMMAND_ID - Static variable in class org.infinispan.commands.write.BackupAckCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.write.BackupMultiKeyAckCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.write.ClearCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.write.ComputeCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.write.ComputeIfAbsentCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.write.ExceptionAckCommand
 
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.InvalidateVersionsCommand
 
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.RemoveExpiredCommand
 
COMMAND_ID - Static variable in class org.infinispan.commands.write.ReplaceCommand
 
COMMAND_ID - Static variable in class org.infinispan.manager.impl.ReplicableCommandManagerFunction
 
COMMAND_ID - Static variable in class org.infinispan.manager.impl.ReplicableCommandRunnable
 
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.stream.impl.StreamIteratorCloseCommand
 
COMMAND_ID - Static variable in class org.infinispan.stream.impl.StreamIteratorNextCommand
 
COMMAND_ID - Static variable in class org.infinispan.stream.impl.StreamIteratorRequestCommand
 
COMMAND_ID - Static variable in class org.infinispan.stream.impl.StreamRequestCommand
 
COMMAND_ID - Static variable in class org.infinispan.stream.impl.StreamResponseCommand
 
COMMAND_ID - Static variable in class org.infinispan.topology.CacheTopologyControlCommand
 
COMMAND_ID - Static variable in class org.infinispan.topology.HeartBeatCommand
 
COMMAND_ID - Static variable in class org.infinispan.xsite.SingleXSiteRpcCommand
 
COMMAND_ID - Static variable in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
 
COMMAND_ID - Static variable in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
 
COMMAND_ID - Static variable in class org.infinispan.xsite.XSiteAdminCommand
 
COMMAND_RETRY - org.infinispan.context.Flag
If a write operation encounters a retry due to a topology change this flag should be used to tell the new owner that such a thing happened.
COMMAND_RETRY - Static variable in class org.infinispan.context.impl.FlagBitSets
 
commandAckCollector - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
CommandAckCollector - Class in org.infinispan.util.concurrent
An acknowledge collector for Triangle algorithm used in non-transactional caches for write operations.
CommandAckCollector() - Constructor for class org.infinispan.util.concurrent.CommandAckCollector
 
CommandAckCollector.MultiTargetCollector - Interface in org.infinispan.util.concurrent
 
CommandInterceptor - Class in org.infinispan.interceptors.base
Deprecated.
Since 9.0, please extend BaseAsyncInterceptor instead.
CommandInterceptor() - Constructor for class org.infinispan.interceptors.base.CommandInterceptor
Deprecated.
 
commandInvocationId - Variable in class org.infinispan.commands.write.AbstractDataWriteCommand
 
commandInvocationId - Variable in class org.infinispan.commands.write.InvalidateCommand
 
CommandInvocationId - Class in org.infinispan.commands
Represents an unique identified for non-transaction write commands.
commandsFactory - Variable in class org.infinispan.cache.impl.CacheImpl
 
commandsFactory - Variable in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
commandsFactory - Variable in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
commandsFactory - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
commandsFactory - Variable in class org.infinispan.statetransfer.StateProviderImpl
 
commandsFactory - Variable in class org.infinispan.transaction.impl.TransactionTable
 
CommandsFactory - Interface in org.infinispan.commands
A factory to build commands, initializing and injecting dependencies accordingly.
CommandsFactoryImpl - Class in org.infinispan.commands
 
CommandsFactoryImpl() - Constructor for class org.infinispan.commands.CommandsFactoryImpl
 
commandTopologyId - Variable in class org.infinispan.remoting.inboundhandler.DefaultTopologyRunnable
 
commit() - Method in interface org.infinispan.atomic.DeltaAware
Deprecated.
Indicate that all deltas collected to date has been extracted (via a call to DeltaAware.delta()) and can be discarded.
commit() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Deprecated.
Commit the transaction associated with the calling thread.
commit() - Method in class org.infinispan.transaction.tm.DummyTransaction
Deprecated.
Attempt to commit this transaction.
commit() - Method in class org.infinispan.transaction.tm.DummyUserTransaction
Deprecated.
Attempt to commit this transaction.
commit() - Method in class org.infinispan.transaction.tm.EmbeddedUserTransaction
 
commit(int, InternalDataContainer) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
commit(Transaction) - Method in interface org.infinispan.persistence.spi.TransactionalCacheWriter
Commit the provided transaction's changes to the underlying store.
commit(Xid, boolean) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
Same comment as for TransactionXaAdapter.prepare(javax.transaction.xa.Xid) applies for commit.
commit(Xid, boolean) - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
commit(DataContainer) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
commit(DataContainer) - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
commit(DataContainer) - Method in class org.infinispan.container.entries.NullCacheEntry
 
commit(DataContainer) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
commit(DataContainer<K, V>) - Method in interface org.infinispan.container.entries.CacheEntry
Commits changes
commit(DataContainer<K, V>) - Method in class org.infinispan.container.entries.ClearCacheEntry
 
commit(DataContainer<K, V>, Metadata) - Method in interface org.infinispan.container.entries.CacheEntry
Deprecated.
since 9.1
commit(CacheEntry, Flag, int, boolean, InvocationContext) - Method in class org.infinispan.statetransfer.CommitManager
It tries to commit the cache entry.
commit(LocalTransaction, boolean) - Method in class org.infinispan.transaction.impl.TransactionCoordinator
 
COMMIT_LOCAL - org.infinispan.interceptors.locking.ClusteringDependentLogic.Commit
Commit the entry, this is the owner.
COMMIT_NON_LOCAL - org.infinispan.interceptors.locking.ClusteringDependentLogic.Commit
Commit the entry but this node is not an owner, therefore, listeners should not be fired.
commitAllTxStores(Transaction, Predicate<? super StoreConfiguration>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
Perform the commit operation for the provided transaction on all Tx stores.
commitAllTxStores(Transaction, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
commitAllTxStores(Transaction, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
commitCommand(TxInvocationContext) - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
CommitCommand - Class in org.infinispan.commands.tx
Command corresponding to the 2nd phase of 2PC.
CommitCommand(ByteString) - Constructor for class org.infinispan.commands.tx.CommitCommand
 
CommitCommand(ByteString, GlobalTransaction) - Constructor for class org.infinispan.commands.tx.CommitCommand
 
commitContextEntries(InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
commitContextEntry(CacheEntry, InvocationContext, FlagAffectedCommand, Flag, boolean) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
commitContextEntry(CacheEntry, InvocationContext, FlagAffectedCommand, Flag, boolean) - Method in class org.infinispan.interceptors.impl.VersionedEntryWrappingInterceptor
 
commitContextEntry(CacheEntry, InvocationContext, FlagAffectedCommand, Flag, boolean) - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedEntryWrappingInterceptor
 
commitEntry(CacheEntry, FlagAffectedCommand, InvocationContext, Flag, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
commitEntry(CacheEntry, FlagAffectedCommand, InvocationContext, Flag, boolean) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
 
commitManager - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
commitManager - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
CommitManager - Class in org.infinispan.statetransfer
Keeps track of the keys updated by normal operation and state transfer.
CommitManager() - Constructor for class org.infinispan.statetransfer.CommitManager
 
commitSingleEntry(CacheEntry, FlagAffectedCommand, InvocationContext, Flag, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
commitSingleEntry(CacheEntry, FlagAffectedCommand, InvocationContext, Flag, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
 
commitSingleEntry(CacheEntry, FlagAffectedCommand, InvocationContext, Flag, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.InvalidationLogic
 
commitSingleEntry(CacheEntry, FlagAffectedCommand, InvocationContext, Flag, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
 
commitSingleEntry(CacheEntry, FlagAffectedCommand, InvocationContext, Flag, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.ReplicationLogic
 
commitSingleEntry(CacheEntry, FlagAffectedCommand, InvocationContext, Flag, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.ScatteredLogic
 
COMMITTED - org.infinispan.container.entries.ReadCommittedEntry.Flags
 
COMMITTED - org.infinispan.transaction.impl.TransactionTable.CompletedTransactionStatus
 
commitType(FlagAffectedCommand, InvocationContext, int, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
commitType(FlagAffectedCommand, InvocationContext, int, boolean) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
Determines what type of commit this is.
commitType(FlagAffectedCommand, InvocationContext, int, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.InvalidationLogic
 
commitType(FlagAffectedCommand, InvocationContext, int, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
 
commitType(FlagAffectedCommand, InvocationContext, int, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.ReplicationLogic
 
COMMON_NAME_ROLE_MAPPER - org.infinispan.configuration.parsing.Element
 
CommonNameRoleMapper - Class in org.infinispan.security.impl
CommonNameRoleMapper.
CommonNameRoleMapper() - Constructor for class org.infinispan.security.impl.CommonNameRoleMapper
 
compareTo(byte[]) - Static method in class org.infinispan.Version
 
compareTo(File) - Method in class org.infinispan.io.GridFile
 
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(Address) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
compareTo(Address) - Method in class org.infinispan.remoting.transport.LocalModeAddress
 
compareTo(Address) - Method in class org.infinispan.topology.PersistentUUID
 
compatibility() - Method in class org.infinispan.configuration.cache.Configuration
 
compatibility() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
Deprecated.
compatibility() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
Deprecated.
since 9.4, replace with ConfigurationBuilder.encoding() to specify the key and value's MediaType as "application/x-java-object", or preferably, avoid storing unmarshalled content when using the server and use the new endpoint interoperability mechanism
COMPATIBILITY - org.infinispan.configuration.parsing.Element
 
CompatibilityModeConfiguration - Class in org.infinispan.configuration.cache
Compatibility mode configuration
CompatibilityModeConfigurationBuilder - Class in org.infinispan.configuration.cache
Compatibility mode configuration builder
compatibilityModeOnlyCompatibleWithObjectStorage(StorageType) - Method in class org.infinispan.util.logging.Log_$logger
 
compatibilityModeOnlyCompatibleWithObjectStorage(StorageType) - Method in interface org.infinispan.util.logging.Log
 
compatibilityModeOnlyCompatibleWithObjectStorage$str() - Method in class org.infinispan.util.logging.Log_$logger
 
CompletableFutures - Class in org.infinispan.util.concurrent
Utility methods connecting CompletableFuture futures.
CompletableFutures() - Constructor for class org.infinispan.util.concurrent.CompletableFutures
 
complete - Variable in class org.infinispan.stream.impl.StreamResponseCommand
 
complete() - Method in interface org.infinispan.scattered.BiasManager.Revocation
 
complete() - Method in class org.infinispan.stream.impl.CompletionRehashPublisherDecorator
 
complete(T) - Method in class org.infinispan.remoting.transport.AbstractRequest
 
COMPLETE - org.infinispan.topology.RebalancingStatus
 
COMPLETED_TX_TIMEOUT - org.infinispan.configuration.parsing.Attribute
 
COMPLETED_TX_TIMEOUT - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
 
completedEmptyMap() - Static method in class org.infinispan.util.concurrent.CompletableFutures
 
completedExceptionFuture(Throwable) - Static method in class org.infinispan.util.concurrent.CompletableFutures
 
completedFalse() - Static method in class org.infinispan.util.concurrent.CompletableFutures
 
completedNull() - Static method in class org.infinispan.util.concurrent.CompletableFutures
 
completedTrue() - Static method in class org.infinispan.util.concurrent.CompletableFutures
 
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(long, Throwable, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
Acknowledges an exception during the operation execution.
completeExceptionally(Throwable) - Method in class org.infinispan.interceptors.impl.ClusteringInterceptor.ClusteredGetAllFuture
 
completeExceptionally(Throwable) - Method in class org.infinispan.remoting.transport.AbstractRequest
 
completeManyWriteOnPrimaryOriginator(WriteCommand, Address, CountDownCompletableFuture) - Method in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor
 
completeManyWriteOnPrimaryOriginator(WriteCommand, Address, CountDownCompletableFuture) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
This is a hook for bias-enabled mode where the primary performs additional RPCs but replication to another node.
completeSingleWriteOnPrimaryOriginator(DataWriteCommand, Address, CompletionStage<?>) - Method in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor
 
completeSingleWriteOnPrimaryOriginator(DataWriteCommand, Address, CompletionStage<?>) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
This is a hook for bias-enabled mode where the primary performs additional RPCs but replication to another node.
CompleteTransactionCommand - Class in org.infinispan.commands.remote.recovery
Command used by the recovery tooling for forcing transaction completion .
CompleteTransactionCommand(ByteString) - Constructor for class org.infinispan.commands.remote.recovery.CompleteTransactionCommand
 
CompleteTransactionCommand(ByteString, Xid, boolean) - Constructor for class org.infinispan.commands.remote.recovery.CompleteTransactionCommand
 
completionQueue - Variable in class org.infinispan.distexec.DistributedExecutionCompletionService
 
CompletionRehashPublisherDecorator<S> - Class in org.infinispan.stream.impl
PublisherDecorator that only notifies a user listener of segment completion after the last entry for a given segment has been retrieved from iteration.
COMPONENT_KEY - Static variable in class org.infinispan.jmx.ComponentsJmxRegistration
 
ComponentAlias - Class in org.infinispan.factories.impl
 
ComponentFactory - Interface in org.infinispan.factories
Factory for Infinispan components.
componentFailedToStop(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
componentFailedToStop(Throwable) - Method in interface org.infinispan.util.logging.Log
 
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<Field>, List<Method>, List<Method>, List<Method>, List<Method>, boolean, boolean) - Constructor for class org.infinispan.factories.components.ComponentMetadata
 
ComponentMetadata(Class<?>, List<Field>, List<Method>, List<Method>, List<Method>, List<Method>, Scopes, boolean) - Constructor for class org.infinispan.factories.components.ComponentMetadata
 
ComponentMetadata.InjectFieldMetadata - Class in org.infinispan.factories.components
 
ComponentMetadata.InjectMethodMetadata - 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 {@link @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
ComponentRef<T> - Interface in org.infinispan.factories.impl
Reference to a component.
componentRegistry - Variable in class org.infinispan.cache.impl.CacheImpl
 
componentRegistry - Variable in class org.infinispan.factories.AbstractNamedCacheComponentFactory
Deprecated.
componentRegistry - Variable in class org.infinispan.interceptors.impl.BaseRpcInterceptor
 
ComponentRegistry - Class in org.infinispan.factories
Named cache specific components
ComponentRegistry(String, Configuration, AdvancedCache<?, ?>, GlobalComponentRegistry, ClassLoader) - Constructor for class org.infinispan.factories.ComponentRegistry
Creates an instance of the component registry.
ComponentsJmxRegistration - Class in org.infinispan.jmx
Registers a set of components on an MBean server.
ComponentsJmxRegistration(MBeanServer, String) - Constructor for class org.infinispan.jmx.ComponentsJmxRegistration
C-tor.
ComponentStatus - Enum in org.infinispan.lifecycle
Different states a component may be in.
ComposedSegmentedLoadWriteStore<K,​V,​T extends AbstractSegmentedStoreConfiguration> - Class in org.infinispan.persistence.support
Segmented store that creates multiple inner stores for each segment.
ComposedSegmentedLoadWriteStore(AbstractSegmentedStoreConfiguration<T>) - Constructor for class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
composeFalse() - Static method in class org.infinispan.util.concurrent.CompletableFutures
 
composeTrue() - Static method in class org.infinispan.util.concurrent.CompletableFutures
 
composeWithExceptions(Consumer<Supplier<PrimitiveIterator.OfInt>>, Consumer<Supplier<PrimitiveIterator.OfInt>>) - Static method in class org.infinispan.stream.impl.AbstractCacheStream
Given two SegmentCompletionListener, return a SegmentCompletionListener that executes both in sequence, even if the first throws an exception, and if both throw exceptions, add any exceptions thrown by the second as suppressed exceptions of the first.
CompositeAction - Class in org.infinispan.remoting.inboundhandler.action
A ReadyAction implementation that delegates it logic to a collection of other ReadyAction.
CompositeAction(Collection<ReadyAction>) - Constructor for class org.infinispan.remoting.inboundhandler.action.CompositeAction
 
CompositeCacheEventFilter<K,​V> - Class in org.infinispan.notifications.cachelistener.filter
Allows AND-composing several cache event filters.
CompositeCacheEventFilter(CacheEventFilter<? super K, ? super V>...) - Constructor for class org.infinispan.notifications.cachelistener.filter.CompositeCacheEventFilter
 
CompositeKeyFilter<K> - Class in org.infinispan.filter
Allows AND-composing several filters.
CompositeKeyFilter(KeyFilter<? super K>...) - Constructor for class org.infinispan.filter.CompositeKeyFilter
 
CompositeKeyFilter.Externalizer - Class in org.infinispan.filter
 
CompositeKeyValueFilter<K,​V> - Class in org.infinispan.filter
Allows AND-composing several key/value filters.
CompositeKeyValueFilter(KeyValueFilter<? super K, ? super V>...) - Constructor for class org.infinispan.filter.CompositeKeyValueFilter
 
CompositeKeyValueFilter.Externalizer - Class in org.infinispan.filter
 
compute(int, K, DataContainer.ComputeAction<K, V>) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
compute(int, K, DataContainer.ComputeAction<K, V>) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
compute(int, K, DataContainer.ComputeAction<K, V>) - Method in interface org.infinispan.container.impl.InternalDataContainer
Same as DataContainer.compute(Object, ComputeAction) except that the segment of the key can provided to update entries without calculating the segment for the given key.
compute(int, K, DataContainer.ComputeAction<K, V>) - Method in class org.infinispan.container.impl.InternalDataContainerAdapter
 
compute(int, WrappedBytes, DataContainer.ComputeAction<WrappedBytes, WrappedBytes>) - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in interface org.infinispan.Cache
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.CacheImpl
 
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.EncoderCache
 
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
An overloaded form of #compute(K, BiFunction), 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.
compute(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
compute(K, DataContainer.ComputeAction<K, V>) - Method in interface org.infinispan.container.DataContainer
Computes the new value for the key.
compute(K, DataContainer.ComputeAction<K, V>) - Method in class org.infinispan.container.impl.AbstractDelegatingDataContainer
 
compute(K, DataContainer.ComputeAction<K, V>) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
compute(K, InternalCacheEntry<K, V>, InternalEntryFactory) - Method in interface org.infinispan.container.DataContainer.ComputeAction
Computes the new value for the key.
compute(K, SerializableBiFunction<? super K, ? super V, ? extends V>) - Method in interface org.infinispan.Cache
compute(K, SerializableBiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
compute(WrappedBytes, BiFunction<? super WrappedBytes, ? super InternalCacheEntry<WrappedBytes, WrappedBytes>, ? extends InternalCacheEntry<WrappedBytes, WrappedBytes>>) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
compute(WrappedBytes, DataContainer.ComputeAction<WrappedBytes, WrappedBytes>) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
compute(WrappedBytes, DataContainer.ComputeAction<WrappedBytes, WrappedBytes>) - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
computeActualNumOwners(int, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
Overloaded #computeAsync(K, BiFunction), which stores metadata alongside the value.
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeAsync(K, SerializableBiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
ComputeCommand - Class in org.infinispan.commands.write
 
ComputeCommand() - Constructor for class org.infinispan.commands.write.ComputeCommand
 
ComputeCommand(Object, BiFunction, boolean, int, long, CommandInvocationId, Metadata, CacheNotifier, ComponentRegistry) - Constructor for class org.infinispan.commands.write.ComputeCommand
 
computeEntryRemoved(K, InternalCacheEntry<K, V>) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
This method is invoked every time an entry is removed inside a compute block
computeEntryRemoved(K, InternalCacheEntry<K, V>) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
computeEntryWritten(K, InternalCacheEntry<K, V>) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
This method is invoked every time an entry is written inside a compute block
computeEntryWritten(K, InternalCacheEntry<K, V>) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
computeExpectedSegments(int, int, Address) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
computeExpectedSegmentsForNode(Address, int) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
computeExpectedSegmentsForNode(Address, int) - Method in class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory.Builder
 
computeGroup(T, Object) - Method in interface org.infinispan.distribution.group.Grouper
Compute the group for a given key
computeGroup(T, String) - Method in interface org.infinispan.distribution.group.Grouper
Deprecated.
Since 9.1
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in interface org.infinispan.Cache
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfAbsent(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfAbsent(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfAbsent(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfAbsent(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfAbsent(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfAbsent(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfAbsent(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfAbsent(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfAbsent(K, Function<? super K, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
An overloaded form of #computeIfAbsent(K, Function), 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.
computeIfAbsent(K, Function<? super K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeIfAbsent(K, Function<? super K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfAbsent(K, Function<? super K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
 
computeIfAbsent(K, Function<? super K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfAbsent(K, Function<? super K, ? extends V>, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfAbsent(K, SerializableFunction<? super K, ? extends V>) - Method in interface org.infinispan.Cache
computeIfAbsent(K, SerializableFunction<? super K, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
computeIfAbsentAsync(K, Function<? super K, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
Overloaded #computeIfAbsentAsync(K, Function), 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.
computeIfAbsentAsync(K, Function<? super K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfAbsentAsync(K, SerializableFunction<? super K, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
ComputeIfAbsentCommand - Class in org.infinispan.commands.write
 
ComputeIfAbsentCommand() - Constructor for class org.infinispan.commands.write.ComputeIfAbsentCommand
 
ComputeIfAbsentCommand(Object, Function, int, long, CommandInvocationId, Metadata, CacheNotifier, ComponentRegistry) - Constructor for class org.infinispan.commands.write.ComputeIfAbsentCommand
 
computeIfAbsentInternal(K, Function<? super K, ? extends V>, ByRef<V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfAbsentInternal(K, Function<? super K, ? extends V>, ByRef<V>) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in interface org.infinispan.Cache
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
An overloaded form of #computeIfPresent(K, BiFunction), 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.
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfPresent(K, SerializableBiFunction<? super K, ? super V, ? extends V>) - Method in interface org.infinispan.Cache
Overloaded Cache.computeIfPresent(Object, BiFunction) with Infinispan SerializableBiFunction The compiler will pick this overload for lambda parameters, making them Serializable
computeIfPresent(K, SerializableBiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
Overloaded #computeIfPresentAsync(K, BiFunction), 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.
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfPresentAsync(K, SerializableBiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
computeIfPresentInternal(K, BiFunction<? super K, ? super V, ? extends V>, SimpleCacheImpl.CacheEntryChange<K, V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfPresentInternal(K, BiFunction<? super K, ? super V, ? extends V>, SimpleCacheImpl.CacheEntryChange<K, V>) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
computeInternal(K, BiFunction<? super K, ? super V, ? extends V>, SimpleCacheImpl.CacheEntryChange<K, V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeInternal(K, BiFunction<? super K, ? super V, ? extends V>, SimpleCacheImpl.CacheEntryChange<K, V>) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
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().
computePreferredTopology(Map<Address, CacheStatusResponse>) - Method in class org.infinispan.partitionhandling.impl.PreferAvailabilityStrategy
Ignore the AvailabilityStrategyContext and only compute the preferred topology for testing.
computeTotalCapacity() - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
computeTotalCapacity(Collection<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
CONCURRENCY_LEVEL - org.infinispan.configuration.parsing.Attribute
 
CONCURRENCY_LEVEL - Static variable in class org.infinispan.configuration.cache.LockingConfiguration
 
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.
ConcurrentChangeException - Exception in org.infinispan.interceptors.distribution
Thrown when the version of entry has changed between loading the entry to the context and committing new value.
ConcurrentChangeException() - Constructor for exception org.infinispan.interceptors.distribution.ConcurrentChangeException
Throwing this exception is cheaper because it does not fill in the stack trace.
config - Variable in class org.infinispan.cache.impl.CacheImpl
 
config - Variable in class org.infinispan.context.AbstractInvocationContextFactory
Deprecated.
 
CONFIG_STATE_CACHE_NAME - Static variable in interface org.infinispan.globalstate.GlobalConfigurationManager
 
configAlreadyDefined(String) - Method in class org.infinispan.util.logging.Log_$logger
 
configAlreadyDefined(String) - Method in interface org.infinispan.util.logging.Log
 
configAlreadyDefined$str() - Method in class org.infinispan.util.logging.Log_$logger
 
configuration - Variable in class org.infinispan.container.impl.AbstractInternalDataContainer
 
configuration - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
configuration - Variable in class org.infinispan.factories.AbstractNamedCacheComponentFactory
 
configuration - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
configuration - Variable in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
 
configuration - Variable in class org.infinispan.remoting.transport.AbstractTransport
Deprecated.
 
configuration - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
configuration - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
configuration - Variable in class org.infinispan.stream.impl.PartitionAwareClusterStreamManager
 
configuration - Variable in class org.infinispan.transaction.impl.TransactionTable
 
Configuration - Class in org.infinispan.configuration.cache
 
CONFIGURATION - org.infinispan.configuration.parsing.Attribute
 
CONFIGURATION_FILE - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
CONFIGURATION_STORAGE - Static variable in class org.infinispan.configuration.global.GlobalStateConfiguration
 
CONFIGURATION_STORAGE_SUPPLIER - Static variable in class org.infinispan.configuration.global.GlobalStateConfiguration
 
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.configuration.cache
 
ConfigurationBuilder() - Constructor for class org.infinispan.configuration.cache.ConfigurationBuilder
 
ConfigurationBuilderHolder - Class in org.infinispan.configuration.parsing
 
ConfigurationBuilderHolder() - Constructor for class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
ConfigurationBuilderHolder(ClassLoader) - Constructor for class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
ConfigurationChildBuilder - Interface in org.infinispan.configuration.cache
 
ConfigurationForClassExtractor - Class in org.infinispan.persistence.factory
 
ConfigurationForClassExtractor() - Constructor for class org.infinispan.persistence.factory.ConfigurationForClassExtractor
 
ConfigurationHolder - Class in org.infinispan.configuration.serializing
ConfigurationHolder.
ConfigurationHolder(GlobalConfiguration, Map<String, Configuration>) - Constructor for class org.infinispan.configuration.serializing.ConfigurationHolder
 
configurationInUse(String) - Method in class org.infinispan.util.logging.Log_$logger
 
configurationInUse(String) - Method in interface org.infinispan.util.logging.Log
 
configurationInUse$str() - Method in class org.infinispan.util.logging.Log_$logger
 
ConfigurationManager - Class in org.infinispan.configuration
It manages all the configuration for a specific container.
ConfigurationManager(GlobalConfiguration) - Constructor for class org.infinispan.configuration.ConfigurationManager
 
ConfigurationManager(ConfigurationBuilderHolder) - Constructor for class org.infinispan.configuration.ConfigurationManager
 
configurationNameMatchesMultipleWildcards(String) - Method in class org.infinispan.util.logging.Log_$logger
 
configurationNameMatchesMultipleWildcards(String) - Method in interface org.infinispan.util.logging.Log
 
configurationNameMatchesMultipleWildcards$str() - Method in class org.infinispan.util.logging.Log_$logger
 
ConfigurationParser - Interface in org.infinispan.configuration.parsing
ConfigurationParser.
Configurations - Class in org.infinispan.configuration.cache
Helper configuration methods.
configurationSerializationFailed(String, Configuration, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
configurationSerializationFailed(String, Configuration, Exception) - Method in interface org.infinispan.util.logging.Log
 
configurationSerializationFailed$str() - Method in class org.infinispan.util.logging.Log_$logger
 
ConfigurationSerializer<T> - Interface in org.infinispan.configuration.serializing
 
configurationStorage() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
 
configurationStorage(ConfigurationStorage) - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
Defines the ConfigurationStorage strategy to use.
ConfigurationStorage - Enum in org.infinispan.globalstate
Configuration storage
configurationStorageClass() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
configurationStorageSupplier(Supplier<? extends LocalConfigurationStorage>) - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
configuratorError(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
configuratorError(Exception) - Method in interface org.infinispan.util.logging.Log
 
configuratorError$str() - Method in class org.infinispan.util.logging.Log_$logger
 
configuratorSAXError(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
configuratorSAXError(Exception) - Method in interface org.infinispan.util.logging.Log
 
configuratorSAXError$str() - Method in class org.infinispan.util.logging.Log_$logger
 
configuratorSAXParseError(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
configuratorSAXParseError(Exception) - Method in interface org.infinispan.util.logging.Log
 
configuratorSAXParseError$str() - Method in class org.infinispan.util.logging.Log_$logger
 
configure() - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
configure() - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
CONFIRM_REVOKED_SEGMENTS - org.infinispan.statetransfer.StateRequestCommand.Type
 
confirmRebalancePhase(String, int, int, Throwable) - Method in interface org.infinispan.topology.LocalTopologyManager
Confirm that the local cache cacheName has finished receiving the new data for topology topologyId.
confirmRebalancePhase(String, int, int, Throwable) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
confirmRebalancePhase(String, int, int, Throwable) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
confirmRebalancePhase(Address, int) - Method in class org.infinispan.topology.ClusterCacheStatus
 
confirmRevokedSegments(int) - Method in class org.infinispan.scattered.impl.ScatteredStateProviderImpl
 
confirmRevokedSegments(int) - Method in interface org.infinispan.scattered.ScatteredStateProvider
Confirm that this node has received cache topology with given topologyId and that it has moved all the segments it does not own according to consistent hash to the ScatteredVersionManager.SegmentState.NOT_OWNED state.
confirmStateTransfer(Address, boolean) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferCollector
 
CONFLICT_RESOLUTION - org.infinispan.topology.CacheTopology.Phase
Interim state between NO_REBALANCE -> READ_OLD_WRITE_ALL readCh is set locally using previous Topology (of said node) readCH, whilst writeCH contains all members after merge
CONFLICTING - org.infinispan.container.versioning.InequalVersionComparisonResult
Denotes a version that was created at the same time as another version, but is not equal.
ConflictManager<K,​V> - Interface in org.infinispan.conflict
 
ConflictManagerFactory - Class in org.infinispan.conflict
A ConflictManager factory for cache instances.
ConflictManagerFactory() - Constructor for class org.infinispan.conflict.ConflictManagerFactory
 
conflictResolutionCancelled(Collection<Address>, int) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
conflictResolutionCancelled(Collection<Address>, int) - Method in interface org.infinispan.util.logging.events.Messages
 
conflictResolutionCancelled$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
conflictResolutionFailed(Collection<Address>, int, String) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
conflictResolutionFailed(Collection<Address>, int, String) - Method in interface org.infinispan.util.logging.events.Messages
 
conflictResolutionFailed$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
conflictResolutionFinished(Collection<Address>, int) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
conflictResolutionFinished(Collection<Address>, int) - Method in interface org.infinispan.util.logging.events.Messages
 
conflictResolutionFinished$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
conflictResolutionStarting(Collection<Address>, int) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
conflictResolutionStarting(Collection<Address>, int) - Method in interface org.infinispan.util.logging.events.Messages
 
conflictResolutionStarting$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
connectChannel - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
CONNECTION_ATTEMPTS - org.infinispan.configuration.parsing.Attribute
 
CONNECTION_ATTEMPTS - Static variable in class org.infinispan.configuration.cache.PersistenceConfiguration
 
CONNECTION_INTERVAL - org.infinispan.configuration.parsing.Attribute
 
CONNECTION_INTERVAL - Static variable in class org.infinispan.configuration.cache.PersistenceConfiguration
 
connectionAttempts() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
 
connectionAttempts(int) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
connectionInterval() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
 
connectionInterval(int) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
CONSISTENT_HASH_FACTORY - org.infinispan.configuration.parsing.Attribute
 
CONSISTENT_HASH_FACTORY - Static variable in class org.infinispan.configuration.cache.HashConfiguration
 
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.util.logging.Log_$logger
 
consistentHashDeprecated() - Method in interface org.infinispan.util.logging.Log
 
consistentHashDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
consistentHashFactory() - Method in class org.infinispan.configuration.cache.HashConfiguration
The consistent hash factory in use.
consistentHashFactory(ConsistentHashFactory<? extends ConsistentHash>) - 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.
ConsistentHashPersistenceConstants - Class in org.infinispan.distribution.ch.impl
Constants used as keys within a persisted consistent hash
ConsistentHashPersistenceConstants() - Constructor for class org.infinispan.distribution.ch.impl.ConsistentHashPersistenceConstants
 
ConstantLambdaExternalizer() - Constructor for class org.infinispan.marshall.core.MarshallableFunctionExternalizers.ConstantLambdaExternalizer
 
construct(Class<RecoveryManager>) - Method in class org.infinispan.factories.RecoveryManagerFactory
 
construct(Class<T>) - Method in class org.infinispan.factories.AbstractComponentFactory
Deprecated.
Since 9.4, please override ComponentFactory.construct(String) instead.
construct(Class<T>, String) - Method in class org.infinispan.factories.NamedComponentFactory
Deprecated.
Constructs a component.
construct(String) - Method in class org.infinispan.distribution.ch.impl.KeyPartitionerFactory
 
construct(String) - Method in class org.infinispan.distribution.group.impl.GroupManagerFactory
 
construct(String) - Method in class org.infinispan.factories.AbstractComponentFactory
 
construct(String) - Method in class org.infinispan.factories.AuthorizationManagerFactory
 
construct(String) - Method in class org.infinispan.factories.CacheStoreFactoryRegistryFactory
 
construct(String) - Method in interface org.infinispan.factories.ComponentFactory
 
construct(String) - Method in class org.infinispan.factories.DataContainerFactory
 
construct(String) - Method in class org.infinispan.factories.DistributionManagerFactory
 
construct(String) - Method in class org.infinispan.factories.EmptyConstructorFactory
 
construct(String) - Method in class org.infinispan.factories.EmptyConstructorNamedCacheFactory
 
construct(String) - Method in class org.infinispan.factories.EncoderRegistryFactory
 
construct(String) - Method in class org.infinispan.factories.EntryMetaFactory
 
construct(String) - Method in class org.infinispan.factories.ExpirationManagerFactory
 
construct(String) - Method in class org.infinispan.factories.InboundInvocationHandlerFactory
 
construct(String) - Method in class org.infinispan.factories.InterceptorChainFactory
 
construct(String) - Method in class org.infinispan.factories.InternalCacheFactory
 
construct(String) - Method in class org.infinispan.factories.LockContainerFactory
 
construct(String) - Method in class org.infinispan.factories.LockManagerFactory
 
construct(String) - Method in class org.infinispan.factories.MarshallerFactory
 
construct(String) - Method in class org.infinispan.factories.NamedComponentFactory
Deprecated.
 
construct(String) - Method in class org.infinispan.factories.NamedExecutorsFactory
 
construct(String) - Method in class org.infinispan.factories.PartitionHandlingManagerFactory
 
construct(String) - Method in class org.infinispan.factories.ResponseGeneratorFactory
 
construct(String) - Method in class org.infinispan.factories.RpcManagerFactory
 
construct(String) - Method in class org.infinispan.factories.SizeCalculatorFactory
 
construct(String) - Method in class org.infinispan.factories.StateTransferComponentFactory
 
construct(String) - Method in class org.infinispan.factories.StreamManagerFactory
 
construct(String) - Method in class org.infinispan.factories.TransactionManagerFactory
 
construct(String) - Method in class org.infinispan.factories.TransactionSynchronizationRegistryFactory
 
construct(String) - Method in class org.infinispan.factories.TransactionTableFactory
 
construct(String) - Method in class org.infinispan.factories.TransportFactory
 
construct(String) - Method in class org.infinispan.factories.VersionGeneratorFactory
 
construct(String) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEventManagerFactory
 
construct(String) - Method in class org.infinispan.security.impl.GlobalSecurityManagerFactory
 
construct(String) - Method in class org.infinispan.stats.impl.ClusterCacheStatsFactory
 
construct(String) - Method in class org.infinispan.stats.impl.ClusterContainerStatsFactory
 
construct(String) - Method in class org.infinispan.stats.impl.StatsCollector.Factory
 
construct(String) - Method in class org.infinispan.topology.ClusterTopologyManagerFactory
 
construct(String) - Method in class org.infinispan.topology.LocalTopologyManagerFactory
 
containerFull(long) - Method in class org.infinispan.util.logging.Log_$logger
 
containerFull(long) - Method in interface org.infinispan.util.logging.Log
 
containerFull$str() - Method in class org.infinispan.util.logging.Log_$logger
 
ContainerFullException - Exception in org.infinispan.interceptors.impl
Exception that is thrown when exception based eviction is enabled and the cache is full
ContainerFullException(String) - Constructor for exception org.infinispan.interceptors.impl.ContainerFullException
 
ContainerMixedSiteStatus - Class in org.infinispan.xsite.status
A mixed SiteStatus.
ContainerMixedSiteStatus(Collection<String>, Collection<String>, Collection<String>) - Constructor for class org.infinispan.xsite.status.ContainerMixedSiteStatus
 
ContainerSiteStatusBuilder - Class in org.infinispan.xsite.status
A per-container SiteStatus builder.
ContainerSiteStatusBuilder() - Constructor for class org.infinispan.xsite.status.ContainerSiteStatusBuilder
 
containRemoteTx(GlobalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
 
contains(int, Object) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
Returns true if the storage contains an entry associated with the given key in the given segment
contains(int, Object) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
contains(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySetBase
 
contains(Object) - Method in class org.infinispan.commands.read.AbstractCloseableIteratorCollection
 
contains(Object) - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
 
contains(Object) - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingEntrySet
 
contains(Object) - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingKeySet
 
contains(Object) - Method in class org.infinispan.persistence.async.AsyncCacheLoader
 
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 interface org.infinispan.persistence.spi.CacheLoader
Returns true if the storage contains an entry associated with the given key.
contains(Object) - Method in class org.infinispan.persistence.support.AbstractSegmentedAdvancedLoadWriteStore
 
contains(Object) - Method in class org.infinispan.persistence.support.DelegatingCacheLoader
 
contains(Object) - Method in class org.infinispan.stream.impl.local.ValueCacheCollection
 
contains(Object) - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
 
contains(Object) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
Deprecated.
 
contains(Object) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
 
containsAll(Collection<?>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySetBase
 
containsAll(Collection<?>) - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
 
containsAll(Collection<?>) - Method in class org.infinispan.stream.impl.local.ValueCacheCollection
 
containsAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
 
containsAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
Deprecated.
 
containsAll(Collection<?>) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
 
containsAll(Param<?>...) - Method in class org.infinispan.functional.impl.Params
Checks whether all the parameters passed in are already present in the current parameters.
containsInstance(AsyncInterceptor) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Checks whether the chain contains the supplied interceptor instance.
containsInstance(AsyncInterceptor) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
containsInstance(AsyncInterceptor) - Method in class org.infinispan.interceptors.impl.AsyncInterceptorChainImpl
 
containsInstance(CommandInterceptor) - Method in class org.infinispan.interceptors.InterceptorChain
Deprecated.
Checks whether the chain contains the supplied interceptor instance.
containsInterceptorType(Class<? extends AsyncInterceptor>) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Checks whether the chain contains an interceptor with the given class.
containsInterceptorType(Class<? extends AsyncInterceptor>) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
containsInterceptorType(Class<? extends AsyncInterceptor>) - Method in class org.infinispan.interceptors.impl.AsyncInterceptorChainImpl
 
containsInterceptorType(Class<? extends AsyncInterceptor>, boolean) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Checks whether the chain contains an interceptor with the given class, or a subclass.
containsInterceptorType(Class<? extends AsyncInterceptor>, boolean) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
containsInterceptorType(Class<? extends AsyncInterceptor>, boolean) - Method in class org.infinispan.interceptors.impl.AsyncInterceptorChainImpl
 
containsInterceptorType(Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
Deprecated.
 
containsInterceptorType(Class<? extends CommandInterceptor>, boolean) - Method in class org.infinispan.interceptors.InterceptorChain
Deprecated.
 
containsKey(int, Object) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
containsKey(int, Object) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
containsKey(int, Object) - Method in interface org.infinispan.container.impl.InternalDataContainer
Same as DataContainer.containsKey(Object) except that the segment of the key can provided to lookup if the entry exists without calculating the segment for the given key.
containsKey(int, Object) - Method in class org.infinispan.container.impl.InternalDataContainerAdapter
 
containsKey(Object) - Method in class org.infinispan.atomic.impl.AtomicMapProxyImpl
 
containsKey(Object) - Method in class org.infinispan.atomic.impl.FineGrainedAtomicMapProxyImpl
 
containsKey(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
containsKey(Object) - Method in class org.infinispan.cache.impl.CacheImpl
 
containsKey(Object) - Method in class org.infinispan.cache.impl.DecoratedCache
 
containsKey(Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
containsKey(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
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.impl.AbstractDelegatingDataContainer
 
containsKey(Object) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
containsKey(Object) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
containsKey(Object) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
containsKey(Object) - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
 
containsKey(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
containsLocalTx(GlobalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
 
containsLockOrBackupLock(Object) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
containsLockOrBackupLock(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
Deprecated.
containsLockOwner(Object) - Method in class org.infinispan.util.concurrent.locks.impl.InfinispanLock
It tests if the lock has the lock owner.
containsProperty(String) - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
 
containsProperty(String) - Method in interface org.infinispan.globalstate.ScopedPersistentState
Returns whether the state contains a property
containsRole(String) - Method in class org.infinispan.security.impl.SubjectACL
 
containsValue(Object) - Method in class org.infinispan.atomic.impl.AtomicMapProxyImpl
 
containsValue(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
containsValue(Object) - Method in class org.infinispan.cache.impl.CacheImpl
 
containsValue(Object) - Method in class org.infinispan.cache.impl.DecoratedCache
 
containsValue(Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
containsValue(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
containsValue(Object) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
containsValue(Object) - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
 
containsValue(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
contentType - Variable in class org.infinispan.remoting.MIMECacheEntry
The MIME Content type value, for example application/octet-stream.
ContentTypeConfiguration - Class in org.infinispan.configuration.cache
 
ContentTypeConfigurationBuilder - Class in org.infinispan.configuration.cache
 
ContentTypeConfigurationBuilder(EncodingConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
 
context - Variable in class org.infinispan.util.logging.events.impl.DecoratedEventLogger
 
context(String) - Method in interface org.infinispan.util.logging.events.EventLogger
Sets a context of this event log.
context(String) - Method in class org.infinispan.util.logging.events.impl.BasicEventLogger
 
context(String) - Method in class org.infinispan.util.logging.events.impl.DecoratedEventLogger
 
context(Cache<?, ?>) - Method in interface org.infinispan.util.logging.events.EventLogger
Sets a cache as context of this event log.
continueIterator(Object, long) - Method in interface org.infinispan.stream.impl.LocalStreamManager
Continues an existing iterator by retrieving the next batchSize of elements
continueIterator(Object, long) - Method in class org.infinispan.stream.impl.LocalStreamManagerImpl
 
continueTaskInBackground() - Method in class org.infinispan.executors.SemaphoreCompletionService
Called from a task to remove the permit that would otherwise be freed when the task finishes running When the asynchronous part of the task finishes, it must call SemaphoreCompletionService.backgroundTaskFinished(Callable) to make the permit available again.
convert(Object, MediaType, MediaType) - Method in class org.infinispan.encoding.DataConversion
 
convert(K, V, Metadata) - Method in class org.infinispan.filter.AbstractKeyValueFilterConverter
 
convert(K, V, Metadata) - Method in interface org.infinispan.filter.Converter
 
convert(K, V, Metadata) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventConverterAsConverter
 
convert(K, V, Metadata, V, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.AbstractCacheEventFilterConverter
 
convert(K, V, Metadata, V, Metadata, EventType) - Method in interface org.infinispan.notifications.cachelistener.filter.CacheEventConverter
Converts the given newValue into something different possibly.
convert(K, V, Metadata, V, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter
 
convert(MarshalledEntry<K, V>, InternalEntryFactory) - Static method in class org.infinispan.persistence.internal.PersistenceUtil
 
convert(MarshalledEntry<K, V>, InternalEntryFactory) - Static method in class org.infinispan.persistence.PersistenceUtil
 
converter - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
Converter<K,​V,​C> - Interface in org.infinispan.filter
Converter that can be used to transform a given entry to a different value.
convertToRequestFormat(Object, MediaType) - Method in class org.infinispan.encoding.DataConversion
 
convertValue(CacheEventConverter<? super K, ? super V, ?>, CacheEntryEvent<K, V>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
COORDINATOR - org.infinispan.topology.ClusterTopologyManager.ClusterManagerStatus
 
coordinatorTimeoutWaitingForView(int, int, Object) - Method in class org.infinispan.util.logging.Log_$logger
 
coordinatorTimeoutWaitingForView(int, int, Object) - Method in interface org.infinispan.util.logging.Log
 
coordinatorTimeoutWaitingForView$str() - Method in class org.infinispan.util.logging.Log_$logger
 
copy() - Method in interface org.infinispan.atomic.CopyableDeltaAware
Deprecated.
 
copy() - Method in class org.infinispan.commands.tx.PrepareCommand
 
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.
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(ReadWriteManyCommand<K, V, R>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
copy(ReadWriteManyEntriesCommand<K, V, T, R>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
copy(WriteOnlyManyCommand<K, V>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
copy(WriteOnlyManyEntriesCommand<K, V, T>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
copy(PutMapCommand, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
copy(CacheEntry) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
 
copy(CacheEntry<K, V>) - Method in interface org.infinispan.container.impl.InternalEntryFactory
Creates a copy of this cache entry and synchronizes serializes the copy process with the InternalEntryFactory.update(org.infinispan.container.entries.InternalCacheEntry, org.infinispan.metadata.Metadata).
CopyableDeltaAware - Interface in org.infinispan.atomic
Deprecated.
since 9.1
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.
copyForCache(ByteString) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
 
copyForLocal(C, List<Object>) - Method in interface org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadManyCommandHelper
 
copyForLocal(ReadOnlyManyCommand, List<Object>) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadOnlyManyHelper
 
copyForRemote(C, List<Object>, InvocationContext) - Method in interface org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadManyCommandHelper
 
copyForRemote(ReadOnlyManyCommand, List<Object>, InvocationContext) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadOnlyManyHelper
 
copyForUpdate() - Method in interface org.infinispan.container.entries.MVCCEntry
Deprecated.
since 9.0 noop
copyForUpdate(DataContainer<? super K, ? super V>) - Method in interface org.infinispan.container.entries.MVCCEntry
Deprecated.
Since 8.0, use MVCCEntry.copyForUpdate() instead.
copyOwners() - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
copyOwners() - Method in class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory.Builder
 
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 interface org.infinispan.container.entries.StateChangingEntry
Deprecated.
copyWithoutRemotableFlags(long) - Static method in enum org.infinispan.context.Flag
Deprecated.
Since 9.0
copyWithoutRemotableFlags(long) - Static method in class org.infinispan.context.impl.FlagBitSets
Creates a copy of a Flag BitSet removing instances of FAIL_SILENTLY.
copyWithoutRemotableFlags(Set<Flag>) - Static method in enum org.infinispan.context.Flag
Deprecated.
Since 9.0
CORE_THREADS - org.infinispan.configuration.parsing.Attribute
 
CoreImmutables - Class in org.infinispan.util
Factory for generating immutable type wrappers for core types.
CoreImmutables() - Constructor for class org.infinispan.util.CoreImmutables
 
couldNotCompleteInjectedTransaction(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotCompleteInjectedTransaction(Throwable) - Method in interface org.infinispan.util.logging.Log
 
couldNotCompleteInjectedTransaction$str() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotExecuteCancellationLocally(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotExecuteCancellationLocally(Throwable) - Method in interface org.infinispan.util.logging.Log
 
couldNotExecuteCancellationLocally$str() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotFindAttribute(String) - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotFindAttribute(String) - Method in interface org.infinispan.util.logging.Log
 
couldNotFindAttribute$str() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotInstantiateTransactionManager(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotInstantiateTransactionManager(Exception) - Method in interface org.infinispan.util.logging.Log
 
couldNotInstantiateTransactionManager$str() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotInterruptThread(UUID) - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotInterruptThread(UUID) - Method in interface org.infinispan.util.logging.Log
 
couldNotInterruptThread$str() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotInvokeSetOnAttribute(String, Object) - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotInvokeSetOnAttribute(String, Object) - Method in interface org.infinispan.util.logging.Log
 
couldNotInvokeSetOnAttribute$str() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotRegisterObjectName(ObjectName, InstanceAlreadyExistsException) - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotRegisterObjectName(ObjectName, InstanceAlreadyExistsException) - Method in interface org.infinispan.util.logging.Log
 
couldNotRegisterObjectName$str() - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotRollbackPrepared1PcTransaction(LocalTransaction, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
couldNotRollbackPrepared1PcTransaction(LocalTransaction, Throwable) - Method in interface org.infinispan.util.logging.Log
 
couldNotRollbackPrepared1PcTransaction$str() - Method in class org.infinispan.util.logging.Log_$logger
 
count() - Method in interface org.infinispan.functional.Traversable
A terminal operation that returns the number of elements in the traversable.
count() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
count() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
count() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
count() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
count() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
count() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
count() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
count() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
count() - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
count() - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
count() - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
count() - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
count() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
count(AdvancedCacheLoader<K, V>, Predicate<? super K>) - Static method in class org.infinispan.persistence.PersistenceUtil
 
count(AdvancedCacheLoader<K, V>, KeyFilter<? super K>) - Static method in class org.infinispan.persistence.PersistenceUtil
count(SegmentedAdvancedLoadWriteStore<?, ?>, IntSet) - Static method in class org.infinispan.persistence.PersistenceUtil
Counts how many entries are present in the segmented store.
COUNT - org.infinispan.eviction.EvictionType
 
counter - Variable in class org.infinispan.interceptors.impl.ClusteringInterceptor.ClusteredGetAllFuture
 
create() - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
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.ContentTypeConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.CustomStoreConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
Deprecated.
 
create() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
Deprecated.
 
create() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
Deprecated.
 
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.MemoryConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
 
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.SecurityConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
Deprecated.
 
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
Deprecated.
 
create() - Method in class org.infinispan.configuration.cache.SyncConfigurationBuilder
Deprecated.
 
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
Deprecated.
 
create() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.internal.PrivateGlobalConfigurationBuilder
 
create() - Static method in class org.infinispan.functional.impl.Params
 
create(boolean, boolean) - Static method in enum org.infinispan.remoting.inboundhandler.TopologyMode
 
create(long, Collection<Address>, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
Creates a collector for a single key write operation.
create(Object) - Static method in class org.infinispan.remoting.responses.SuccessfulResponse
 
create(Object) - Static method in class org.infinispan.remoting.responses.UnsuccessfulResponse
 
create(Object, Object, InternalCacheEntry) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
 
create(Object, Object, EntryVersion, long, long, long, long) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
 
create(Object, Object, Metadata) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
 
create(Object, Object, Metadata, long, long) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
 
create(Object, Object, Metadata, long, long, long, long) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
 
create(K, V, InternalCacheEntry<?, ?>) - Method in interface org.infinispan.container.impl.InternalEntryFactory
Creates a new InternalCacheEntry instance based on the version and timestamp/lifespan information reflected in the CacheEntry instance passed in.
create(K, V, EntryVersion, long, long, long, long) - Method in interface org.infinispan.container.impl.InternalEntryFactory
Creates a new InternalCacheEntry instance
create(K, V, Metadata) - Method in interface org.infinispan.container.impl.InternalEntryFactory
Creates a new InternalCacheEntry instance
create(K, V, Metadata, long, long) - Method in interface org.infinispan.container.impl.InternalEntryFactory
Creates a new InternalCacheEntry instance
create(K, V, Metadata, long, long, long, long) - Method in interface org.infinispan.container.impl.InternalEntryFactory
Creates a new InternalCacheEntry instance
create(AdvancedCache<K, V>) - Static method in class org.infinispan.functional.impl.FunctionalMapImpl
 
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.impl.DefaultConsistentHashFactory
 
create(Hash, int, int, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory
 
create(Hash, int, int, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory
 
create(Hash, int, int, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory
 
create(Hash, int, int, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory
 
create(WrappedBytes, WrappedBytes, Metadata) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
Creates an off heap entry using the provided key value and metadata
create(WrappedBytes, WrappedBytes, Metadata) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
Create an entry off-heap.
create(CacheEntry) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
 
create(CacheEntry<K, V>) - Method in interface org.infinispan.container.impl.InternalEntryFactory
Creates a new InternalCacheEntry instance based on the key, value, version and timestamp/lifespan information reflected in the CacheEntry instance passed in.
create(FunctionalMapImpl<K, V>) - Static method in class org.infinispan.functional.impl.ReadOnlyMapImpl
 
create(FunctionalMapImpl<K, V>) - Static method in class org.infinispan.functional.impl.ReadWriteMapImpl
 
create(FunctionalMapImpl<K, V>) - Static method in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
create(Params, AdvancedCache<K, V>) - Static method in class org.infinispan.functional.impl.FunctionalMapImpl
 
create(R, boolean) - Static method in class org.infinispan.functional.impl.StatsEnvelope
 
create(T, CacheEntry<?, ?>, boolean, boolean) - Static method in class org.infinispan.functional.impl.StatsEnvelope
 
CREATE - Static variable in class org.infinispan.functional.impl.StatsEnvelope
 
createAsyncWriter(CacheWriter) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
createBiased(long, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
 
createBuilder(Hash, int, int, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory
 
createBuilder(Hash, int, int, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory
 
createCache(String, String) - Method in class org.infinispan.manager.DefaultCacheManagerAdmin
 
createCache(String, String) - Method in interface org.infinispan.manager.EmbeddedCacheManagerAdmin
Creates a cache on the container using the specified template.
createCache(String, String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.GlobalConfigurationManager
Defines a cluster-wide cache configuration using the supplied template
createCache(String, String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.GlobalConfigurationManagerImpl
 
createCache(String, String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.ImmutableLocalConfigurationStorage
 
createCache(String, String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.OverlayLocalConfigurationStorage
 
createCache(String, String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
 
createCache(String, String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.LocalConfigurationStorage
Creates the cache using the supplied template, configuration and flags.
createCache(String, Configuration) - Method in class org.infinispan.manager.DefaultCacheManager
 
createCache(String, Configuration) - Method in class org.infinispan.manager.DefaultCacheManagerAdmin
 
createCache(String, Configuration) - Method in interface org.infinispan.manager.EmbeddedCacheManager
Creates a cache on the local node using the supplied configuration.
createCache(String, Configuration) - Method in interface org.infinispan.manager.EmbeddedCacheManagerAdmin
Creates a cache across the cluster.
createCache(String, Configuration) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
createCache(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.GlobalConfigurationManager
Defines a cluster-wide cache configuration
createCache(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.GlobalConfigurationManagerImpl
 
createCache(Configuration, GlobalComponentRegistry, String) - Method in class org.infinispan.factories.InternalCacheFactory
This implementation clones the configuration passed in before using it.
createCache(CacheEntryCreatedEvent<ScopedState, CacheState>) - Method in class org.infinispan.globalstate.impl.GlobalConfigurationStateListener
 
CreateCacheCommand - Class in org.infinispan.commands
Command to create/start a cache on a subset of Infinispan cluster nodes
CreateCacheCommand(ByteString) - Constructor for class org.infinispan.commands.CreateCacheCommand
 
CreateCacheCommand(ByteString, String, String) - Constructor for class org.infinispan.commands.CreateCacheCommand
 
CreateCacheCommand(ByteString, String, String, int) - Constructor for class org.infinispan.commands.CreateCacheCommand
 
createClearNonTxInvocationContext() - Method in class org.infinispan.context.AbstractInvocationContextFactory
Deprecated.
 
createClearNonTxInvocationContext() - Method in interface org.infinispan.context.InvocationContextFactory
createComponentFactoryInternal(Class<?>, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
createContext() - Method in class org.infinispan.commands.control.LockControlCommand
 
createContext() - Method in class org.infinispan.commands.tx.PrepareCommand
 
createContext() - Method in interface org.infinispan.util.concurrent.locks.TransactionalRemoteLockCommand
It creates the transaction context.
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.ReadCommittedEntry
 
created - Variable in class org.infinispan.container.entries.TransientMortalCacheEntry
 
created() - Method in class org.infinispan.container.entries.RemoteMetadata
 
created() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
 
created() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
 
created() - Method in interface org.infinispan.metadata.InternalMetadata
 
CREATED - org.infinispan.container.entries.ReadCommittedEntry.Flags
 
createDistributedTaskBuilder(Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
createDistributedTaskBuilder(Callable<T>) - Method in interface org.infinispan.distexec.DistributedExecutorService
Deprecated.
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
Deprecated.
 
createDistributedTaskPart(DistributedTask<T>, DistributedExecuteCommand<T>, Address, int) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
createEvent(Cache<K, V>, Event.Type) - Static method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
createGlobalTransaction() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction.Externalizer
Deprecated.
 
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
Deprecated.
 
createGlobalTransaction() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction.Externalizer
 
createInitialCacheTopology() - Method in class org.infinispan.topology.ClusterCacheStatus
 
createInstance(PartitionHandlingConfiguration) - Method in interface org.infinispan.conflict.EntryMergePolicyFactory
 
createInstance(PartitionHandlingConfiguration) - Method in class org.infinispan.conflict.EntryMergePolicyFactoryRegistry
 
createInstance(StoreConfiguration) - Method in interface org.infinispan.persistence.factory.CacheStoreFactory
Returns new instance based on StoreConfiguration.
createInstance(StoreConfiguration) - Method in class org.infinispan.persistence.factory.CacheStoreFactoryRegistry
Creates new Object based on configuration.
createInstance(StoreConfiguration) - Method in class org.infinispan.persistence.factory.LocalClassLoaderCacheStoreFactory
 
createInvocationContext(boolean, int) - Method in interface org.infinispan.context.InvocationContextFactory
If we are in a tx scope this will return an TxInvocationContext.
createInvocationContext(boolean, int) - Method in class org.infinispan.context.NonTransactionalInvocationContextFactory
Deprecated.
 
createInvocationContext(boolean, int) - Method in class org.infinispan.context.TransactionalInvocationContextFactory
Deprecated.
 
createInvocationContext(Transaction, boolean) - Method in interface org.infinispan.context.InvocationContextFactory
Creates an invocation context
createInvocationContext(Transaction, boolean) - Method in class org.infinispan.context.NonTransactionalInvocationContextFactory
Deprecated.
 
createInvocationContext(Transaction, boolean) - Method in class org.infinispan.context.TransactionalInvocationContextFactory
Deprecated.
 
createL1(K, V, Metadata) - Method in interface org.infinispan.container.impl.InternalEntryFactory
Creates a L1 entry.
createL1(K, V, Metadata) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
 
createLocalExecutor(Cache<?, ?>) - Static method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
createLocalizedCacheTopology(CacheTopology) - Method in interface org.infinispan.distribution.DistributionManager
 
createLocalizedCacheTopology(CacheTopology) - Method in class org.infinispan.distribution.impl.DistributionManagerImpl
 
createMap() - Method in class org.infinispan.commands.read.GetAllCommand
 
createMixedStatus(List<E>, List<E>) - Method in class org.infinispan.xsite.status.AbstractSiteStatusBuilder
 
createMixedStatus(List<String>, List<String>) - Method in class org.infinispan.xsite.status.ContainerSiteStatusBuilder
 
createMixedStatus(List<Address>, List<Address>) - Method in class org.infinispan.xsite.status.CacheSiteStatusBuilder
 
createMultiTargetCollector(long, int, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
 
createMultiTargetCollector(C, int) - Method in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor
 
createMultiTargetCollector(C, int) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
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
 
createNonTxInvocationContext() - Method in interface org.infinispan.context.InvocationContextFactory
createNonTxInvocationContext() - Method in class org.infinispan.context.NonTransactionalInvocationContextFactory
Deprecated.
 
createNonTxInvocationContext() - Method in class org.infinispan.context.TransactionalInvocationContextFactory
Deprecated.
 
createPushStateTask() - Method in class org.infinispan.persistence.support.SingletonCacheWriter
Deprecated.
 
createRemoteInvocationContext(Address) - Method in interface org.infinispan.context.InvocationContextFactory
createRemoteInvocationContext(Address) - Method in class org.infinispan.context.NonTransactionalInvocationContextFactory
Deprecated.
 
createRemoteInvocationContext(Address) - Method in class org.infinispan.context.TransactionalInvocationContextFactory
Deprecated.
 
createRemoteInvocationContextForCommand(VisitableCommand, Address) - Method in class org.infinispan.context.AbstractInvocationContextFactory
Deprecated.
 
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
Deprecated.
 
createRemoteTxInvocationContext(RemoteTransaction, Address) - Method in class org.infinispan.context.TransactionalInvocationContextFactory
Deprecated.
 
createSegmentBasedCollector(long, Map<Address, Collection<Integer>>, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
Creates a collector for PutMapCommand.
createSingleKeyNonTxInvocationContext() - Method in interface org.infinispan.context.InvocationContextFactory
createSingleKeyNonTxInvocationContext() - Method in class org.infinispan.context.NonTransactionalInvocationContextFactory
Deprecated.
 
createSingleKeyNonTxInvocationContext() - Method in class org.infinispan.context.TransactionalInvocationContextFactory
Deprecated.
 
createStream() - Method in class org.infinispan.stream.impl.local.AbstractLocalCacheStream
 
createTransaction() - Method in class org.infinispan.transaction.tm.EmbeddedBaseTransactionManager
 
createTxInvocationContext(LocalTransaction) - Method in interface org.infinispan.context.InvocationContextFactory
createTxInvocationContext(LocalTransaction) - Method in class org.infinispan.context.NonTransactionalInvocationContextFactory
Deprecated.
 
createTxInvocationContext(LocalTransaction) - Method in class org.infinispan.context.TransactionalInvocationContextFactory
Deprecated.
 
createValue(CacheEntry) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
 
createValue(CacheEntry<?, V>) - Method in interface org.infinispan.container.impl.InternalEntryFactory
Creates an InternalCacheValue based on the InternalCacheEntry passed in.
createWrappedEntry(Object, CacheEntry) - Method in class org.infinispan.container.impl.EntryFactoryImpl
 
creatingTmpCacheTimedOut(String, Address) - Method in class org.infinispan.util.logging.Log_$logger
 
creatingTmpCacheTimedOut(String, Address) - Method in interface org.infinispan.util.logging.Log
 
creatingTmpCacheTimedOut$str() - Method in class org.infinispan.util.logging.Log_$logger
 
csm - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
csm - Variable in class org.infinispan.stream.impl.StreamResponseCommand
 
ctx - Variable in class org.infinispan.persistence.file.SingleFileStore
 
ctx - Variable in class org.infinispan.persistence.support.DelegatingCacheLoader
 
ctx - Variable in class org.infinispan.persistence.support.DelegatingCacheWriter
 
currentLevel - Variable in class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory.Builder
 
currentlyRunning - Variable in class org.infinispan.stream.impl.ClusterStreamManagerImpl
 
currentSize - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
currentTopologyId() - Method in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor
 
CUSTOM - org.infinispan.configuration.cache.BackupFailurePolicy
 
CUSTOM - org.infinispan.conflict.MergePolicy
 
CUSTOM - org.infinispan.globalstate.ConfigurationStorage
A custom configuration storage provider
CUSTOM_CONFIGURATION_STORAGE - org.infinispan.configuration.parsing.Element
 
CUSTOM_INTERCEPTORS - org.infinispan.configuration.parsing.Element
 
CUSTOM_ROLE_MAPPER - org.infinispan.configuration.parsing.Element
 
CUSTOM_STORE_CLASS - Static variable in class org.infinispan.configuration.cache.CustomStoreConfiguration
 
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.util.logging.Log_$logger
 
customInterceptorExpectsInjection(String) - Method in interface org.infinispan.util.logging.Log
 
customInterceptorExpectsInjection$str() - Method in class org.infinispan.util.logging.Log_$logger
 
customInterceptorMissingClass() - Method in class org.infinispan.util.logging.Log_$logger
 
customInterceptorMissingClass() - Method in interface org.infinispan.util.logging.Log
 
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.
customStorageStrategyNotSet() - Method in class org.infinispan.util.logging.Log_$logger
 
customStorageStrategyNotSet() - Method in interface org.infinispan.util.logging.Log
 
customStorageStrategyNotSet$str() - Method in class org.infinispan.util.logging.Log_$logger
 
customStoreClass() - Method in class org.infinispan.configuration.cache.CustomStoreConfiguration
 
customStoreClass(Class<?>) - Method in class org.infinispan.configuration.cache.CustomStoreConfigurationBuilder
 
CustomStoreConfiguration - Class in org.infinispan.configuration.cache
 
CustomStoreConfiguration(AttributeSet, AsyncStoreConfiguration, SingletonStoreConfiguration) - Constructor for class org.infinispan.configuration.cache.CustomStoreConfiguration
 
CustomStoreConfigurationBuilder - Class in org.infinispan.configuration.cache
StoreConfigurationBuilder used for stores/loaders that don't have a configuration builder
CustomStoreConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.CustomStoreConfigurationBuilder
 
CyclicDependencyException - Exception in org.infinispan.util
Thrown when a cyclic dependency exist
CyclicDependencyException(String) - Constructor for exception org.infinispan.util.CyclicDependencyException
 
CyclicDependencyException(String, Throwable) - Constructor for exception org.infinispan.util.CyclicDependencyException
 

D

data - Variable in class org.infinispan.io.GridFilesystem
 
data - Variable in class org.infinispan.remoting.MIMECacheEntry
The payload.
DATA_CONTAINER - org.infinispan.configuration.parsing.Attribute
 
DATA_CONTAINER - org.infinispan.configuration.parsing.Element
 
DATA_CONTAINER - Static variable in class org.infinispan.configuration.cache.DataContainerConfiguration
Deprecated.
 
DATA_REHASHED - org.infinispan.notifications.cachelistener.event.Event.Type
 
DataCommand - Interface in org.infinispan.commands
Commands of this type manipulate data in the cache.
dataContainer - Variable in class org.infinispan.commands.write.InvalidateVersionsCommand
 
dataContainer - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
dataContainer - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
dataContainer - Variable in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
dataContainer - Variable in class org.infinispan.interceptors.impl.ClusteringInterceptor
 
dataContainer - Variable in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
dataContainer - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
dataContainer - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
dataContainer - Variable in class org.infinispan.statetransfer.StateProviderImpl
 
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
Deprecated.
data container is no longer to exposed via configuration at a later point
dataContainer(DataContainer) - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
Deprecated.
data container is no longer to exposed via configuration at a later point
DataContainer<K,​V> - Interface in org.infinispan.container
The main internal data structure which stores entries.
DataContainer.ComputeAction<K,​V> - Interface in org.infinispan.container
 
DataContainerConfiguration - Class in org.infinispan.configuration.cache
Deprecated.
DataContainerConfigurationBuilder - Class in org.infinispan.configuration.cache
Deprecated.
dataContainerConfigurationDeprecated() - Method in class org.infinispan.util.logging.Log_$logger
 
dataContainerConfigurationDeprecated() - Method in interface org.infinispan.util.logging.Log
 
dataContainerConfigurationDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
DataContainerFactory - Class in org.infinispan.factories
Constructs the data container
DataContainerFactory() - Constructor for class org.infinispan.factories.DataContainerFactory
 
DataContainerRemoveIterator<K,​V> - Class in org.infinispan.util
This is an iterator that will iterate upon the data container.
DataContainerRemoveIterator(Cache<K, V>) - Constructor for class org.infinispan.util.DataContainerRemoveIterator
 
DataContainerRemoveIterator(Cache<K, V>, DataContainer<K, V>) - Constructor for class org.infinispan.util.DataContainerRemoveIterator
 
DataConversion - Class in org.infinispan.encoding
Handle conversions for Keys or values.
DataConversion.Externalizer - Class in org.infinispan.encoding
 
DataConversionAwareListenable<K,​V> - Interface in org.infinispan.notifications
 
DataLocality - Enum in org.infinispan.distribution
Used to determine whether a key is mapped to a local node.
dataRehashed(DataRehashedEvent<K, V>) - Method in class org.infinispan.stream.impl.LocalStreamManagerImpl
We need to listen to data rehash events in case if data moves while we are iterating over it.
DataRehashed - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when a rehash starts or ends.
DataRehashedEvent<K,​V> - Interface in org.infinispan.notifications.cachelistener.event
An event passed in to methods annotated with DataRehashed.
dataType() - Method in annotation type org.infinispan.jmx.annotations.ManagedAttribute
 
DataType - Enum in org.infinispan.jmx.annotations
 
DataWriteCommand - Interface in org.infinispan.commands.write
Mixes features from DataCommand and WriteCommand
DDAsyncInterceptor - Class in org.infinispan.interceptors
Interface for async interceptors using double-dispatch.
DDAsyncInterceptor() - Constructor for class org.infinispan.interceptors.DDAsyncInterceptor
 
deadlockCheck(DeadlockChecker) - Method in class org.infinispan.util.concurrent.locks.impl.InfinispanLock
It forces a deadlock checking.
deadlockCheck(DeadlockChecker) - Method in interface org.infinispan.util.concurrent.locks.impl.LockContainer
It forces a deadlock checks in all existing locks.
deadlockCheck(DeadlockChecker) - Method in class org.infinispan.util.concurrent.locks.impl.PerKeyLockContainer
 
deadlockCheck(DeadlockChecker) - Method in class org.infinispan.util.concurrent.locks.impl.StripedLockContainer
 
DeadlockChecker - Interface in org.infinispan.util.concurrent.locks
An interface to implement the deadlock algorithm.
deadlockDetected(Object, Object) - Method in interface org.infinispan.util.concurrent.locks.DeadlockChecker
It checks for deadlock.
DeadlockDetectedException - Exception in org.infinispan.util.concurrent.locks
Exception signaling detected deadlocks.
DeadlockDetectedException(String) - Constructor for exception org.infinispan.util.concurrent.locks.DeadlockDetectedException
 
deadlockDetection() - Method in class org.infinispan.configuration.cache.Configuration
Deprecated.
Since 9.0, will be ignored.
deadlockDetection() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
Deprecated.
Since 9.0, deadlock detection is always disabled.
deadlockDetection() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
Deprecated.
Since 9.0, deadlock detection is always disabled.
DeadlockDetectionConfiguration - Class in org.infinispan.configuration.cache
Deprecated.
Since 9.0, deadlock detection is always disabled.
DeadlockDetectionConfigurationBuilder - Class in org.infinispan.configuration.cache
Deprecated.
Since 9.0, deadlock detection is always disabled.
DEADLOCKED - org.infinispan.util.concurrent.locks.LockState
The deadlock occurred with another possible lock owner and it should abort.
deallocate() - Method in class org.infinispan.container.offheap.MemoryAddressHash
 
deallocate(long, long) - Method in interface org.infinispan.container.offheap.OffHeapMemoryAllocator
Deallocates the memory at the given address assuming a given size.
deallocate(long, long) - Method in class org.infinispan.container.offheap.UnpooledOffHeapMemoryAllocator
 
DEBUG_DEPENDENCIES - Static variable in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
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.cache.impl
A decorator to a cache, which can be built with a specific set of Flags.
DecoratedCache(AdvancedCache<K, V>) - Constructor for class org.infinispan.cache.impl.DecoratedCache
 
DecoratedCache(AdvancedCache<K, V>, Object, Flag...) - Constructor for class org.infinispan.cache.impl.DecoratedCache
 
DecoratedCache(AdvancedCache<K, V>, Collection<Flag>) - Constructor for class org.infinispan.cache.impl.DecoratedCache
 
DecoratedCache(AdvancedCache<K, V>, Flag...) - Constructor for class org.infinispan.cache.impl.DecoratedCache
 
DecoratedEventLogger - Class in org.infinispan.util.logging.events.impl
DecoratedEventLogger.
DecoratedEventLogger(EventLogger) - Constructor for class org.infinispan.util.logging.events.impl.DecoratedEventLogger
 
decorateLocal(ConsistentHash, boolean, IntSet, Publisher<S>) - Method in class org.infinispan.stream.impl.CompletionRehashPublisherDecorator
 
decorateRemote(ClusterStreamManager.RemoteIteratorPublisher<S>) - Method in class org.infinispan.stream.impl.CompletionRehashPublisherDecorator
 
decOwned(Address) - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
 
decPrimaryOwned(Address) - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
 
DEFAULT - org.infinispan.configuration.global.ShutdownHookBehavior
By default a shutdown hook is registered if no MBean server (apart from the JDK default) is detected.
DEFAULT - org.infinispan.configuration.parsing.Element
 
DEFAULT - org.infinispan.eviction.EvictionThreadPolicy
 
DEFAULT - org.infinispan.transaction.TransactionProtocol
uses the 2PC protocol
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 - org.infinispan.configuration.parsing.Attribute
 
DEFAULT_CHUNK_SIZE - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
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_JGROUPS_CONFIGURATION_FILE - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
DEFAULT_KEY - Static variable in class org.infinispan.encoding.DataConversion
 
DEFAULT_MARSHALL_VERSION - Static variable in class org.infinispan.configuration.global.GlobalConfiguration
Deprecated.
Since 9.4, use Version.getVersionShort() instead.
DEFAULT_MAX_RETRIES - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
DEFAULT_MEDIA_TYPE - Static variable in class org.infinispan.configuration.cache.ContentTypeConfiguration
 
DEFAULT_PATTERN - Static variable in class org.infinispan.factories.threads.DefaultThreadFactory
 
DEFAULT_RECOVERY_INFO_CACHE - Static variable in class org.infinispan.configuration.cache.RecoveryConfiguration
 
DEFAULT_STALE_STATS_THRESHOLD - Static variable in class org.infinispan.stats.impl.AbstractClusterStats
 
DEFAULT_TIMEOUT - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
DEFAULT_TRANSPORT - Static variable in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
DEFAULT_VALUE - Static variable in class org.infinispan.encoding.DataConversion
 
DEFAULT_WAIT_TIME - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
DefaultBuilder() - Constructor for class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl.DefaultBuilder
 
defaultCacheConfigurationWithoutName() - Method in class org.infinispan.util.logging.Log_$logger
 
defaultCacheConfigurationWithoutName() - Method in interface org.infinispan.util.logging.Log
 
defaultCacheConfigurationWithoutName$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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(InputStream) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs and starts a new instance of the CacheManager, using the input stream passed in to read configuration file contents.
DefaultCacheManager(InputStream, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs a new instance of the CacheManager, using the input stream passed in to read configuration file contents.
DefaultCacheManager(String) - 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(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(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.
DefaultCacheManagerAdmin - Class in org.infinispan.manager
The default implementation of EmbeddedCacheManagerAdmin
defaultCacheName() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
defaultCacheName() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
defaultCacheName(String) - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
Sets the name of the cache that acts as the default cache and is returned by CacheContainer.getCache().
defaultChunkSize - Variable in class org.infinispan.io.GridFilesystem
 
defaultClusteredBuilder() - Static method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
DefaultConflictManager<K,​V> - Class in org.infinispan.conflict.impl
 
DefaultConflictManager() - Constructor for class org.infinispan.conflict.impl.DefaultConflictManager
 
DefaultConsistentHash - Class in org.infinispan.distribution.ch.impl
Default ConsistentHash implementation.
DefaultConsistentHash(Hash, int, int, List<Address>, Map<Address, Float>, List<Address>[]) - Constructor for class org.infinispan.distribution.ch.impl.DefaultConsistentHash
 
DefaultConsistentHash.Externalizer - Class in org.infinispan.distribution.ch.impl
 
DefaultConsistentHashFactory - Class in org.infinispan.distribution.ch.impl
Default implementation of ConsistentHashFactory.
DefaultConsistentHashFactory() - Constructor for class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
 
DefaultConsistentHashFactory.Builder - Class in org.infinispan.distribution.ch.impl
 
DefaultConsistentHashFactory.Externalizer - Class in org.infinispan.distribution.ch.impl
 
DefaultDataContainer<K,​V> - Class in org.infinispan.container.impl
DefaultDataContainer is both eviction and non-eviction based data container.
DefaultDataContainer(int) - Constructor for class org.infinispan.container.impl.DefaultDataContainer
 
DefaultDataContainer(int, long, EntrySizeCalculator<? super K, ? super V>) - Constructor for class org.infinispan.container.impl.DefaultDataContainer
Method invoked when memory policy is used.
DefaultDataContainer(int, long, EvictionType) - Constructor for class org.infinispan.container.impl.DefaultDataContainer
 
DefaultDataContainer(long, EntrySizeCalculator<? super K, ? super InternalCacheEntry<K, V>>) - Constructor for class org.infinispan.container.impl.DefaultDataContainer
Constructor that allows user to provide a size calculator that also handles the cache entry and metadata.
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
Deprecated.
since 9.1 Please use EmbeddedCacheManager.executor() or CacheStream instead.
DefaultExecutorService(Cache<?, ?>) - Constructor for class org.infinispan.distexec.DefaultExecutorService
Deprecated.
Creates a new DefaultExecutorService given a master cache node for local task execution.
DefaultExecutorService(Cache<?, ?>, ExecutorService) - Constructor for class org.infinispan.distexec.DefaultExecutorService
Deprecated.
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
Deprecated.
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.
defaultLifespan - Variable in class org.infinispan.cache.impl.CacheSupport
 
DefaultLockManager - Class in org.infinispan.util.concurrent.locks.impl
The default LockManager implementation for transactional and non-transactional caches.
DefaultLockManager() - Constructor for class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
 
defaultMapEntryFromDataContainer(InternalCacheEntry, InternalEntryFactory) - Static method in class org.infinispan.statetransfer.OutboundTransferTask
 
defaultMapEntryFromStore(MarshalledEntry, InternalEntryFactory) - Static method in class org.infinispan.statetransfer.OutboundTransferTask
 
defaultMaxIdleTime - Variable in class org.infinispan.cache.impl.CacheSupport
 
defaultMetadata - Variable in class org.infinispan.cache.impl.CacheImpl
 
DefaultPendingLockManager - Class in org.infinispan.util.concurrent.locks.impl
The default implementation for PendingLockManager.
DefaultPendingLockManager() - Constructor for class org.infinispan.util.concurrent.locks.impl.DefaultPendingLockManager
 
DefaultReadyAction - Class in org.infinispan.remoting.inboundhandler.action
A list of Action to be executed to check when it is ready.
DefaultReadyAction(ActionState, Action...) - Constructor for class org.infinispan.remoting.inboundhandler.action.DefaultReadyAction
 
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
 
DefaultSegmentedDataContainer<K,​V> - Class in org.infinispan.container.impl
DataContainer implementation that internally stores entries in an array of maps.
DefaultSegmentedDataContainer(Supplier<ConcurrentMap<K, InternalCacheEntry<K, V>>>, int) - Constructor for class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
defaultSynchronous - Variable in class org.infinispan.interceptors.impl.BaseRpcInterceptor
 
DefaultThreadFactory - Class in org.infinispan.factories.threads
Thread factory based on JBoss Thread's JBossThreadFactory.
DefaultThreadFactory(String, ThreadGroup, int, String, String, String) - Constructor for class org.infinispan.factories.threads.DefaultThreadFactory
Construct a new instance.
DefaultThreadFactory(ThreadGroup, int, String, String, String) - Constructor for class org.infinispan.factories.threads.DefaultThreadFactory
Construct a new instance.
DefaultTopologyRunnable - Class in org.infinispan.remoting.inboundhandler
The default Runnable for the remote commands receives.
DefaultTopologyRunnable(BasePerCacheInboundInvocationHandler, CacheRpcCommand, Reply, TopologyMode, int, boolean) - Constructor for class org.infinispan.remoting.inboundhandler.DefaultTopologyRunnable
 
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
 
defaultValue() - Static method in class org.infinispan.functional.MetaParam.MetaLifespan
 
defaultValue() - Static method in class org.infinispan.functional.MetaParam.MetaMaxIdle
 
defaultValue() - Static method in enum org.infinispan.functional.Param.ExecutionMode
 
defaultValue() - Static method in enum org.infinispan.functional.Param.LockingMode
 
defaultValue() - Static method in enum org.infinispan.functional.Param.PersistenceMode
Provides default persistence mode.
defaultValue() - Static method in enum org.infinispan.functional.Param.ReplicationMode
 
defaultValue() - Static method in enum org.infinispan.functional.Param.StatisticsMode
 
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.
defineConfiguration(String, String, Configuration) - Method in class org.infinispan.manager.DefaultCacheManager
 
defineConfiguration(String, String, Configuration) - Method in interface org.infinispan.manager.EmbeddedCacheManager
Defines a named cache's configuration using by first reading the template configuration and then applying the override afterwards to generate a configuration.
defineConfiguration(String, String, Configuration) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
defineConfiguration(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 by using the provided configuration
defineConfiguration(String, Configuration) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
DefineConfigurationAction - Class in org.infinispan.security.actions
DefineConfigurationAction.
DefineConfigurationAction(EmbeddedCacheManager, String, Configuration) - Constructor for class org.infinispan.security.actions.DefineConfigurationAction
 
DEGRADED_MODE - org.infinispan.partitionhandling.AvailabilityMode
Data can not be safely accessed because of a network split or successive nodes leaving.
degradedModeKeysUnavailable(Collection<?>) - Method in class org.infinispan.util.logging.Log_$logger
 
degradedModeKeysUnavailable(Collection<?>) - Method in interface org.infinispan.util.logging.Log
 
degradedModeKeysUnavailable$str() - Method in class org.infinispan.util.logging.Log_$logger
 
degradedModeKeyUnavailable(Object) - Method in class org.infinispan.util.logging.Log_$logger
 
degradedModeKeyUnavailable(Object) - Method in interface org.infinispan.util.logging.Log
 
degradedModeKeyUnavailable$str() - Method in class org.infinispan.util.logging.Log_$logger
 
degradedModeLockUnavailable() - Method in class org.infinispan.util.logging.Log_$logger
 
degradedModeLockUnavailable() - Method in interface org.infinispan.util.logging.Log
 
degradedModeLockUnavailable$str() - Method in class org.infinispan.util.logging.Log_$logger
 
delegate - Variable in class org.infinispan.remoting.inboundhandler.AbstractDelegatingHandler
 
delegate() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
delegate() - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
delegate() - Method in class org.infinispan.container.impl.InternalDataContainerAdapter
 
delegate() - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
delegate() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
 
delegate() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
 
delegate() - Method in class org.infinispan.stream.impl.interceptor.AbstractDelegatingEntryCacheSet
 
delegate() - Method in class org.infinispan.stream.impl.interceptor.AbstractDelegatingKeyCacheSet
 
delegate() - Method in class org.infinispan.util.AbstractDelegatingCacheCollection
 
delegate() - Method in class org.infinispan.util.AbstractDelegatingCacheSet
 
delegate() - Method in class org.infinispan.util.AbstractDelegatingCloseableIteratorCollection
 
delegate() - Method in class org.infinispan.util.AbstractDelegatingCloseableIteratorSet
 
delegate() - Method in class org.infinispan.util.EntryWrapper
 
DelegatingCacheEntryListenerInvocation<K,​V> - Class in org.infinispan.notifications.cachelistener.filter
A wrapper around a CacheEntryListenerInvocation that keeps a reference to the FilterIndexingServiceProvider instance that handles this invocation.
DelegatingCacheEntryListenerInvocation(CacheEntryListenerInvocation<K, V>) - Constructor for class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
DelegatingCacheLoader<K,​V> - 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(int, Object) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
Removes the entry for the provided key which is in the given segment.
delete(int, Object) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
delete(Object) - Method in class org.infinispan.persistence.async.AsyncCacheWriter
 
delete(Object) - Method in class org.infinispan.persistence.file.SingleFileStore
 
delete(Object) - Method in interface org.infinispan.persistence.spi.CacheWriter
 
delete(Object) - Method in class org.infinispan.persistence.support.AbstractSegmentedAdvancedLoadWriteStore
 
delete(Object) - Method in class org.infinispan.persistence.support.DelegatingCacheWriter
 
delete(Object) - Method in class org.infinispan.persistence.support.SingletonCacheWriter
Deprecated.
 
DELETE - Static variable in class org.infinispan.functional.impl.StatsEnvelope
 
deleteBatch(Iterable) - Method in class org.infinispan.persistence.async.AsyncCacheWriter
 
deleteBatch(Iterable<Object>) - Method in interface org.infinispan.persistence.spi.CacheWriter
Remove all provided keys from the store in a single batch operation.
deleteBatch(Iterable<Object>) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
deleteBatchFromAllNonTxStores(Iterable<Object>, Predicate<? super StoreConfiguration>, long) - Method in interface org.infinispan.persistence.manager.PersistenceManager
Remove all entries from the underlying non-transactional stores as a single batch.
deleteBatchFromAllNonTxStores(Iterable<Object>, Predicate<? super StoreConfiguration>, long) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
deleteBatchFromAllNonTxStores(Iterable<Object>, Predicate<? super StoreConfiguration>, long) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
deleteFromAllStores(Object, int, Predicate<? super StoreConfiguration>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
 
deleteFromAllStores(Object, int, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
deleteFromAllStores(Object, int, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
deleteOnExit() - Method in class org.infinispan.io.GridFile
 
delistResource(XAResource, int) - Method in class org.infinispan.transaction.tm.DummyTransaction
Deprecated.
De-list an XA resource from this transaction.
deliverMode(DeliverOrder) - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
Deprecated.
 
deliverOrder() - Method in class org.infinispan.remoting.rpc.RpcOptions
 
DeliverOrder - Enum in org.infinispan.remoting.inboundhandler
Used in RPC, it defines how the messages are delivered to the nodes.
delta() - Method in interface org.infinispan.atomic.DeltaAware
Deprecated.
Extracts changes made to implementations, in an efficient format that can easily and cheaply be serialized and deserialized.
Delta - Interface in org.infinispan.atomic
Deprecated.
since 9.1
DELTA_WRITE - org.infinispan.context.Flag
Deprecated.
since 9.1
DELTA_WRITE - Static variable in class org.infinispan.context.impl.FlagBitSets
Deprecated.
DeltaAware - Interface in org.infinispan.atomic
Deprecated.
since 9.1
DeltaCompositeKey - Class in org.infinispan.atomic
Deprecated.
since 9.1
DeltaCompositeKey(Object, Object) - Constructor for class org.infinispan.atomic.DeltaCompositeKey
Deprecated.
 
DeltaCompositeKey.DeltaCompositeKeyExternalizer - Class in org.infinispan.atomic
Deprecated.
DeltaCompositeKeyExternalizer() - Constructor for class org.infinispan.atomic.DeltaCompositeKey.DeltaCompositeKeyExternalizer
Deprecated.
 
deny(String, String) - Method in class org.infinispan.security.impl.ClusterRoleMapper
 
DENY - org.infinispan.security.AuditResponse
 
DENY_READ_WRITES - org.infinispan.partitionhandling.PartitionHandling
If the partition does not have all owners for a given segment, both reads and writes are denied for all keys in that segment.
DependencyGraph<T> - Class in org.infinispan.util
Graph to track dependencies between objects
DependencyGraph() - Constructor for class org.infinispan.util.DependencyGraph
 
deprecatedDefaultCache() - Method in class org.infinispan.util.logging.Log_$logger
 
deprecatedDefaultCache() - Method in interface org.infinispan.util.logging.Log
 
deprecatedDefaultCache$str() - Method in class org.infinispan.util.logging.Log_$logger
 
description() - Method in annotation type org.infinispan.jmx.annotations.ManagedAttribute
 
description() - Method in annotation type org.infinispan.jmx.annotations.ManagedOperation
 
description() - Method in annotation type org.infinispan.jmx.annotations.MBean
 
description() - Method in annotation type org.infinispan.jmx.annotations.Parameter
 
destroy() - Method in class org.infinispan.persistence.file.SingleFileStore
 
destroy() - Method in interface org.infinispan.persistence.spi.ExternalStore
Method to be used to destroy and clean up any resources associated with this store.
destroy() - Static method in class org.infinispan.transaction.tm.BatchModeTransactionManager
 
destroy() - Static method in class org.infinispan.transaction.tm.DummyTransactionManager
Deprecated.
 
destroy() - Static method in class org.infinispan.transaction.tm.EmbeddedTransactionManager
 
detail - Variable in class org.infinispan.util.logging.events.impl.DecoratedEventLogger
 
detail(String) - Method in interface org.infinispan.util.logging.events.EventLogger
Sets a detail for this event log which could include additional information.
detail(String) - Method in class org.infinispan.util.logging.events.impl.BasicEventLogger
 
detail(String) - Method in class org.infinispan.util.logging.events.impl.DecoratedEventLogger
 
detail(Throwable) - Method in interface org.infinispan.util.logging.events.EventLogger
Sets a throwable to include as detail for this event.
DETAIL - org.infinispan.jmx.annotations.DisplayType
 
detectScope(Class<?>) - Static method in class org.infinispan.factories.scopes.ScopeDetector
 
DIFFERENT_MACHINE - org.infinispan.manager.ClusterExecutionPolicy
The command will be executed only on a different machine.
DIFFERENT_RACK - org.infinispan.manager.ClusterExecutionPolicy
The command will be executed on machine on a different rack.
DIFFERENT_SITE - org.infinispan.manager.ClusterExecutionPolicy
The command will be executed on a different site.
DIR - Static variable in class org.infinispan.io.GridFile.Metadata
 
directoryCannotBeCreated(String) - Method in class org.infinispan.util.logging.Log_$logger
 
directoryCannotBeCreated(String) - Method in interface org.infinispan.util.logging.Log
 
directoryCannotBeCreated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
disable() - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
disable() - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
disable() - Method in class org.infinispan.configuration.cache.CompatibilityModeConfigurationBuilder
Disables compatibility mode between embedded.
disable() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
Deprecated.
Since 9.0, deadlock detection is always disabled.
disable() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
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
Deprecated.
Enable the singleton store cache store
disable() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
Deprecated.
Disables storing both keys and values as binary.
disable() - Method in class org.infinispan.configuration.cache.VersioningConfigurationBuilder
Deprecated.
 
disable() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
 
disable() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
 
disable() - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
 
DISABLE_BACKUPS - Static variable in class org.infinispan.configuration.cache.SitesConfiguration
 
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
disableReaper() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
Disable the background reaper to test entries for expiration.
disableRehashAware() - Method in interface org.infinispan.BaseCacheStream
Disables tracking of rehash events that could occur to the underlying cache.
disableRehashAware() - Method in interface org.infinispan.CacheStream
Disables tracking of rehash events that could occur to the underlying cache.
disableRehashAware() - Method in interface org.infinispan.DoubleCacheStream
Disables tracking of rehash events that could occur to the underlying cache.
disableRehashAware() - Method in interface org.infinispan.IntCacheStream
Disables tracking of rehash events that could occur to the underlying cache.
disableRehashAware() - Method in interface org.infinispan.LockedStream
Disables tracking of rehash events that could occur to the underlying cache.
disableRehashAware() - Method in interface org.infinispan.LongCacheStream
Disables tracking of rehash events that could occur to the underlying cache.
disableRehashAware() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
disableRehashAware() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
disableRehashAware() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
disableRehashAware() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
disableRehashAware() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
disableRehashAware() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
disableRehashAware() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
disableRehashAware() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
disableRehashAware() - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
disableRehashAware() - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
disableRehashAware() - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
disableRehashAware() - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
disableRehashAware() - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
disableRehashAware() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
disableStore(String) - Method in class org.infinispan.interceptors.impl.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
 
disableStore(String) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
disconnectChannel - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
disconnectJGroups(String) - Method in class org.infinispan.util.logging.Log_$logger
 
disconnectJGroups(String) - Method in interface org.infinispan.util.logging.Log
 
disconnectJGroups$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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.
displayName() - Method in annotation type org.infinispan.jmx.annotations.ManagedAttribute
 
displayName() - Method in annotation type org.infinispan.jmx.annotations.ManagedOperation
 
displayType() - Method in annotation type org.infinispan.jmx.annotations.ManagedAttribute
 
DisplayType - Enum in org.infinispan.jmx.annotations
 
DIST - org.infinispan.configuration.parsing.ParsedCacheMode
 
DIST_ASYNC - org.infinispan.configuration.cache.CacheMode
Async DIST
DIST_SYNC - org.infinispan.configuration.cache.CacheMode
Synchronous DIST
DistCacheWriterInterceptor - Class in org.infinispan.interceptors.impl
Cache store interceptor specific for the distribution and replication cache modes.
DistCacheWriterInterceptor() - Constructor for class org.infinispan.interceptors.impl.DistCacheWriterInterceptor
 
distinct() - Method in interface org.infinispan.CacheStream
distinct() - Method in interface org.infinispan.DoubleCacheStream
distinct() - Method in interface org.infinispan.IntCacheStream
distinct() - Method in interface org.infinispan.LongCacheStream
distinct() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
distinct() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
distinct() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
distinct() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
distinct() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
distinct() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
distinct() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
distinct() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
distinct() - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
distinct() - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
distinct() - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
distinct() - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
distinct() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
DistinctDoubleOperation - Class in org.infinispan.stream.impl.intops.primitive.d
Performs distinct operation on a DoubleStream
DistinctIntOperation - Class in org.infinispan.stream.impl.intops.primitive.i
Performs distinct operation on a IntStream
DistinctLongOperation - Class in org.infinispan.stream.impl.intops.primitive.l
Performs distinct operation on a LongStream
DistinctOperation<S> - Class in org.infinispan.stream.impl.intops.object
Performs distinct operation on a regular Stream
distLostDataCheck(ConsistentHash, List<Address>) - Static method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
DISTRIBUTED_CACHE - org.infinispan.configuration.parsing.Element
 
DISTRIBUTED_CACHE_CONFIGURATION - org.infinispan.configuration.parsing.Element
 
DISTRIBUTED_SYNC_TIMEOUT - Static variable in class org.infinispan.configuration.global.TransportConfiguration
 
distributedBatchSize - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
distributedBatchSize(int) - Method in interface org.infinispan.BaseCacheStream
Controls how many keys are returned from a remote node when using a stream terminal operation with a distributed cache to back this stream.
distributedBatchSize(int) - Method in interface org.infinispan.CacheStream
Controls how many keys are returned from a remote node when using a stream terminal operation with a distributed cache to back this stream.
distributedBatchSize(int) - Method in interface org.infinispan.DoubleCacheStream
Controls how many keys are returned from a remote node when using a stream terminal operation with a distributed cache to back this stream.
distributedBatchSize(int) - Method in interface org.infinispan.IntCacheStream
Controls how many keys are returned from a remote node when using a stream terminal operation with a distributed cache to back this stream.
distributedBatchSize(int) - Method in interface org.infinispan.LockedStream
Controls how many keys are returned from a remote node when using a stream terminal operation with a distributed cache to back this stream.
distributedBatchSize(int) - Method in interface org.infinispan.LongCacheStream
Controls how many keys are returned from a remote node when using a stream terminal operation with a distributed cache to back this stream.
distributedBatchSize(int) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
distributedBatchSize(int) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
distributedBatchSize(int) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
distributedBatchSize(int) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
distributedBatchSize(int) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
distributedBatchSize(int) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
distributedBatchSize(int) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
distributedBatchSize(int) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
distributedBatchSize(int) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
distributedBatchSize(int) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
distributedBatchSize(int) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
distributedBatchSize(int) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
distributedBatchSize(int) - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
distributedBatchSize(int) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
DistributedCacheStream<Original,​R> - Class in org.infinispan.stream.impl
Implementation of CacheStream that provides support for lazily distributing stream methods to appropriate nodes
DistributedCacheStream(Address, boolean, DistributionManager, Supplier<CacheStream<R>>, ClusterStreamManager, boolean, int, Executor, ComponentRegistry, Function<? super Original, ?>) - Constructor for class org.infinispan.stream.impl.DistributedCacheStream
Standard constructor requiring all pertinent information to properly utilize a distributed cache stream
DistributedCacheStream(AbstractCacheStream) - Constructor for class org.infinispan.stream.impl.DistributedCacheStream
This constructor is to be used only when a user calls a map or flat map method changing back to a regular Stream from an IntStream, DoubleStream etc.
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.
DistributedDoubleCacheStream<Original> - Class in org.infinispan.stream.impl
Implementation of DoubleStream that utilizes a lazily evaluated distributed back end execution.
DistributedDoubleCacheStream(AbstractCacheStream) - Constructor for class org.infinispan.stream.impl.DistributedDoubleCacheStream
This constructor is to be used only when a user calls a map or flat map method changing to a DoubleStream from a CacheStream, Stream, IntStream, LongStream etc.
DistributedExecuteCommand<V> - Class in org.infinispan.commands.read
DistributedExecuteCommand is used to migrate Callable and execute it in remote JVM.
DistributedExecuteCommand() - Constructor for class org.infinispan.commands.read.DistributedExecuteCommand
 
DistributedExecuteCommand(ByteString) - Constructor for class org.infinispan.commands.read.DistributedExecuteCommand
 
DistributedExecuteCommand(ByteString, Collection<Object>, Callable<V>) - 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<CompletableFuture<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.
DistributedExecutorService - Interface in org.infinispan.distexec
Deprecated.
since 9.1 Please use ClusterExecutor or CacheStream instead.
distributedExecutorsNotSupported() - Method in class org.infinispan.util.logging.Log_$logger
 
distributedExecutorsNotSupported() - Method in interface org.infinispan.util.logging.Log
 
distributedExecutorsNotSupported$str() - Method in class org.infinispan.util.logging.Log_$logger
 
DistributedIntCacheStream<Original> - Class in org.infinispan.stream.impl
Implementation of IntStream that utilizes a lazily evaluated distributed back end execution.
DistributedIntCacheStream(AbstractCacheStream) - Constructor for class org.infinispan.stream.impl.DistributedIntCacheStream
This constructor is to be used only when a user calls a map or flat map method changing to an IntStream from a CacheStream, Stream, DoubleStream, LongStream etc.
DistributedLongCacheStream<Original> - Class in org.infinispan.stream.impl
Implementation of LongStream that utilizes a lazily evaluated distributed back end execution.
DistributedLongCacheStream(AbstractCacheStream) - Constructor for class org.infinispan.stream.impl.DistributedLongCacheStream
This constructor is to be used only when a user calls a map or flat map method changing to an IntStream from a CacheStream, Stream, DoubleStream, IntStream etc.
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.
distributedTaskFailover(Address, Address, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
distributedTaskFailover(Address, Address, Exception) - Method in interface org.infinispan.util.logging.Log
 
distributedTaskFailover$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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
 
DistributionBulkInterceptor<K,​V> - Class in org.infinispan.interceptors.distribution
Interceptor that handles bulk entrySet and keySet commands when using in a distributed/replicated environment.
DistributionBulkInterceptor() - Constructor for class org.infinispan.interceptors.distribution.DistributionBulkInterceptor
 
DistributionBulkInterceptor.BackingEntrySet<K,​V> - Class in org.infinispan.interceptors.distribution
 
DistributionBulkInterceptor.BackingKeySet<K,​V> - Class in org.infinispan.interceptors.distribution
 
DistributionBulkInterceptor.TxBackingEntrySet<K,​V> - Class in org.infinispan.interceptors.distribution
 
DistributionInfo - Class in org.infinispan.distribution
 
DistributionInfo(int, Address, List<Address>, List<Address>, Collection<Address>, Address) - Constructor for class org.infinispan.distribution.DistributionInfo
 
DistributionLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
 
distributionManager - Variable in class org.infinispan.commands.write.InvalidateVersionsCommand
 
distributionManager - Variable in class org.infinispan.expiration.impl.ClusterExpirationManager
 
distributionManager - Variable in class org.infinispan.interceptors.impl.ClusteringInterceptor
 
distributionManager - Variable in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
distributionManager - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
distributionManager - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
distributionManager - Variable in class org.infinispan.statetransfer.StateProviderImpl
 
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.impl
The default distribution manager implementation
DistributionManagerImpl() - Constructor for class org.infinispan.distribution.impl.DistributionManagerImpl
 
DLD_NORECOVERY_NOXA - org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
Deprecated.
DLD_NORECOVERY_XA - org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
Deprecated.
DLD_RECOVERY_XA - org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
Deprecated.
DldGlobalTransaction - Class in org.infinispan.transaction.xa
Deprecated.
Since 9.0, no longer used.
DldGlobalTransaction() - Constructor for class org.infinispan.transaction.xa.DldGlobalTransaction
Deprecated.
 
DldGlobalTransaction(Address, boolean) - Constructor for class org.infinispan.transaction.xa.DldGlobalTransaction
Deprecated.
 
DldGlobalTransaction.Externalizer - Class in org.infinispan.transaction.xa
Deprecated.
dm - Variable in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
dm - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
doAddBackupOwners(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
 
doAfterCall(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
Deprecated.
Callback that is invoked after every handleXXX() method defined above.
doAs(Subject, PrivilegedAction<T>) - Static method in class org.infinispan.security.Security
A "lightweight" implementation of Subject.doAs(Subject, PrivilegedAction) which uses a ThreadLocal Subject instead of modifying the current AccessControlContext.
doAs(Subject, PrivilegedExceptionAction<T>) - Static method in class org.infinispan.security.Security
A "lightweight" implementation of Subject.doAs(Subject, PrivilegedExceptionAction) which uses a ThreadLocal Subject instead of modifying the current AccessControlContext.
doBeforeCall(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
Deprecated.
 
doCheck(Object, boolean, long) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
doCheck(Object, boolean, long) - Method in class org.infinispan.scattered.impl.ScatteredPartitionHandlingManagerImpl
 
doCopyOwners() - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
doHandleClusterView() - Method in class org.infinispan.topology.ClusterCacheStatus
 
doJoin(Address, CacheJoinInfo) - Method in class org.infinispan.topology.ClusterCacheStatus
 
doLeave(Address) - Method in class org.infinispan.topology.ClusterCacheStatus
 
domain() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
doMergePartitions(Map<Address, CacheStatusResponse>) - Method in class org.infinispan.topology.ClusterCacheStatus
 
DONT_LOAD - org.infinispan.commands.VisitableCommand.LoadType
Never load previous value.
DONT_REGISTER - org.infinispan.configuration.global.ShutdownHookBehavior
Forces the cache NOT to register a shutdown hook, even if no MBean server is detected.
doPrivileged(PrivilegedAction<T>) - Static method in class org.infinispan.security.Security
 
doPrivileged(PrivilegedExceptionAction<T>) - Static method in class org.infinispan.security.Security
 
doReadObject(ObjectInput) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash.Externalizer
 
doReadObject(ObjectInput) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash.Externalizer
 
doReadObject(ObjectInput) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash.Externalizer
 
doReadObject(ObjectInput) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress.Externalizer
 
doReadObject(ObjectInput) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress.Externalizer
 
doReadObject(ObjectInput) - Method in class org.infinispan.topology.CacheTopology.Externalizer
 
doReadObject(ObjectInput) - Method in class org.infinispan.topology.ManagerStatusResponse.Externalizer
 
doRealInvocation(Event<K, V>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
doRealInvocation(EventWrapper<K, V, CacheEntryEvent<K, V>>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
doRealInvocation(EventWrapper<K, V, CacheEntryEvent<K, V>>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.ClusteredListenerInvocation
 
DOUBLE - org.infinispan.stream.impl.IntermediateType
 
doubleCacheStream() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
doubleCacheStream() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
doubleCacheStream() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
doubleCacheStream() - Method in class org.infinispan.stream.impl.tx.TxDistributedCacheStream
 
doubleCacheStream() - Method in class org.infinispan.stream.impl.tx.TxDistributedIntCacheStream
 
doubleCacheStream() - Method in class org.infinispan.stream.impl.tx.TxDistributedLongCacheStream
 
DoubleCacheStream - Interface in org.infinispan
A DoubleStream that has additional methods to allow for Serializable instances.
DoubleSummaryStatisticsExternalizer - Class in org.infinispan.marshall.exts
Externalizer used for DoubleSummaryStatistics.
DoubleSummaryStatisticsExternalizer() - Constructor for class org.infinispan.marshall.exts.DoubleSummaryStatisticsExternalizer
 
downgradeLock(Object) - Method in class org.infinispan.util.concurrent.locks.StripedLock
 
doWriteObject(ObjectOutput, DefaultConsistentHash) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash.Externalizer
 
doWriteObject(ObjectOutput, ReplicatedConsistentHash) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash.Externalizer
 
doWriteObject(ObjectOutput, ScatteredConsistentHash) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash.Externalizer
 
doWriteObject(ObjectOutput, JGroupsAddress) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress.Externalizer
 
doWriteObject(ObjectOutput, JGroupsTopologyAwareAddress) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress.Externalizer
 
doWriteObject(ObjectOutput, CacheTopology) - Method in class org.infinispan.topology.CacheTopology.Externalizer
 
doWriteObject(ObjectOutput, ManagerStatusResponse) - Method in class org.infinispan.topology.ManagerStatusResponse.Externalizer
 
drainCompletionQueue() - Method in class org.infinispan.executors.SemaphoreCompletionService
 
dropEvents() - Method in interface org.infinispan.notifications.cachelistener.cluster.ClusterEventManager
Drops and ignores all previously added events on this thread.
dropEvents() - Method in class org.infinispan.notifications.cachelistener.cluster.impl.BatchingClusterEventManagerImpl
 
dropEvents() - Method in class org.infinispan.notifications.cachelistener.cluster.impl.ClusterEventManagerStub
 
DUMMY_INVOCATION_ID - Static variable in class org.infinispan.commands.CommandInvocationId
 
DummyBaseTransactionManager - Class in org.infinispan.transaction.tm
DummyBaseTransactionManager() - Constructor for class org.infinispan.transaction.tm.DummyBaseTransactionManager
Deprecated.
 
DummyNoXaXid - Class in org.infinispan.transaction.tm
Deprecated.
it will be removed and EmbeddedXid would be used instead.
DummyNoXaXid() - Constructor for class org.infinispan.transaction.tm.DummyNoXaXid
Deprecated.
 
DummyTransaction - Class in org.infinispan.transaction.tm
Deprecated.
DummyTransaction(DummyBaseTransactionManager) - Constructor for class org.infinispan.transaction.tm.DummyTransaction
Deprecated.
 
DummyTransactionManager - Class in org.infinispan.transaction.tm
DummyTransactionManager() - Constructor for class org.infinispan.transaction.tm.DummyTransactionManager
Deprecated.
 
DummyTransactionManagerLookup - Class in org.infinispan.transaction.lookup
DummyTransactionManagerLookup() - Constructor for class org.infinispan.transaction.lookup.DummyTransactionManagerLookup
Deprecated.
 
DummyUserTransaction - Class in org.infinispan.transaction.tm
Deprecated.
DummyUserTransaction(DummyTransactionManager) - Constructor for class org.infinispan.transaction.tm.DummyUserTransaction
Deprecated.
 
DummyXid - Class in org.infinispan.transaction.tm
Deprecated.
DummyXid(UUID) - Constructor for class org.infinispan.transaction.tm.DummyXid
Deprecated.
 
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.
duplicateCacheName(String) - Method in class org.infinispan.util.logging.Log_$logger
 
duplicateCacheName(String) - Method in interface org.infinispan.util.logging.Log
 
duplicateCacheName$str() - Method in class org.infinispan.util.logging.Log_$logger
 
duplicateExternalizerIdFound(int, Class<?>, String, int) - Method in class org.infinispan.util.logging.Log_$logger
 
duplicateExternalizerIdFound(int, Class<?>, String, int) - Method in interface org.infinispan.util.logging.Log
 
duplicateExternalizerIdFound(int, String) - Method in class org.infinispan.util.logging.Log_$logger
 
duplicateExternalizerIdFound(int, String) - Method in interface org.infinispan.util.logging.Log
 
duplicateExternalizerIdFound2$str() - Method in class org.infinispan.util.logging.Log_$logger
 
duplicateExternalizerIdFound4$str() - Method in class org.infinispan.util.logging.Log_$logger
 
duplicateIdEncoder(short) - Method in class org.infinispan.util.logging.Log_$logger
 
duplicateIdEncoder(short) - Method in interface org.infinispan.util.logging.Log
 
duplicateIdEncoder$str() - Method in class org.infinispan.util.logging.Log_$logger
 
duplicateIdWrapper(byte) - Method in class org.infinispan.util.logging.Log_$logger
 
duplicateIdWrapper(byte) - Method in interface org.infinispan.util.logging.Log
 
duplicateIdWrapper$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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.
DYNAMIC - org.infinispan.jmx.annotations.MeasurementType
 

E

Element - Enum in org.infinispan.configuration.parsing
An enumeration of all the recognized XML element local names, by name.
elementDeprecatedUseOther(Element, Element) - Method in class org.infinispan.util.logging.Log_$logger
 
elementDeprecatedUseOther(Element, Element) - Method in interface org.infinispan.util.logging.Log
 
elementDeprecatedUseOther$str() - Method in class org.infinispan.util.logging.Log_$logger
 
elements() - Method in class org.infinispan.security.CachePermissionCollection
 
EmbeddedBaseTransactionManager - Class in org.infinispan.transaction.tm
A simple TransactionManager implementation.
EmbeddedBaseTransactionManager() - Constructor for class org.infinispan.transaction.tm.EmbeddedBaseTransactionManager
 
embeddedCacheManager - Variable in class org.infinispan.interceptors.base.BaseCustomInterceptor
Deprecated.
 
embeddedCacheManager - Variable in class org.infinispan.interceptors.BaseCustomAsyncInterceptor
 
EmbeddedCacheManager - Interface in org.infinispan.manager
EmbeddedCacheManager is an CacheManager that runs in the same JVM as the client.
EmbeddedCacheManagerAdmin - Interface in org.infinispan.manager
Cache manager operations which affect the whole cluster.
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(String) - Constructor for exception org.infinispan.manager.EmbeddedCacheManagerStartupException
 
EmbeddedCacheManagerStartupException(String, Throwable) - Constructor for exception org.infinispan.manager.EmbeddedCacheManagerStartupException
 
EmbeddedCacheManagerStartupException(Throwable) - Constructor for exception org.infinispan.manager.EmbeddedCacheManagerStartupException
 
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
 
EmbeddedTimeService - Class in org.infinispan.util
The default implementation of TimeService.
EmbeddedTimeService() - Constructor for class org.infinispan.util.EmbeddedTimeService
 
EmbeddedTransaction - Class in org.infinispan.transaction.tm
EmbeddedTransaction(EmbeddedBaseTransactionManager) - Constructor for class org.infinispan.transaction.tm.EmbeddedTransaction
 
EmbeddedTransactionManager - Class in org.infinispan.transaction.tm
Simple transaction manager implementation that maintains transaction state in memory only.
EmbeddedTransactionManagerLookup - Class in org.infinispan.transaction.lookup
Returns an instance of EmbeddedTransactionManager.
EmbeddedTransactionManagerLookup() - Constructor for class org.infinispan.transaction.lookup.EmbeddedTransactionManagerLookup
 
EmbeddedUserTransaction - Class in org.infinispan.transaction.tm
A UserTransaction implementation that uses EmbeddedTransactionManager.
EmbeddedXid - Class in org.infinispan.transaction.tm
Implementation of Xid used by EmbeddedTransactionManager.
EmbeddedXid(UUID) - Constructor for class org.infinispan.transaction.tm.EmbeddedXid
 
empty() - Static method in class org.infinispan.marshall.core.MarshalledEntryImpl
Returns the value that should be used as an empty MarshalledEntry.
EMPTY - Static variable in class org.infinispan.metadata.EmbeddedMetadata
 
EMPTY - Static variable in class org.infinispan.remoting.responses.UnsuccessfulResponse
 
EMPTY_ARRAY - Static variable in interface org.infinispan.remoting.transport.Address
 
EMPTY_ARRAY - Static variable in class org.infinispan.util.concurrent.CompletableFutures
 
EMPTY_INJECT_METHODS - Static variable in class org.infinispan.factories.components.ComponentMetadata
 
EMPTY_PRIORITIZED_METHODS - Static variable in class org.infinispan.factories.components.ComponentMetadata
 
EmptyAsyncInterceptorChain - Class in org.infinispan.interceptors
 
EmptyAsyncInterceptorChain() - Constructor for class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
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
 
emptyString() - Static method in class org.infinispan.util.ByteString
 
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.AuthorizationConfigurationBuilder
 
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
Deprecated.
Since 9.0, deadlock detection is always disabled.
enable() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
enable() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
 
enable() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
Enable statistics gathering and reporting
enable() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
enable() - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
Enable recovery for this cache
enable() - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
Deprecated.
Enable the singleton store cache store
enable() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
Deprecated.
Enables storing both keys and values as binary.
enable() - Method in class org.infinispan.configuration.cache.VersioningConfigurationBuilder
Deprecated.
 
enable() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
 
enable() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
 
enable() - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
 
enable(boolean) - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
 
enabled - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
enabled() - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
If true, all modifications to this cache store happen asynchronously, on a separate thread.
enabled() - Method in class org.infinispan.configuration.cache.AuthorizationConfiguration
 
enabled() - Method in class org.infinispan.configuration.cache.BackupConfiguration
 
enabled() - Method in class org.infinispan.configuration.cache.CompatibilityModeConfiguration
 
enabled() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfiguration
Deprecated.
Since 9.0, always returns false.
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() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
Deprecated.
enabled() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfiguration
 
enabled() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfiguration
 
enabled() - Method in class org.infinispan.configuration.cache.L1Configuration
 
enabled() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
Deprecated.
enabled() - Method in class org.infinispan.configuration.cache.RecoveryConfiguration
Determines if recovery is enabled for the cache.
enabled() - Method in class org.infinispan.configuration.cache.SingletonStoreConfiguration
Deprecated.
If true, the singleton store cache store is enabled.
enabled() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
Deprecated.
enabled() - Method in class org.infinispan.configuration.cache.TakeOfflineConfiguration
 
enabled() - Method in class org.infinispan.configuration.cache.VersioningConfiguration
Deprecated.
 
enabled() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
enabled() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
enabled() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
 
enabled() - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
 
enabled(boolean) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
enabled(boolean) - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
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(boolean) - Method in class org.infinispan.configuration.cache.CompatibilityModeConfigurationBuilder
Sets whether compatibility mode is enabled or disabled.
enabled(boolean) - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
Deprecated.
Since 9.0, deadlock detection is always disabled.
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(boolean) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
enabled(boolean) - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
Enable or disable statistics gathering and reporting
enabled(boolean) - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
enabled(boolean) - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
Deprecated.
enabled(boolean) - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
Enable recovery for this cache
enabled(boolean) - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
Deprecated.
If true, the singleton store cache store is enabled.
enabled(boolean) - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
Deprecated.
enabled(boolean) - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
Deprecated.
Sets whether this feature is enabled or disabled.
enabled(boolean) - Method in class org.infinispan.configuration.cache.VersioningConfigurationBuilder
Deprecated.
 
enabled(boolean) - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
 
enabled(boolean) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
 
enabled(boolean) - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
Enables or disables the storage of global state.
ENABLED - org.infinispan.configuration.parsing.Attribute
 
ENABLED - Static variable in class org.infinispan.configuration.cache.AsyncStoreConfiguration
 
ENABLED - Static variable in class org.infinispan.configuration.cache.AuthorizationConfiguration
 
ENABLED - Static variable in class org.infinispan.configuration.cache.BackupConfiguration
 
ENABLED - Static variable in class org.infinispan.configuration.cache.CompatibilityModeConfiguration
 
ENABLED - Static variable in class org.infinispan.configuration.cache.DeadlockDetectionConfiguration
Deprecated.
ENABLED - Static variable in class org.infinispan.configuration.cache.GroupsConfiguration
 
ENABLED - Static variable in class org.infinispan.configuration.cache.InvocationBatchingConfiguration
 
ENABLED - Static variable in class org.infinispan.configuration.cache.JMXStatisticsConfiguration
 
ENABLED - Static variable in class org.infinispan.configuration.cache.L1Configuration
 
ENABLED - Static variable in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
Deprecated.
ENABLED - Static variable in class org.infinispan.configuration.cache.RecoveryConfiguration
 
ENABLED - Static variable in class org.infinispan.configuration.cache.SingletonStoreConfiguration
Deprecated.
 
ENABLED - Static variable in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
Deprecated.
 
ENABLED - Static variable in class org.infinispan.configuration.cache.VersioningConfiguration
Deprecated.
 
ENABLED - Static variable in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
ENABLED - Static variable in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
ENABLED - Static variable in class org.infinispan.configuration.global.GlobalStateConfiguration
 
enabledBackups() - Method in class org.infinispan.configuration.cache.SitesConfiguration
Returns the list of BackupConfiguration that have BackupConfiguration.enabled() == true.
enableReaper() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
Enable the background reaper to test entries for expiration.
ENCODER - org.infinispan.configuration.parsing.Attribute
 
EncoderCache<K,​V> - Class in org.infinispan.cache.impl
Cache decoration that makes use of the Encoder and Wrapper to convert between storage value and read/write value.
EncoderCache(AdvancedCache<K, V>, DataConversion, DataConversion) - Constructor for class org.infinispan.cache.impl.EncoderCache
 
encoderClassNotFound(Class<?>) - Method in class org.infinispan.util.logging.Log_$logger
 
encoderClassNotFound(Class<?>) - Method in interface org.infinispan.util.logging.Log
 
encoderClassNotFound$str() - Method in class org.infinispan.util.logging.Log_$logger
 
EncoderEntryMapper<K,​V,​T extends Map.Entry<K,​V>> - Class in org.infinispan.cache.impl
Function that uses an encoder to converter entries from the configured storage format to the requested format.
EncoderEntryMapper.Externalizer - Class in org.infinispan.cache.impl
 
encoderIdNotFound(short) - Method in class org.infinispan.util.logging.Log_$logger
 
encoderIdNotFound(short) - Method in interface org.infinispan.util.logging.Log
 
encoderIdNotFound$str() - Method in class org.infinispan.util.logging.Log_$logger
 
EncoderKeyMapper<K> - Class in org.infinispan.cache.impl
Function that uses a keyEncoder to converter keys from the configured storage format to the requested format.
EncoderKeyMapper(DataConversion) - Constructor for class org.infinispan.cache.impl.EncoderKeyMapper
 
EncoderKeyMapper.Externalizer - Class in org.infinispan.cache.impl
 
EncoderRegistry - Interface in org.infinispan.marshall.core
Manages existent Encoder, Wrapper and Transcoder instances.
EncoderRegistryFactory - Class in org.infinispan.factories
Factory for EncoderRegistryImpl objects.
EncoderRegistryFactory() - Constructor for class org.infinispan.factories.EncoderRegistryFactory
 
EncoderRegistryImpl - Class in org.infinispan.marshall.core
 
EncoderRegistryImpl() - Constructor for class org.infinispan.marshall.core.EncoderRegistryImpl
 
EncoderValueMapper<V> - Class in org.infinispan.cache.impl
Function that uses a valueEncoder to converter values from the configured storage format to the requested format.
EncoderValueMapper(DataConversion) - Constructor for class org.infinispan.cache.impl.EncoderValueMapper
 
EncoderValueMapper.Externalizer - Class in org.infinispan.cache.impl
 
encoding() - Method in class org.infinispan.configuration.cache.Configuration
 
encoding() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
encoding() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
ENCODING - org.infinispan.configuration.parsing.Element
 
EncodingConfiguration - Class in org.infinispan.configuration.cache
Controls encoding configuration for keys and values in the cache.
EncodingConfiguration(ContentTypeConfiguration, ContentTypeConfiguration) - Constructor for class org.infinispan.configuration.cache.EncodingConfiguration
 
EncodingConfigurationBuilder - Class in org.infinispan.configuration.cache
 
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.batch.BatchContainer
 
endBatch(boolean) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
endBatch(boolean) - Method in class org.infinispan.cache.impl.CacheImpl
 
endBatch(boolean) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
endBatch(boolean) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
endBatch(boolean, boolean) - Method in class org.infinispan.batch.BatchContainer
 
EndIterator - Class in org.infinispan.stream.impl
Singleton object with no state that is used to signal that an iterator has reached the end.
EndIterator.EndIteratorExternalizer - Class in org.infinispan.stream.impl
 
EndIteratorExternalizer() - Constructor for class org.infinispan.stream.impl.EndIterator.EndIteratorExternalizer
 
endStateTransfer(String) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateConsumer
It notifies the end of state transfer from other site.
endStateTransfer(String) - Method in class org.infinispan.xsite.statetransfer.XSiteStateConsumerImpl
 
enlist(Transaction, LocalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
 
enlist(Transaction, LocalTransaction) - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
enlist(TxInvocationContext) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
enlistClientTransaction(Transaction, LocalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
 
enlistClientTransaction(Transaction, LocalTransaction) - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
enlistResource(XAResource) - Method in class org.infinispan.transaction.tm.DummyTransaction
Deprecated.
Enlist an XA resource with this transaction.
ensureOrder(TotalOrderRemoteTransactionState, Collection<?>) - Method in class org.infinispan.transaction.totalorder.TotalOrderManager
It ensures the validation order for the transaction corresponding to the prepare command.
enteringDegradedModeGracefulLeaver(Address) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
enteringDegradedModeGracefulLeaver(Address) - Method in interface org.infinispan.util.logging.events.Messages
 
enteringDegradedModeGracefulLeaver$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
enteringDegradedModeLostData(Collection<Address>) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
enteringDegradedModeLostData(Collection<Address>) - Method in interface org.infinispan.util.logging.events.Messages
 
enteringDegradedModeLostData$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
enteringDegradedModeMinorityPartition(Collection<Address>, Collection<Address>, Collection<Address>) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
enteringDegradedModeMinorityPartition(Collection<Address>, Collection<Address>, Collection<Address>) - Method in interface org.infinispan.util.logging.events.Messages
 
enteringDegradedModeMinorityPartition$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
enterSynchronizationAsync(CompletableFuture<Void>) - Method in class org.infinispan.transaction.impl.RemoteTransaction
 
entries - Variable in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
entries() - Method in interface org.infinispan.functional.FunctionalMap.ReadOnlyMap
Provides a Traversable that allows clients to navigate all cached entries.
entries() - Method in class org.infinispan.functional.impl.ReadOnlyMapImpl
 
entriesMigrated(long, String, String) - Method in class org.infinispan.util.logging.Log_$logger
 
entriesMigrated(long, String, String) - Method in interface org.infinispan.util.logging.Log
 
entriesMigrated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
entryCommitted(CacheNotifier, FunctionalNotifier, boolean, boolean, boolean, CacheEntry, InvocationContext, FlagAffectedCommand, Object, Metadata) - Static method in class org.infinispan.notifications.cachelistener.NotifyHelper
 
entryCreated(long) - Method in interface org.infinispan.container.offheap.OffHeapConcurrentMap.EntryListener
Invoked when an entry is about to be created.
entryExpired(CacheEntryExpiredEvent) - Method in class org.infinispan.interceptors.impl.TransactionalExceptionEvictionInterceptor
 
entryExpiredInMemory(InternalCacheEntry<K, V>, long, boolean) - Method in class org.infinispan.expiration.impl.ClusterExpirationManager
 
entryExpiredInMemory(InternalCacheEntry<K, V>, long, boolean) - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
entryExpiredInMemory(InternalCacheEntry<K, V>, long, boolean) - Method in interface org.infinispan.expiration.impl.InternalExpirationManager
This should be invoked passing in an entry that is now expired.
entryExpiredInMemoryFromIteration(InternalCacheEntry<K, V>, long) - Method in class org.infinispan.expiration.impl.ClusterExpirationManager
 
entryExpiredInMemoryFromIteration(InternalCacheEntry<K, V>, long) - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
entryExpiredInMemoryFromIteration(InternalCacheEntry<K, V>, long) - Method in interface org.infinispan.expiration.impl.InternalExpirationManager
This method is very similar to InternalExpirationManager.entryExpiredInMemory(InternalCacheEntry, long, boolean) except that it does the bare minimum when an entry expired to guarantee if the entry is valid or not.
entryFactory - Variable in class org.infinispan.container.impl.AbstractInternalDataContainer
 
entryFactory - Variable in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
entryFactory - Variable in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
entryFactory - Variable in class org.infinispan.interceptors.impl.ClusteringInterceptor
 
entryFactory - Variable in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
entryFactory - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
entryFactory - Variable in class org.infinispan.statetransfer.StateProviderImpl
 
EntryFactory - Interface in org.infinispan.container.impl
A factory for constructing MVCCEntry instances for use in the InvocationContext.
EntryFactoryImpl - Class in org.infinispan.container.impl
EntryFactory implementation to be used for optimistic locking scheme.
EntryFactoryImpl() - Constructor for class org.infinispan.container.impl.EntryFactoryImpl
 
EntryIterator(Iterator<InternalCacheEntry<K, V>>) - Constructor for class org.infinispan.container.impl.AbstractInternalDataContainer.EntryIterator
 
EntryLookup - Interface in org.infinispan.context
Interface that can look up MVCC wrapped entries.
EntryMergePolicy<K,​V> - Interface in org.infinispan.conflict
 
EntryMergePolicyFactory - Interface in org.infinispan.conflict
 
EntryMergePolicyFactoryRegistry - Class in org.infinispan.conflict
A registry for EntryMergePolicyFactory implementations, which allows EntryMergePolicy implementations to be eagerly/lazily loaded across multiple contexts.
EntryMergePolicyFactoryRegistry() - Constructor for class org.infinispan.conflict.EntryMergePolicyFactoryRegistry
 
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.
entryRemoved(long) - Method in interface org.infinispan.container.offheap.OffHeapConcurrentMap.EntryListener
Invoked when an entry is about to be removed.
entryReplaced(long, long) - Method in interface org.infinispan.container.offheap.OffHeapConcurrentMap.EntryListener
Invoked when an entry is about to be replaced with a new one.
entryRetrieved(long) - Method in interface org.infinispan.container.offheap.OffHeapConcurrentMap.EntryListener
Invoked when an entry is successfully retrieved.
entrySet - Variable in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingEntrySet
 
entrySet() - Method in class org.infinispan.atomic.impl.AtomicMapProxyImpl
 
entrySet() - Method in class org.infinispan.atomic.impl.FineGrainedAtomicMapProxyImpl
 
entrySet() - Method in interface org.infinispan.Cache
Returns a set view of the mappings contained in this cache and cache loader across the entire cluster.
entrySet() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
entrySet() - Method in class org.infinispan.cache.impl.CacheImpl
 
entrySet() - Method in class org.infinispan.cache.impl.DecoratedCache
 
entrySet() - Method in class org.infinispan.cache.impl.EncoderCache
 
entrySet() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
entrySet() - Method in interface org.infinispan.container.DataContainer
Deprecated.
Please use iterator method if bulk operations are required.
entrySet() - Method in class org.infinispan.container.impl.AbstractDelegatingDataContainer
 
entrySet() - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
entrySet() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
entrySet() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
 
entrySet() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
EntrySet() - Constructor for class org.infinispan.cache.impl.SimpleCacheImpl.EntrySet
 
EntrySetBase() - Constructor for class org.infinispan.cache.impl.SimpleCacheImpl.EntrySetBase
 
EntrySetCommand<K,​V> - Class in org.infinispan.commands.read
Command implementation for Map.entrySet() functionality.
EntrySetCommand(Cache<K, V>, InternalDataContainer<K, V>, KeyPartitioner, long) - Constructor for class org.infinispan.commands.read.EntrySetCommand
 
EntryStreamSupplier<K,​V> - Class in org.infinispan.stream.impl.local
Stream supplier that is to be used when the underlying stream is composed by CacheEntry instances.
EntryStreamSupplier(Cache<K, V>, ToIntFunction<Object>, Supplier<Stream<CacheEntry<K, V>>>) - Constructor for class org.infinispan.stream.impl.local.EntryStreamSupplier
 
entryToKeyFunction() - Static method in class org.infinispan.stream.StreamMarshalling
Provides a function that returns the key of the entry when invoked.
entryToValueFunction() - Static method in class org.infinispan.stream.StreamMarshalling
Provides a function that returns the value of the entry when invoked.
EntryVersion - Interface in org.infinispan.container.versioning
A version is used to compare entries against one another.
EntryVersionParamExternalizer() - Constructor for class org.infinispan.marshall.exts.MetaParamExternalizers.EntryVersionParamExternalizer
 
EntryVersionsMap - Class in org.infinispan.container.versioning
 
EntryVersionsMap() - Constructor for class org.infinispan.container.versioning.EntryVersionsMap
 
EntryVersionsMap(int) - Constructor for class org.infinispan.container.versioning.EntryVersionsMap
 
EntryView - Class in org.infinispan.functional
Entry views expose cached entry information to the user.
EntryView.ReadEntryView<K,​V> - Interface in org.infinispan.functional
Expose read-only information about a cache entry potentially associated with a key in the functional map.
EntryView.ReadWriteEntryView<K,​V> - Interface in org.infinispan.functional
Expose information about a cache entry potentially associated with a key in the functional map, and allows that cache entry to be written with new value and/or new metadata parameters.
EntryView.WriteEntryView<K,​V> - Interface in org.infinispan.functional
Expose a write-only facade for a cache entry potentially associated with a key in the functional map which allows the cache entry to be written with new value and/or new metadata parameters.
EntryViews - Class in org.infinispan.functional.impl
Entry views implementation class holder.
EntryViews.AccessLoggingReadWriteView<K,​V> - Interface in org.infinispan.functional.impl
 
EntryViews.NoValueReadOnlyViewExternalizer - Class in org.infinispan.functional.impl
 
EntryViews.ReadOnlySnapshotViewExternalizer - Class in org.infinispan.functional.impl
 
EntryViews.ReadWriteSnapshotViewExternalizer - Class in org.infinispan.functional.impl
 
EntryWrapper<K,​V> - Class in org.infinispan.util
Wrapper for CacheEntry(s) that can be used to update the cache when it's value is set.
EntryWrapper(Cache<K, V>, CacheEntry<K, V>) - Constructor for class org.infinispan.util.EntryWrapper
Creates a new entry wrapper given the cache and entry.
EntryWrappingInterceptor - Class in org.infinispan.interceptors.impl
Interceptor in charge with wrapping entries and add them in caller's context.
EntryWrappingInterceptor() - Constructor for class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
EnumSetExternalizer - Class in org.infinispan.marshall.exts
EnumSet externalizer.
EnumSetExternalizer() - Constructor for class org.infinispan.marshall.exts.EnumSetExternalizer
 
EQUAL - org.infinispan.container.versioning.InequalVersionComparisonResult
Denotes that the two versions being compared are equal.
equalityPredicate(Object) - Static method in class org.infinispan.stream.StreamMarshalling
Provides a predicate that returns true when the object is equal.
equals(Object) - Method in class org.infinispan.atomic.DeltaCompositeKey
Deprecated.
 
equals(Object) - Method in class org.infinispan.commands.CancelCommand
 
equals(Object) - Method in class org.infinispan.commands.CommandInvocationId
 
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.remote.ClusteredGetAllCommand
 
equals(Object) - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
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.ClearCommand
 
equals(Object) - Method in class org.infinispan.commands.write.ComputeCommand
 
equals(Object) - Method in class org.infinispan.commands.write.ComputeIfAbsentCommand
 
equals(Object) - Method in class org.infinispan.commands.write.InvalidateCommand
 
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.RemoveExpiredCommand
 
equals(Object) - Method in class org.infinispan.commands.write.ReplaceCommand
 
equals(Object) - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.AuthorizationConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.BackupConfiguration
 
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.ContentTypeConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfiguration
Deprecated.
 
equals(Object) - Method in class org.infinispan.configuration.cache.EncodingConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.EvictionConfiguration
Deprecated.
 
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.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.MemoryConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
 
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.SecurityConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.SingletonStoreConfiguration
Deprecated.
 
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
Deprecated.
 
equals(Object) - Method in class org.infinispan.configuration.cache.SyncConfiguration
Deprecated.
 
equals(Object) - Method in class org.infinispan.configuration.cache.TakeOfflineConfiguration
 
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
Deprecated.
 
equals(Object) - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
equals(Object) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.global.SerializationConfiguration
 
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.ThreadPoolConfigurationBuilder
 
equals(Object) - Method in class org.infinispan.configuration.global.TransportConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.internal.PrivateGlobalConfiguration
 
equals(Object) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
equals(Object) - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
equals(Object) - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
equals(Object) - Method in class org.infinispan.container.entries.MortalCacheValue
 
equals(Object) - Method in class org.infinispan.container.entries.TransientCacheValue
 
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.container.versioning.SimpleClusteredVersion
 
equals(Object) - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
equals(Object) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
 
equals(Object) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
 
equals(Object) - Method in class org.infinispan.distribution.ch.impl.HashFunctionPartitioner
 
equals(Object) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
equals(Object) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory
 
equals(Object) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
 
equals(Object) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory
 
equals(Object) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory
 
equals(Object) - Method in class org.infinispan.distribution.group.impl.PartitionerConsistentHash
 
equals(Object) - Method in class org.infinispan.encoding.DataConversion
 
equals(Object) - Method in class org.infinispan.functional.MetaParam.MetaEntryVersion
 
equals(Object) - Method in class org.infinispan.functional.MetaParam.MetaLoadedFromPersistence
 
equals(Object) - Method in class org.infinispan.functional.MetaParam.MetaLong
 
equals(Object) - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
 
equals(Object) - Method in class org.infinispan.globalstate.ScopedState
 
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.marshall.core.MarshalledEntryImpl
 
equals(Object) - Method in class org.infinispan.metadata.EmbeddedMetadata
 
equals(Object) - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
 
equals(Object) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
equals(Object) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
equals(Object) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.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.remoting.LocalInvocation
 
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
Deprecated.
 
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.security.CachePermission
 
equals(Object) - Method in class org.infinispan.security.impl.CachePrincipalPair
 
equals(Object) - Method in class org.infinispan.security.impl.CacheRoleImpl
 
equals(Object) - Method in class org.infinispan.security.impl.CommonNameRoleMapper
 
equals(Object) - Method in class org.infinispan.security.impl.IdentityRoleMapper
 
equals(Object) - Method in class org.infinispan.security.impl.LoggingAuditLogger
 
equals(Object) - Method in class org.infinispan.security.impl.NullAuditLogger
 
equals(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
equals(Object) - Method in class org.infinispan.topology.CacheJoinInfo
 
equals(Object) - Method in class org.infinispan.topology.CacheTopology
 
equals(Object) - Method in class org.infinispan.topology.PersistentUUID
 
equals(Object) - Method in class org.infinispan.transaction.impl.LocalTransaction
 
equals(Object) - Method in class org.infinispan.transaction.impl.RemoteTransaction
 
equals(Object) - Method in class org.infinispan.transaction.impl.TotalOrderRemoteTransactionState
 
equals(Object) - Method in class org.infinispan.transaction.synchronization.SynchronizationAdapter
 
equals(Object) - Method in class org.infinispan.transaction.tm.DummyNoXaXid
Deprecated.
 
equals(Object) - Method in class org.infinispan.transaction.tm.DummyTransaction
Deprecated.
 
equals(Object) - Method in class org.infinispan.transaction.tm.DummyXid
Deprecated.
 
equals(Object) - Method in class org.infinispan.transaction.totalorder.TotalOrderLatchImpl
 
equals(Object) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
Deprecated.
 
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
Deprecated.
 
equals(Object) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
equals(Object) - Method in class org.infinispan.util.ByteString
 
equals(Object) - Method in class org.infinispan.util.KeyValuePair
 
equals(Object) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferCollector
 
equalsKey(long, WrappedBytes) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
Returns whether the given key as bytes is the same key as the key stored in the entry for the given address.
equalsKey(long, WrappedBytes) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
Assumes the address points to the entry excluding the pointer reference at the beginning
error(EventLogCategory, String) - Method in interface org.infinispan.util.logging.events.EventLogger
Logs a message to the event log using the EventLogLevel.ERROR severity
ERROR - org.infinispan.security.AuditResponse
 
ERROR - org.infinispan.util.logging.events.EventLogLevel
 
errorAsyncStoreNotStopped() - Method in class org.infinispan.util.logging.Log_$logger
 
errorAsyncStoreNotStopped() - Method in interface org.infinispan.util.logging.Log
 
errorAsyncStoreNotStopped$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorChangingSingletonStoreStatus(SingletonCacheWriter.PushStateException) - Method in class org.infinispan.util.logging.Log_$logger
 
errorChangingSingletonStoreStatus(SingletonCacheWriter.PushStateException) - Method in interface org.infinispan.util.logging.Log
 
errorChangingSingletonStoreStatus$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorCommittingTx(XAException) - Method in class org.infinispan.util.logging.Log_$logger
 
errorCommittingTx(XAException) - Method in interface org.infinispan.util.logging.Log
 
errorCommittingTx$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorCreatingChannelFromConfigFile(String, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
errorCreatingChannelFromConfigFile(String, Exception) - Method in interface org.infinispan.util.logging.Log
 
errorCreatingChannelFromConfigFile$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorCreatingChannelFromConfigString(String, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
errorCreatingChannelFromConfigString(String, Exception) - Method in interface org.infinispan.util.logging.Log
 
errorCreatingChannelFromConfigString$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorCreatingChannelFromXML(String, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
errorCreatingChannelFromXML(String, Exception) - Method in interface org.infinispan.util.logging.Log
 
errorCreatingChannelFromXML$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorDeserializing(String) - Method in class org.infinispan.util.logging.Log_$logger
 
errorDeserializing(String) - Method in interface org.infinispan.util.logging.Log
 
errorDeserializing$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorDoingRemoteCall(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
errorDoingRemoteCall(Exception) - Method in interface org.infinispan.util.logging.Log
 
errorDoingRemoteCall$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorEnlistingResource(XAException) - Method in class org.infinispan.util.logging.Log_$logger
 
errorEnlistingResource(XAException) - Method in interface org.infinispan.util.logging.Log
 
errorEnlistingResource$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorExecutingParallelStoreTask(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
errorExecutingParallelStoreTask(Throwable) - Method in interface org.infinispan.util.logging.Log
 
errorExecutingParallelStoreTask$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorInstantiatingJGroupsChannelLookup(String, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
errorInstantiatingJGroupsChannelLookup(String, Exception) - Method in interface org.infinispan.util.logging.Log
 
errorInstantiatingJGroupsChannelLookup$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorPersistingGlobalConfiguration(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
errorPersistingGlobalConfiguration(Throwable) - Method in interface org.infinispan.util.logging.Log
 
errorPersistingGlobalConfiguration$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorProcessing1pcPrepareCommand(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
errorProcessing1pcPrepareCommand(Throwable) - Method in interface org.infinispan.util.logging.Log
 
errorProcessing1pcPrepareCommand$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorProcessing2pcCommitCommand(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
errorProcessing2pcCommitCommand(Throwable) - Method in interface org.infinispan.util.logging.Log
 
errorProcessing2pcCommitCommand$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorProcessingPrepare(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
errorProcessingPrepare(Throwable) - Method in interface org.infinispan.util.logging.Log
 
errorProcessingPrepare$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorProcessingRequest(long, Address) - Method in class org.infinispan.util.logging.Log_$logger
 
errorProcessingRequest(long, Address) - Method in interface org.infinispan.util.logging.Log
 
errorProcessingRequest$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorProcessingResponse(long, Address) - Method in class org.infinispan.util.logging.Log_$logger
 
errorProcessingResponse(long, Address) - Method in interface org.infinispan.util.logging.Log
 
errorProcessingResponse$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorReadingFileStore(String, long) - Method in class org.infinispan.util.logging.Log_$logger
 
errorReadingFileStore(String, long) - Method in interface org.infinispan.util.logging.Log
 
errorReadingFileStore$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorReadingProperties(IOException) - Method in class org.infinispan.util.logging.Log_$logger
 
errorReadingProperties(IOException) - Method in interface org.infinispan.util.logging.Log
 
errorReadingProperties$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorReadingRebalancingStatus(Address, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
errorReadingRebalancingStatus(Address, Exception) - Method in interface org.infinispan.util.logging.Log
 
errorReadingRebalancingStatus$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorRollingBack(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
errorRollingBack(Throwable) - Method in interface org.infinispan.util.logging.Log
 
errorRollingBack$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorSendingResponse(long, Address, ReplicableCommand) - Method in class org.infinispan.util.logging.Log_$logger
 
errorSendingResponse(long, Address, ReplicableCommand) - Method in interface org.infinispan.util.logging.Log
 
errorSendingResponse$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorTranscoding(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
errorTranscoding(Throwable) - Method in interface org.infinispan.util.logging.Log
 
errorTranscoding$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorTranscodingContent(Throwable, Object) - Method in class org.infinispan.util.logging.Log_$logger
 
errorTranscodingContent(Throwable, Object) - Method in interface org.infinispan.util.logging.Log
 
errorTranscodingContent$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorUpdatingMembersList(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
errorUpdatingMembersList(Throwable) - Method in interface org.infinispan.util.logging.Log
 
errorUpdatingMembersList$str() - Method in class org.infinispan.util.logging.Log_$logger
 
errorWritingValueForAttribute(String, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
errorWritingValueForAttribute(String, Exception) - Method in interface org.infinispan.util.logging.Log
 
errorWritingValueForAttribute$str() - Method in class org.infinispan.util.logging.Log_$logger
 
estimateSize() - Method in class org.infinispan.stream.impl.spliterators.IteratorAsSpliterator
 
estimateSizeOverhead(long) - Static method in class org.infinispan.container.offheap.UnpooledOffHeapMemoryAllocator
Tries to estimate overhead of the allocation by first adding 8 to account for underlying allocator housekeeping and then rounds up to nearest power of 16 to account for 16 byte alignment.
eval(K, Consumer<EntryView.WriteEntryView<K, V>>) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Evaluate a write-only Consumer operation with a EntryView.WriteEntryView of the value associated with the key, and return a CompletableFuture which will be completed with the object returned by the operation.
eval(K, Consumer<EntryView.WriteEntryView<K, V>>) - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
eval(K, Function<EntryView.ReadEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadOnlyMap
Evaluate a read-only function on the value associated with the key and return a CompletableFuture with the return type of the function.
eval(K, Function<EntryView.ReadEntryView<K, V>, R>) - Method in class org.infinispan.functional.impl.ReadOnlyMapImpl
 
eval(K, Function<EntryView.ReadWriteEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
Evaluate a read-write function on the value and metadata associated with the key and return a CompletableFuture with the return type of the function.
eval(K, Function<EntryView.ReadWriteEntryView<K, V>, R>) - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
 
eval(K, SerializableConsumer<EntryView.WriteEntryView<K, V>>) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Same as FunctionalMap.WriteOnlyMap.eval(Object, Consumer) except that the function must also implement Serializable
eval(K, SerializableFunction<EntryView.ReadEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadOnlyMap
Same as FunctionalMap.ReadOnlyMap.eval(Object, Function) except that the function must also implement Serializable
eval(K, SerializableFunction<EntryView.ReadWriteEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
Same as FunctionalMap.ReadWriteMap.eval(Object, Function) except that the function must also implement Serializable
eval(K, T, BiConsumer<T, EntryView.WriteEntryView<K, V>>) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Evaluate a write-only BiConsumer operation, with an argument passed in and a EntryView.WriteEntryView of the value associated with the key, and return a CompletableFuture which will be completed when the operation completes.
eval(K, T, BiConsumer<T, EntryView.WriteEntryView<K, V>>) - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
eval(K, T, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
Evaluate a read-write function, with an argument passed in and a EntryView.WriteEntryView of the value associated with the key, and return a CompletableFuture which will be completed with the returned value by the function.
eval(K, T, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>) - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
 
eval(K, T, SerializableBiConsumer<T, EntryView.WriteEntryView<K, V>>) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Same as FunctionalMap.WriteOnlyMap.eval(Object, Object, BiConsumer) except that the function must also implement Serializable
eval(K, T, SerializableBiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
Same as FunctionalMap.ReadWriteMap.eval(Object, Object, BiFunction) except that the function must also implement Serializable
evalAll(Consumer<EntryView.WriteEntryView<K, V>>) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Evaluate a write-only Consumer operation with the EntryView.WriteEntryView of the value associated with the key, for all existing keys in functional map, and returns a CompletableFuture that will be completed when the write-only operation has been executed against all the entries.
evalAll(Consumer<EntryView.WriteEntryView<K, V>>) - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
evalAll(Function<EntryView.ReadWriteEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
Evaluate a read-write Function operation with the EntryView.ReadWriteEntryView of the value associated with the key, for all existing keys, and returns a Traversable to navigate each of the Function invocation returns.
evalAll(Function<EntryView.ReadWriteEntryView<K, V>, R>) - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
 
evalAll(SerializableConsumer<EntryView.WriteEntryView<K, V>>) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Same as FunctionalMap.WriteOnlyMap.evalAll(Consumer) except that the function must also implement Serializable
evalAll(SerializableFunction<EntryView.ReadWriteEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
Same as FunctionalMap.ReadWriteMap.evalAll(Function) except that the function must also implement Serializable
evalMany(Map<? extends K, ? extends T>, BiConsumer<T, EntryView.WriteEntryView<K, V>>) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Evaluate a write-only BiConsumer operation, with an argument passed in and a EntryView.WriteEntryView of the value associated with the key, for each of the keys in the set passed in, and returns a CompletableFuture that will be completed when the write-only operation has been executed against all the entries.
evalMany(Map<? extends K, ? extends T>, BiConsumer<T, EntryView.WriteEntryView<K, V>>) - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
evalMany(Map<? extends K, ? extends T>, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
Evaluate a read-write BiFunction, with an argument passed in and a EntryView.ReadWriteEntryView of the value associated with the key, for each of the keys in the set passed in, and returns an Traversable to navigate each of the BiFunction invocation returns.
evalMany(Map<? extends K, ? extends T>, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>) - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
 
evalMany(Map<? extends K, ? extends T>, SerializableBiConsumer<T, EntryView.WriteEntryView<K, V>>) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Same as FunctionalMap.WriteOnlyMap.evalMany(Map, BiConsumer) except that the function must also implement Serializable
evalMany(Map<? extends K, ? extends T>, SerializableBiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
Same as FunctionalMap.ReadWriteMap.evalMany(Map, BiFunction) except that the function must also implement Serializable
evalMany(Set<? extends K>, Consumer<EntryView.WriteEntryView<K, V>>) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Evaluate a write-only Consumer operation with the EntryView.WriteEntryView of the value associated with the key, for each of the keys in the set passed in, and returns a CompletableFuture that will be completed when the write-only operation has been executed against all the entries.
evalMany(Set<? extends K>, Consumer<EntryView.WriteEntryView<K, V>>) - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
evalMany(Set<? extends K>, Function<EntryView.ReadEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadOnlyMap
Evaluate a read-only function on a key and potential value associated in the functional map, for each of the keys in the set passed in, and returns an Traversable to work on each computed function's result.
evalMany(Set<? extends K>, Function<EntryView.ReadEntryView<K, V>, R>) - Method in class org.infinispan.functional.impl.ReadOnlyMapImpl
 
evalMany(Set<? extends K>, Function<EntryView.ReadWriteEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
Evaluate a read-write Function operation with the EntryView.ReadWriteEntryView of the value associated with the key, for each of the keys in the set passed in, and returns a Traversable to navigate each of the Function invocation returns.
evalMany(Set<? extends K>, Function<EntryView.ReadWriteEntryView<K, V>, R>) - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
 
evalMany(Set<? extends K>, SerializableConsumer<EntryView.WriteEntryView<K, V>>) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Same as FunctionalMap.WriteOnlyMap.evalMany(Set, Consumer) except that the function must also implement Serializable
evalMany(Set<? extends K>, SerializableFunction<EntryView.ReadEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadOnlyMap
Same as FunctionalMap.ReadOnlyMap.evalMany(Set, Function) except that the function must also implement Serializable
evalMany(Set<? extends K>, SerializableFunction<EntryView.ReadWriteEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
Same as FunctionalMap.ReadWriteMap.evalMany(Set, Function) except that the function must also implement Serializable
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.impl
Basic implementation of an event that covers all event types.
EventImpl - Class in org.infinispan.notifications.cachemanagerlistener.event.impl
Implementation of cache manager events
EventImpl() - Constructor for class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
EventImpl() - Constructor for class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
EventImpl(String, EmbeddedCacheManager, Event.Type, List<Address>, List<Address>, Address, int) - Constructor for class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
EventLog - Interface in org.infinispan.util.logging.events
EventLog describes an event log's attributes.
EventLogCategory - Enum in org.infinispan.util.logging.events
EventLogCategory.
eventLogContext(String) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
eventLogContext(String) - Method in interface org.infinispan.util.logging.events.Messages
 
eventLogContext$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
EventLogger - Interface in org.infinispan.util.logging.events
EventLogger provides an interface for logging event messages.
EventLogLevel - Enum in org.infinispan.util.logging.events
EventLogLevel.
EventLogManager - Interface in org.infinispan.util.logging.events
EventLogManager.
EventLogManagerImpl - Class in org.infinispan.util.logging.events.impl
EventLogManagerImpl.
EventLogManagerImpl() - Constructor for class org.infinispan.util.logging.events.impl.EventLogManagerImpl
 
eventLogScope(String) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
eventLogScope(String) - Method in interface org.infinispan.util.logging.events.Messages
 
eventLogScope$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
eventLogWho(String) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
eventLogWho(String) - Method in interface org.infinispan.util.logging.events.Messages
 
eventLogWho$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
EventType - Class in org.infinispan.notifications.cachelistener.filter
Enum that provides information to allow for an event to know which type and if this event was generated due to a retry usually caused by a topology change while replicating.
EventType(boolean, boolean, Event.Type) - Constructor for class org.infinispan.notifications.cachelistener.filter.EventType
 
EventWrapper<K,​V,​E extends Event<K,​V>> - Class in org.infinispan.notifications.cachelistener
Simple wrapper that keeps the original key along with the converted event.
EventWrapper(K, E) - Constructor for class org.infinispan.notifications.cachelistener.EventWrapper
 
evict(int, K) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
evict(int, K) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
evict(int, K) - Method in interface org.infinispan.container.impl.InternalDataContainer
Same as DataContainer.evict(Object) except that the segment of the key can provided to remove the entry without calculating the segment for the given key.
evict(int, K) - Method in class org.infinispan.container.impl.InternalDataContainerAdapter
 
evict(K) - Method in interface org.infinispan.Cache
Evicts an entry from the memory of the cache.
evict(K) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
evict(K) - Method in class org.infinispan.cache.impl.CacheImpl
 
evict(K) - Method in class org.infinispan.cache.impl.DecoratedCache
 
evict(K) - Method in class org.infinispan.cache.impl.EncoderCache
 
evict(K) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
evict(K) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
evict(K) - Method in interface org.infinispan.container.DataContainer
Atomically, it removes the key from DataContainer and passivates it to persistence.
evict(K) - Method in class org.infinispan.container.impl.AbstractDelegatingDataContainer
 
evict(K) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
evict(K) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
evict(WrappedBytes) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
EvictCommand - Class in org.infinispan.commands.write
 
EvictCommand(Object, CacheNotifier, int, long, CommandInvocationId, InternalEntryFactory) - Constructor for class org.infinispan.commands.write.EvictCommand
 
EVICTED - org.infinispan.container.entries.ReadCommittedEntry.Flags
 
eviction() - Method in class org.infinispan.configuration.cache.Configuration
Deprecated.
eviction() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
Deprecated.
Since 9.0, Use ConfigurationBuilder.memory() instead
eviction() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
Deprecated.
EVICTION - org.infinispan.configuration.parsing.Attribute
 
EVICTION - org.infinispan.configuration.parsing.Element
 
EVICTION_EXECUTOR - org.infinispan.configuration.parsing.Attribute
Deprecated.
EVICTION_MAX_SIZE - Static variable in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
Deprecated.
 
EVICTION_STRATEGY - Static variable in class org.infinispan.configuration.cache.MemoryConfiguration
 
EVICTION_TYPE - Static variable in class org.infinispan.configuration.cache.MemoryConfiguration
 
evictionCache - Variable in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
EvictionConfiguration - Class in org.infinispan.configuration.cache
Deprecated.
EvictionConfigurationBuilder - Class in org.infinispan.configuration.cache
Deprecated.
evictionDisabled(String) - Method in class org.infinispan.util.logging.Log_$logger
 
evictionDisabled(String) - Method in interface org.infinispan.util.logging.Log
 
evictionDisabled$str() - Method in class org.infinispan.util.logging.Log_$logger
 
evictionExecutorDeprecated() - Method in class org.infinispan.util.logging.Log_$logger
 
evictionExecutorDeprecated() - Method in interface org.infinispan.util.logging.Log
 
evictionExecutorDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
evictionManager - Variable in class org.infinispan.container.impl.AbstractInternalDataContainer
 
evictionManager - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
EvictionManager<K,​V> - Interface in org.infinispan.eviction
Central component that deals with eviction of cache entries.
EvictionManagerImpl<K,​V> - Class in org.infinispan.eviction.impl
 
EvictionManagerImpl() - Constructor for class org.infinispan.eviction.impl.EvictionManagerImpl
 
evictionMaxEntriesDeprecated() - Method in class org.infinispan.util.logging.Log_$logger
 
evictionMaxEntriesDeprecated() - Method in interface org.infinispan.util.logging.Log
 
evictionMaxEntriesDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
evictionScheduledExecutor() - Method in class org.infinispan.configuration.global.GlobalConfiguration
Deprecated.
This method always returns null now. Look for a thread pool named as GlobalConfiguration.expirationThreadPool() instead.
evictionSize() - Method in interface org.infinispan.container.DataContainer
Returns how large the eviction size is currently.
evictionSize() - Method in class org.infinispan.container.impl.AbstractDelegatingDataContainer
 
evictionSize() - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
evictionSize() - Method in class org.infinispan.container.impl.DefaultDataContainer
 
evictionSize() - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
evictionSizeTooLarge(long) - Method in class org.infinispan.util.logging.Log_$logger
 
evictionSizeTooLarge(long) - Method in interface org.infinispan.util.logging.Log
 
evictionSizeTooLarge$str() - Method in class org.infinispan.util.logging.Log_$logger
 
evictionStrategy() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
The configured eviction strategy
evictionStrategy() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
The configured eviction strategy, please see MemoryConfigurationBuilder.evictionStrategy(EvictionStrategy).
evictionStrategy(EvictionStrategy) - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
Sets the eviction strategy which can be: NONE - no eviction will take place MANUAL - no eviction will take place automatically, but user is assumed to manually call evict REMOVE - eviction will remove entries to make room for new entries to be inserted EXCEPTION - eviction will not take place, but instead an exception will be thrown to ensure container doesn't grow too large The eviction strategy NONE and MANUAL are essentially the same except that MANUAL does not warn the user when passivation is enabled.
EvictionStrategy - Enum in org.infinispan.eviction
Supported eviction strategies
EvictionThreadPolicy - Enum in org.infinispan.eviction
Supported eviction thread policy
evictionThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfiguration
evictionThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
Deprecated.
evictionThreadPool() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
Deprecated.
evictionType() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
The configured eviction type
evictionType() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
The configured eviction type, please see MemoryConfigurationBuilder.evictionType(EvictionType).
evictionType(EvictionType) - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
Sets the eviction type which can either be COUNT - entries will be evicted when the number of entries exceeds the MemoryConfigurationBuilder.size(long) MEMORY - entries will be evicted when the approximate combined size of all values exceeds the MemoryConfigurationBuilder.size(long) Cache size is guaranteed not to exceed upper limit specified by size.
EvictionType - Enum in org.infinispan.eviction
Supported eviction type
EXCEPTION - org.infinispan.eviction.EvictionStrategy
Strategy where the cache will block new entries from being written if they would exceed the configured size
ExceptionAckCommand - Class in org.infinispan.commands.write
A command that represents an exception acknowledge sent by any owner.
ExceptionAckCommand() - Constructor for class org.infinispan.commands.write.ExceptionAckCommand
 
ExceptionAckCommand(ByteString) - Constructor for class org.infinispan.commands.write.ExceptionAckCommand
 
ExceptionAckCommand(ByteString, long, Throwable, int) - Constructor for class org.infinispan.commands.write.ExceptionAckCommand
 
exceptionBasedEvictionOnlySupportedInTransactionalCaches() - Method in class org.infinispan.util.logging.Log_$logger
 
exceptionBasedEvictionOnlySupportedInTransactionalCaches() - Method in interface org.infinispan.util.logging.Log
 
exceptionBasedEvictionOnlySupportedInTransactionalCaches$str() - Method in class org.infinispan.util.logging.Log_$logger
 
exceptionDuringClusterListenerRetrieval(Address, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
exceptionDuringClusterListenerRetrieval(Address, Throwable) - Method in interface org.infinispan.util.logging.Log
 
exceptionDuringClusterListenerRetrieval$str() - Method in class org.infinispan.util.logging.Log_$logger
 
exceptionDuringConflictResolution(Object, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
exceptionDuringConflictResolution(Object, Throwable) - Method in interface org.infinispan.util.logging.Log
 
exceptionDuringConflictResolution$str() - Method in class org.infinispan.util.logging.Log_$logger
 
exceptionHandlingCommand(ReplicableCommand, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
exceptionHandlingCommand(ReplicableCommand, Throwable) - Method in interface org.infinispan.util.logging.Log
 
exceptionHandlingCommand$str() - Method in class org.infinispan.util.logging.Log_$logger
 
exceptionInvokingListener(String, Method, Object, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
exceptionInvokingListener(String, Method, Object, Throwable) - Method in interface org.infinispan.util.logging.Log
 
exceptionInvokingListener$str() - Method in class org.infinispan.util.logging.Log_$logger
 
exceptionProcessingEntryRetrievalValues(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
exceptionProcessingEntryRetrievalValues(Throwable) - Method in interface org.infinispan.util.logging.Log
 
exceptionProcessingEntryRetrievalValues$str() - Method in class org.infinispan.util.logging.Log_$logger
 
exceptionPurgingDataContainer(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
exceptionPurgingDataContainer(Exception) - Method in interface org.infinispan.util.logging.Log
 
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
 
EXCLUSIVE - org.infinispan.registry.InternalCacheRegistry.Flag
means that the cache must be declared only once
EXEC - org.infinispan.security.AuthorizationPermission
Allows performing task execution (e.g.
execute(Runnable) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
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(Runnable) - Method in class org.infinispan.executors.LimitedExecutor
 
execute(Runnable) - Method in interface org.infinispan.manager.ClusterExecutor
execute(Runnable) - Method in class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
 
execute(Runnable) - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
execute(ExecutorService) - Method in class org.infinispan.statetransfer.OutboundTransferTask
 
execute(RpcManager, long, TimeUnit) - Method in class org.infinispan.remoting.transport.RetryOnFailureXSiteCommand
Invokes remotely the command using the Transport passed as parameter.
execute(BlockingRunnable) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
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(SerializableRunnable) - Method in interface org.infinispan.manager.ClusterExecutor
The same as Executor.execute(Runnable), except the Runnable must also implement Serializable.
executeAsync(Supplier<CompletionStage<Void>>) - Method in class org.infinispan.executors.LimitedExecutor
Similar to LimitedExecutor.execute(Runnable), but the task can continue executing asynchronously, without blocking the OS thread, while still counting against this executor's limit.
executeOnCoordinatorRetry(ReplicableCommand, int) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
executeTask(KeyFilter<? super K>, BiConsumer<? super K, InternalCacheEntry<K, V>>) - Method in interface org.infinispan.container.DataContainer
Deprecated.
since 9.3 Please use the DataContainer.iterator() method and apply filtering manually
executeTask(KeyFilter<? super K>, BiConsumer<? super K, InternalCacheEntry<K, V>>) - Method in class org.infinispan.container.impl.AbstractDelegatingDataContainer
 
executeTask(KeyFilter<? super K>, BiConsumer<? super K, InternalCacheEntry<K, V>>) - Method in class org.infinispan.container.impl.DefaultDataContainer
 
executeTask(KeyValueFilter<? super K, ? super V>, BiConsumer<? super K, InternalCacheEntry<K, V>>) - Method in interface org.infinispan.container.DataContainer
Deprecated.
since 9.3 Please use the DataContainer.iterator() method and apply filtering manually
executeTask(KeyValueFilter<? super K, ? super V>, BiConsumer<? super K, InternalCacheEntry<K, V>>) - Method in class org.infinispan.container.impl.AbstractDelegatingDataContainer
 
executeTask(KeyValueFilter<? super K, ? super V>, BiConsumer<? super K, InternalCacheEntry<K, V>>) - Method in class org.infinispan.container.impl.DefaultDataContainer
 
EXECUTION_MODE_ID - Static variable in class org.infinispan.functional.ParamIds
 
executionCandidates() - Method in interface org.infinispan.distexec.FailoverContext
Returns a list of candidates for possible repeated execution governed by installed DistributedTaskFailoverPolicy
executionCandidates(DistributedTask<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
executionError(String, String, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
executionError(String, String, Throwable) - Method in interface org.infinispan.util.logging.Log
 
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.executors.ManageableExecutorService
 
executor - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
executor - Variable in class org.infinispan.persistence.support.SingletonCacheWriter
Deprecated.
Executor service used to submit tasks to push in-memory state.
executor - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
executor() - Method in class org.infinispan.manager.DefaultCacheManager
 
executor() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Providess the cache manager based executor.
executor() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
EXECUTOR - org.infinispan.configuration.parsing.Attribute
 
ExecutorAllCompletionService - Class in org.infinispan.executors
Exectues given tasks in provided executor.
ExecutorAllCompletionService(Executor) - Constructor for class org.infinispan.executors.ExecutorAllCompletionService
 
ExecutorFactoryConfiguration - Class in org.infinispan.configuration.global
 
ExecutorFactoryConfigurationBuilder - Class in org.infinispan.configuration.global
Configures executor factory.
executorService - Variable in class org.infinispan.statetransfer.StateProviderImpl
 
existingConfigForInternalCache(String) - Method in class org.infinispan.util.logging.Log_$logger
 
existingConfigForInternalCache(String) - Method in interface org.infinispan.util.logging.Log
 
existingConfigForInternalCache$str() - Method in class org.infinispan.util.logging.Log_$logger
 
exists() - Method in class org.infinispan.io.GridFile
 
ExpandableMarshalledValueByteStream - Class in org.infinispan.io
A byte stream that can be written to and expanded on the fly, not dissimilar to ExposedByteArrayOutputStream but with the benefit of not having to allocate unnecessary byte arrays by not extending ByteArrayOutputStream.
ExpandableMarshalledValueByteStream() - Constructor for class org.infinispan.io.ExpandableMarshalledValueByteStream
 
ExpandableMarshalledValueByteStream(int) - Constructor for class org.infinispan.io.ExpandableMarshalledValueByteStream
 
ExpandableMarshalledValueByteStream(int, int) - Constructor for class org.infinispan.io.ExpandableMarshalledValueByteStream
Creates a new byte array output stream, with a buffer capacity of the specified size, in bytes.
expectedJustOneResponse(Map<Address, Response>) - Method in class org.infinispan.util.logging.Log_$logger
 
expectedJustOneResponse(Map<Address, Response>) - Method in interface org.infinispan.util.logging.Log
 
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
 
EXPIRATION - org.infinispan.configuration.parsing.Element
 
EXPIRATION_EXECUTOR - org.infinispan.configuration.parsing.Attribute
 
EXPIRATION_SCHEDULED_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
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.
expirationManager - Variable in class org.infinispan.container.impl.AbstractInternalDataContainer
 
expirationManager - Variable in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
ExpirationManager<K,​V> - Interface in org.infinispan.expiration
Central component that deals with expiration of cache entries.
ExpirationManagerFactory - Class in org.infinispan.factories
Constructs the expiration manager
ExpirationManagerFactory() - Constructor for class org.infinispan.factories.ExpirationManagerFactory
 
ExpirationManagerImpl<K,​V> - Class in org.infinispan.expiration.impl
 
ExpirationManagerImpl() - Constructor for class org.infinispan.expiration.impl.ExpirationManagerImpl
 
expirationTask - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
expirationThreadPool() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
Configuration for the expiration thread pool
EXPIRED - org.infinispan.container.entries.ReadCommittedEntry.Flags
 
EXPIRED - org.infinispan.transaction.impl.TransactionTable.CompletedTransactionStatus
 
expiredIterationPredicate(long) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
Returns a predicate that will return false when an entry is expired.
expiring - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
This map is used for performance reasons.
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 class org.infinispan.container.entries.RemoteMetadata
 
expiryTime() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
 
expiryTime() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
 
expiryTime() - Method in interface org.infinispan.metadata.InternalMetadata
 
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.
ExtendedLockPromise - Interface in org.infinispan.util.concurrent.locks
An extended LockPromise interface that allows a better control over it.
Externalizer() - Constructor for class org.infinispan.atomic.impl.AtomicMapProxyImpl.Externalizer
 
Externalizer() - Constructor for class org.infinispan.cache.impl.EncoderEntryMapper.Externalizer
 
Externalizer() - Constructor for class org.infinispan.cache.impl.EncoderKeyMapper.Externalizer
 
Externalizer() - Constructor for class org.infinispan.cache.impl.EncoderValueMapper.Externalizer
 
Externalizer() - Constructor for class org.infinispan.commands.functional.functions.MergeFunction.Externalizer
 
Externalizer() - Constructor for class org.infinispan.compat.BiFunctionMapper.Externalizer
 
Externalizer() - Constructor for class org.infinispan.compat.FunctionMapper.Externalizer
 
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.RemoteMetadata.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.impl.DefaultConsistentHash.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.impl.ScatteredConsistentHash.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.impl.TopologyAwareConsistentHashFactory.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory.Externalizer
 
Externalizer() - Constructor for class org.infinispan.encoding.DataConversion.Externalizer
 
Externalizer() - Constructor for class org.infinispan.filter.AcceptAllKeyValueFilter.Externalizer
 
Externalizer() - Constructor for class org.infinispan.filter.CollectionKeyFilter.Externalizer
 
Externalizer() - Constructor for class org.infinispan.filter.CompositeKeyFilter.Externalizer
 
Externalizer() - Constructor for class org.infinispan.filter.CompositeKeyValueFilter.Externalizer
 
Externalizer() - Constructor for class org.infinispan.filter.KeyFilterAsKeyValueFilter.Externalizer
 
Externalizer() - Constructor for class org.infinispan.filter.KeyValueFilterAsKeyFilter.Externalizer
 
Externalizer() - Constructor for class org.infinispan.functional.impl.MetaParamsInternalMetadata.Externalizer
 
Externalizer() - Constructor for class org.infinispan.functional.impl.StatsEnvelope.Externalizer
 
Externalizer() - Constructor for class org.infinispan.globalstate.impl.CacheState.Externalizer
 
Externalizer() - Constructor for class org.infinispan.globalstate.ScopedState.Externalizer
 
Externalizer() - Constructor for class org.infinispan.globalstate.ScopeFilter.Externalizer
 
Externalizer() - Constructor for class org.infinispan.interceptors.distribution.VersionedResult.Externalizer
 
Externalizer() - Constructor for class org.infinispan.interceptors.distribution.VersionedResults.Externalizer
 
Externalizer() - Constructor for class org.infinispan.metadata.EmbeddedMetadata.Externalizer
 
Externalizer() - Constructor for class org.infinispan.metadata.impl.InternalMetadataImpl.Externalizer
 
Externalizer() - Constructor for class org.infinispan.notifications.cachelistener.cluster.ClusterEvent.Externalizer
 
Externalizer() - Constructor for class org.infinispan.notifications.cachelistener.cluster.ClusterEventCallable.Externalizer
 
Externalizer() - Constructor for class org.infinispan.notifications.cachelistener.cluster.ClusterListenerRemoveCallable.Externalizer
 
Externalizer() - Constructor for class org.infinispan.notifications.cachelistener.cluster.ClusterListenerReplicateCallable.Externalizer
 
Externalizer() - Constructor for class org.infinispan.notifications.cachelistener.cluster.MultiClusterEventCallable.Externalizer
 
Externalizer() - Constructor for class org.infinispan.notifications.cachelistener.filter.CacheEventConverterAsConverter.Externalizer
 
Externalizer() - Constructor for class org.infinispan.notifications.cachelistener.filter.CacheEventFilterAsKeyValueFilter.Externalizer
 
Externalizer() - Constructor for class org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverterAsKeyValueFilterConverter.Externalizer
 
Externalizer() - Constructor for class org.infinispan.notifications.cachelistener.filter.KeyFilterAsCacheEventFilter.Externalizer
 
Externalizer() - Constructor for class org.infinispan.notifications.cachelistener.filter.KeyValueFilterAsCacheEventFilter.Externalizer
 
Externalizer() - Constructor for class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter.Externalizer
 
Externalizer() - Constructor for class org.infinispan.partitionhandling.AvailabilityMode.Externalizer
 
Externalizer() - Constructor for class org.infinispan.remoting.MIMECacheEntry.Externalizer
 
Externalizer() - Constructor for class org.infinispan.remoting.responses.BiasRevocationResponse.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.CacheStatusResponse.Externalizer
 
Externalizer() - Constructor for class org.infinispan.topology.CacheTopology.Externalizer
 
Externalizer() - Constructor for class org.infinispan.topology.ManagerStatusResponse.Externalizer
 
Externalizer() - Constructor for class org.infinispan.topology.PersistentUUID.Externalizer
 
Externalizer() - Constructor for class org.infinispan.transaction.xa.DldGlobalTransaction.Externalizer
Deprecated.
 
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
Deprecated.
 
Externalizer() - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction.Externalizer
 
Externalizer() - Constructor for class org.infinispan.util.KeyValuePair.Externalizer
 
Externalizer(StreamingMarshaller) - Constructor for class org.infinispan.marshall.core.MarshalledEntryImpl.Externalizer
 
Externalizer(GlobalComponentRegistry) - Constructor for class org.infinispan.atomic.impl.ApplyDelta.Externalizer
Deprecated.
 
Externalizer(GlobalComponentRegistry) - Constructor for class org.infinispan.atomic.impl.AtomicKeySetImpl.Externalizer
 
ExternallyMarshallable - Class in org.infinispan.marshall.core
As much as possible, Infinispan consumers should provide Externalizer or AdvancedExternalizer instances for the types being marshalled, so that these types can be marshalled as efficiently as possible.
ExternalPojo - Interface in org.infinispan.marshall.core
Marker interface for those pojos that are allowed to be marshalled externally.
ExternalStore<K,​V> - Interface in org.infinispan.persistence.spi
Basic interface for interacting with an external store in a read-write mode.
extractDependencyType(Type, Type, boolean) - Method in class org.infinispan.factories.components.ComponentMetadata
 
extractException(Throwable) - Static method in class org.infinispan.util.concurrent.CompletableFutures
 
extractIndexable(Object) - Method in class org.infinispan.encoding.DataConversion
 
extractSegment(ReplicableCommand, Object, KeyPartitioner) - Static method in interface org.infinispan.commands.SegmentSpecificCommand
Utility to extract the segment from a given command that may be a SegmentSpecificCommand.
extractStateTransferFlag(InvocationContext, FlagAffectedCommand) - Static method in class org.infinispan.context.impl.FlagBitSets
 
extraneousMembersJoinRestoredCache(List<Address>, String) - Method in class org.infinispan.util.logging.Log_$logger
 
extraneousMembersJoinRestoredCache(List<Address>, String) - Method in interface org.infinispan.util.logging.Log
 
extraneousMembersJoinRestoredCache$str() - Method in class org.infinispan.util.logging.Log_$logger
 

F

f - Variable in class org.infinispan.commands.functional.ReadOnlyKeyCommand
 
f - Variable in class org.infinispan.commands.functional.ReadOnlyManyCommand
 
factory - Variable in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
factory - Variable in class org.infinispan.stream.impl.ClusterStreamManagerImpl
 
factory() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfiguration
 
factory() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfiguration
 
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(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() - Constructor for class org.infinispan.stats.impl.StatsCollector.Factory
 
factoryCannotConstructComponent(String) - Method in class org.infinispan.util.logging.Log_$logger
 
factoryCannotConstructComponent(String) - Method in interface org.infinispan.util.logging.Log
 
factoryCannotConstructComponent$str() - Method in class org.infinispan.util.logging.Log_$logger
 
fail() - Method in class org.infinispan.commands.functional.AbstractWriteKeyCommand
 
fail() - Method in class org.infinispan.commands.functional.AbstractWriteManyCommand
 
fail() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
Deprecated.
 
fail() - Method in class org.infinispan.commands.write.ClearCommand
 
fail() - Method in class org.infinispan.commands.write.ComputeCommand
 
fail() - Method in class org.infinispan.commands.write.ComputeIfAbsentCommand
 
fail() - Method in class org.infinispan.commands.write.InvalidateCommand
 
fail() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
fail() - Method in class org.infinispan.commands.write.PutMapCommand
 
fail() - Method in class org.infinispan.commands.write.RemoveCommand
 
fail() - Method in class org.infinispan.commands.write.ReplaceCommand
 
fail() - Method in interface org.infinispan.commands.write.WriteCommand
Make subsequent invocations of WriteCommand.isSuccessful() return false.
fail() - Method in interface org.infinispan.scattered.BiasManager.Revocation
 
FAIL - org.infinispan.configuration.cache.BackupFailurePolicy
 
FAIL_SILENTLY - org.infinispan.configuration.parsing.Attribute
 
FAIL_SILENTLY - org.infinispan.context.Flag
Swallows any exceptions, logging them instead at a low log level.
FAIL_SILENTLY - Static variable in class org.infinispan.configuration.cache.AsyncStoreConfiguration
 
FAIL_SILENTLY - Static variable in class org.infinispan.context.impl.FlagBitSets
 
failAtomic() - Method in class org.infinispan.batch.AutoBatchSupport
 
FAILED - org.infinispan.lifecycle.ComponentStatus
The component is in a failed state due to a problem with one of the other lifecycle transition phases.
failedConfirmingRevokedSegments(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
failedConfirmingRevokedSegments(Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedConfirmingRevokedSegments$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedConflictResolution(String, CacheTopology, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
failedConflictResolution(String, CacheTopology, Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedConflictResolution$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedInvalidatingRemoteCache(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
failedInvalidatingRemoteCache(Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedInvalidatingRemoteCache$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedInvokingCacheManagerListener(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
failedInvokingCacheManagerListener(Exception) - Method in interface org.infinispan.util.logging.Log
 
failedInvokingCacheManagerListener$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedLoadingKeysFromCacheStore(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
failedLoadingKeysFromCacheStore(Exception) - Method in interface org.infinispan.util.logging.Log
 
failedLoadingKeysFromCacheStore$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedLoadingValueFromCacheStore(Object, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
failedLoadingValueFromCacheStore(Object, Exception) - Method in interface org.infinispan.util.logging.Log
 
failedLoadingValueFromCacheStore$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedOutBoundTransferExecution(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
failedOutBoundTransferExecution(Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedOutBoundTransferExecution$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedProcessingValuesDuringRebalance(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
failedProcessingValuesDuringRebalance(Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedProcessingValuesDuringRebalance$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedReadingPersistentState(IOException, File) - Method in class org.infinispan.util.logging.Log_$logger
 
failedReadingPersistentState(IOException, File) - Method in interface org.infinispan.util.logging.Log
 
failedReadingPersistentState$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedSynchronizationRegistration(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
failedSynchronizationRegistration(Exception) - Method in interface org.infinispan.util.logging.Log
 
failedSynchronizationRegistration$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedToCallStopAfterFailure(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
failedToCallStopAfterFailure(Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedToCallStopAfterFailure$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedToCreateInitialCtx(NamingException) - Method in class org.infinispan.util.logging.Log_$logger
 
failedToCreateInitialCtx(NamingException) - Method in interface org.infinispan.util.logging.Log
 
failedToCreateInitialCtx$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedToEnlistTransactionXaAdapter(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
failedToEnlistTransactionXaAdapter(Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedToEnlistTransactionXaAdapter$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedToInvalidateKeys(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
failedToInvalidateKeys(Exception) - Method in interface org.infinispan.util.logging.Log
 
failedToInvalidateKeys$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedToRecoverCacheState(String, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
failedToRecoverCacheState(String, Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedToRecoverCacheState$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedToRecoverClusterState(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
failedToRecoverClusterState(Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedToRecoverClusterState$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedToRequestSegments(String, Address, Collection<Integer>, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
failedToRequestSegments(String, Address, Collection<Integer>, Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedToRequestSegments$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedToRestartXSiteStateTransfer(String, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
failedToRestartXSiteStateTransfer(String, Throwable) - Method in interface org.infinispan.util.logging.Log
 
failedToRestartXSiteStateTransfer$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedToRetrieveTransactionsForSegments(String, Address, Collection<Integer>, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
failedToRetrieveTransactionsForSegments(String, Address, Collection<Integer>, Exception) - Method in interface org.infinispan.util.logging.Log
 
failedToRetrieveTransactionsForSegments$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedToUpdateAttribute(String, Object) - Method in class org.infinispan.util.logging.Log_$logger
 
failedToUpdateAttribute(String, Object) - Method in interface org.infinispan.util.logging.Log
 
failedToUpdateAttribute$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedWaitingForTopology(int) - Method in class org.infinispan.util.logging.Log_$logger
 
failedWaitingForTopology(int) - Method in interface org.infinispan.util.logging.Log
 
failedWaitingForTopology$str() - Method in class org.infinispan.util.logging.Log_$logger
 
failedWritingGlobalState(IOException, File) - Method in class org.infinispan.util.logging.Log_$logger
 
failedWritingGlobalState(IOException, File) - Method in interface org.infinispan.util.logging.Log
 
failedWritingGlobalState$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
failSilently() - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
 
failSilently(boolean) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
FAILURE_POLICY - Static variable in class org.infinispan.configuration.cache.BackupConfiguration
 
FAILURE_POLICY_CLASS - org.infinispan.configuration.parsing.Attribute
 
FAILURE_POLICY_CLASS - Static variable in class org.infinispan.configuration.cache.BackupConfiguration
 
failureCompletingTransaction(Transaction) - Method in class org.infinispan.transaction.impl.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
 
fallingBackToEmbeddedTm() - Method in class org.infinispan.util.logging.Log_$logger
 
fallingBackToEmbeddedTm() - Method in interface org.infinispan.util.logging.Log
 
fallingBackToEmbeddedTm$str() - Method in class org.infinispan.util.logging.Log_$logger
 
fatal(EventLogCategory, String) - Method in interface org.infinispan.util.logging.events.EventLogger
Logs a message to the event log using the EventLogLevel.FATAL severity
FATAL - org.infinispan.util.logging.events.EventLogLevel
 
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.
features() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
FETCH_IN_MEMORY_STATE - Static variable in class org.infinispan.configuration.cache.StateTransferConfiguration
 
FETCH_PERSISTENT_STATE - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
FETCH_STATE - org.infinispan.configuration.parsing.Attribute
 
fetchInMemoryState() - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
If true, the cache will fetch data from the neighboring caches when it starts up, so the cache starts 'warm', although it will impact startup time.
fetchInMemoryState(boolean) - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
If true, the cache will fetch data from the neighboring caches when it starts up, so the cache starts 'warm', although it will impact startup time.
fetchPersistentState - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
Deprecated.
fetchPersistentState() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
If true, fetch persistent state when joining a cluster.
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 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(boolean) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
If true, fetch persistent state when joining a cluster.
fetchRebalancingStatusFromCoordinator() - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
fetchRequiredKeys(LocalizedCacheTopology, Map<Address, List<Object>>, List<Object>, InvocationContext, C) - Method in interface org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadManyCommandHelper
 
fetchRequiredKeys(LocalizedCacheTopology, Map<Address, List<Object>>, List<Object>, InvocationContext, ReadOnlyManyCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadOnlyManyHelper
 
FIFO - org.infinispan.eviction.EvictionStrategy
Deprecated.
FILE - Static variable in class org.infinispan.io.GridFile.Metadata
 
FILE_STORE - org.infinispan.configuration.parsing.Element
 
fileLocationTransform(String, int) - Static method in class org.infinispan.configuration.cache.AbstractSegmentedStoreConfiguration
Transforms a file location to a segment based one.
filename(String) - Static method in class org.infinispan.io.GridFile
 
filter - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
filter(DoublePredicate) - Method in interface org.infinispan.DoubleCacheStream
filter(DoublePredicate) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
filter(DoublePredicate) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
filter(DoublePredicate) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
filter(IntPredicate) - Method in interface org.infinispan.IntCacheStream
filter(IntPredicate) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
filter(IntPredicate) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
filter(IntPredicate) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
filter(LongPredicate) - Method in interface org.infinispan.LongCacheStream
filter(LongPredicate) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
filter(LongPredicate) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
filter(LongPredicate) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
filter(Predicate<? super CacheEntry<K, V>>) - Method in interface org.infinispan.LockedStream
Returns a locked stream consisting of the elements of this stream that match the given predicate.
filter(Predicate<? super CacheEntry<K, V>>) - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
filter(Predicate<? super R>) - Method in interface org.infinispan.CacheStream
filter(Predicate<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
filter(Predicate<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
filter(Predicate<? super R>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
filter(Predicate<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
filter(Predicate<? super T>) - Method in interface org.infinispan.functional.Traversable
An intermediate operation that returns a traversable containing elements matching the given predicate.
filter(SerializableDoublePredicate) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleCacheStream.filter(DoublePredicate) except that the DoublePredicate must also implement Serializable
filter(SerializableDoublePredicate) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
filter(SerializableIntPredicate) - Method in interface org.infinispan.IntCacheStream
Same as IntCacheStream.filter(IntPredicate) except that the IntPredicate must also implement Serializable
filter(SerializableIntPredicate) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
filter(SerializableLongPredicate) - Method in interface org.infinispan.LongCacheStream
Same as LongCacheStream.filter(LongPredicate) except that the LongPredicate must also implement Serializable.
filter(SerializableLongPredicate) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
filter(SerializablePredicate<? super CacheEntry<K, V>>) - Method in interface org.infinispan.LockedStream
Same as LockedStream.filter(Predicate) except that the Predicate must also implement Serializable
filter(SerializablePredicate<? super R>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.filter(Predicate) except that the Predicate must also implement Serializable
filterAndConvert - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
filterAndConvert(Stream<CacheEntry<K, V>>, KeyValueFilterConverter<? super K, ? super V, C>) - Static method in class org.infinispan.filter.CacheFilters
Adds needed intermediate operations to the provided stream, returning a possibly new stream as a result of the operations.
filterAndConvert(K, V, Metadata) - Method in interface org.infinispan.filter.KeyValueFilterConverter
Will both filter the entry and if passed subsequently convert the value to a new value.
filterAndConvert(K, V, Metadata) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverterAsKeyValueFilterConverter
 
filterAndConvert(K, V, Metadata, V, Metadata, EventType) - Method in interface org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverter
Will both filter the entry and if passed subsequently convert the value to a new value.
filterAndConvert(K, V, Metadata, V, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter
 
filterAndConvert(CacheStream<CacheEntry<K, V>>, KeyValueFilterConverter<? super K, ? super V, C>) - Static method in class org.infinispan.filter.CacheFilters
 
filterAnnotations - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
filterBySegment(LocalizedCacheTopology, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
FilterDoubleOperation - Class in org.infinispan.stream.impl.intops.primitive.d
Performs filter operation on a DoubleStream
FilterDoubleOperation(DoublePredicate) - Constructor for class org.infinispan.stream.impl.intops.primitive.d.FilterDoubleOperation
 
filterEntries(Map<K, V>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
filterExpiredEntries(Spliterator<InternalCacheEntry<K, V>>) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
Returns a new spliterator that will not return entries that have expired.
FilterIndexingServiceProvider - Interface in org.infinispan.notifications.cachelistener.filter
A service provider for filter indexing services.
FilteringListenable<K,​V> - Interface in org.infinispan.notifications
A Listenable that can also filter events based on key
FilterIntOperation<S> - Class in org.infinispan.stream.impl.intops.primitive.i
Performs filter operation on a IntStream
FilterIntOperation(IntPredicate) - Constructor for class org.infinispan.stream.impl.intops.primitive.i.FilterIntOperation
 
filterKeys(Set<?>) - Method in interface org.infinispan.BaseCacheStream
Filters which entries are returned by only returning ones that map to the given key.
filterKeys(Set<?>) - Method in interface org.infinispan.CacheStream
Filters which entries are returned by only returning ones that map to the given key.
filterKeys(Set<?>) - Method in interface org.infinispan.DoubleCacheStream
Filters which entries are returned by only returning ones that map to the given key.
filterKeys(Set<?>) - Method in interface org.infinispan.IntCacheStream
Filters which entries are returned by only returning ones that map to the given key.
filterKeys(Set<?>) - Method in interface org.infinispan.LockedStream
Filters which entries are returned by only returning ones that map to the given key.
filterKeys(Set<?>) - Method in interface org.infinispan.LongCacheStream
Filters which entries are returned by only returning ones that map to the given key.
filterKeys(Set<?>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
filterKeys(Set<?>) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
filterKeys(Set<?>) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
filterKeys(Set<?>) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
filterKeys(Set<?>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
filterKeys(Set<?>) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
filterKeys(Set<?>) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
filterKeys(Set<?>) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
filterKeys(Set<?>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
filterKeys(Set<?>) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
filterKeys(Set<?>) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
filterKeys(Set<?>) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
filterKeys(Set<?>) - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
filterKeys(Set<?>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
filterKeySegments(Set<Integer>) - Method in interface org.infinispan.BaseCacheStream
Deprecated.
since 9.3 This is to be replaced by BaseCacheStream.filterKeySegments(IntSet)
filterKeySegments(Set<Integer>) - Method in interface org.infinispan.CacheStream
Deprecated.
This is to be replaced by CacheStream.filterKeySegments(IntSet)
filterKeySegments(Set<Integer>) - Method in interface org.infinispan.DoubleCacheStream
Filters which entries are returned by what segment they are present in.
filterKeySegments(Set<Integer>) - Method in interface org.infinispan.IntCacheStream
Filters which entries are returned by what segment they are present in.
filterKeySegments(Set<Integer>) - Method in interface org.infinispan.LockedStream
Deprecated.
This is to be replaced by LockedStream.filterKeySegments(IntSet)
filterKeySegments(Set<Integer>) - Method in interface org.infinispan.LongCacheStream
Filters which entries are returned by what segment they are present in.
filterKeySegments(Set<Integer>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
filterKeySegments(Set<Integer>) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
filterKeySegments(Set<Integer>) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
filterKeySegments(Set<Integer>) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
filterKeySegments(Set<Integer>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
filterKeySegments(Set<Integer>) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
filterKeySegments(Set<Integer>) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
filterKeySegments(Set<Integer>) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
filterKeySegments(Set<Integer>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
filterKeySegments(Set<Integer>) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
filterKeySegments(Set<Integer>) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
filterKeySegments(Set<Integer>) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
filterKeySegments(Set<Integer>) - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
filterKeySegments(Set<Integer>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
filterKeySegments(IntSet) - Method in interface org.infinispan.BaseCacheStream
Filters which entries are returned by what segment they are present in.
filterKeySegments(IntSet) - Method in interface org.infinispan.CacheStream
Filters which entries are returned by what segment they are present in.
filterKeySegments(IntSet) - Method in interface org.infinispan.LockedStream
Filters which entries are returned by what segment they are present in.
filterKeySegments(IntSet) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
filterKeySegments(IntSet) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
filterKeySegments(IntSet) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
filterKeySegments(IntSet) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
filterKeySegments(IntSet) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
filterKeySegments(IntSet) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
filterKeySegments(IntSet) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
filterKeySegments(IntSet) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
filterKeySegments(IntSet) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
filterKeySegments(IntSet) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
filterKeySegments(IntSet) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
filterKeySegments(IntSet) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
filterKeySegments(IntSet) - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
filterKeySegments(IntSet) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
FilterLongOperation<S> - Class in org.infinispan.stream.impl.intops.primitive.l
Performs filter operation on a LongStream
FilterLongOperation(LongPredicate) - Constructor for class org.infinispan.stream.impl.intops.primitive.l.FilterLongOperation
 
FilterMapResponseCollector - Class in org.infinispan.remoting.transport.impl
FilterMapResponseCollector(ResponseFilter, boolean, int) - Constructor for class org.infinispan.remoting.transport.impl.FilterMapResponseCollector
 
FilterOperation<S> - Class in org.infinispan.stream.impl.intops.object
Performs filter operation on a regular Stream
FilterOperation(Predicate<? super S>) - Constructor for class org.infinispan.stream.impl.intops.object.FilterOperation
 
filterPrivateCaches(Set<String>) - Method in class org.infinispan.registry.impl.InternalCacheRegistryImpl
 
filterPrivateCaches(Set<String>) - Method in interface org.infinispan.registry.InternalCacheRegistry
Removes the private caches from the specified set of cache names
filterTargets(Collection<Address>) - Method in interface org.infinispan.manager.ClusterExecutor
Allows for filtering of address nodes by only allowing addresses in this collection from being contacted.
filterTargets(Predicate<? super Address>) - Method in interface org.infinispan.manager.ClusterExecutor
Allows for filtering of address nodes dynamically per invocation.
filterTargets(ClusterExecutionPolicy) - Method in interface org.infinispan.manager.ClusterExecutor
Allows for filtering of address nodes by only allowing addresses that match the given execution policy to be used.
filterTargets(ClusterExecutionPolicy, Predicate<? super Address>) - Method in interface org.infinispan.manager.ClusterExecutor
Allows for filtering of address nodes dynamically per invocation.
find() - Method in interface org.infinispan.functional.EntryView.ReadEntryView
Optional value.
findAny() - Method in interface org.infinispan.functional.Traversable
A terminal operation that returns an optional containing an element of the traversable, or an empty optional if empty.
findAny() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
findAny() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
findAny() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
findAny() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
findAny() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
findAny() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
findAny() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
findAny() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
findAny() - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
findAny() - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
findAny() - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
findAny() - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
findAny() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
findAnyLockedOrBackupLocked(Collection<Object>) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
findAnyLockedOrBackupLocked(Collection<Object>) - Method in interface org.infinispan.transaction.xa.CacheTransaction
Deprecated.
findComponentMetadata(Class<?>) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
Deprecated.
findComponentMetadata(String) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
Deprecated.
findCreatedEntries() - Method in interface org.infinispan.notifications.cachelistener.QueueingSegmentListener
This method is to be called just before marking the transfer as complete and after all keys have been manually processed.
findExternalizerFor(Object) - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
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
findFactoryForComponent(String) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
Locates the fully qualified class name of a factory capable of constructing an instance of
findFirst() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
findFirst() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
findFirst() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
findFirst() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
findFirst() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
findFirst() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
findFirst() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
findFirst() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
findFirst() - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
findFirst() - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
findFirst() - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
findFirst() - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
findFirst() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
findInterceptorExtending(Class<T>) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Returns the first interceptor extending the given class, or null if there is none.
findInterceptorExtending(Class<T>) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
findInterceptorExtending(Class<T>) - Method in class org.infinispan.interceptors.impl.AsyncInterceptorChainImpl
 
findInterceptorWithClass(Class<T>) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Returns the first interceptor with the given class, or null if there is none.
findInterceptorWithClass(Class<T>) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
findInterceptorWithClass(Class<T>) - Method in class org.infinispan.interceptors.impl.AsyncInterceptorChainImpl
 
findListenerCallbacks(Object) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
 
findMetaParam(Class<T>) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
 
findMetaParam(Class<T>) - Method in interface org.infinispan.functional.MetaParam.Lookup
Returns a non-empty Optional instance containing a metadata parameter instance that can be assigned to the type Class passed in, or an empty Optional if no metadata can be assigned to that type.
findNewBackupOwner(DefaultConsistentHashFactory.Builder, Collection<Address>, Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
 
findNewPrimaryOwner(AbstractConsistentHashFactory.Builder, Collection<Address>, Address) - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHashFactory
 
findNext() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator
 
findWorstPrimaryOwner(AbstractConsistentHashFactory.Builder, List<Address>) - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHashFactory
 
FineGrainedAtomicMap<K,​V> - Interface in org.infinispan.atomic
FineGrainedAtomicMap is a special type of Map geared for use in Infinispan.
FineGrainedAtomicMapProxyImpl<K,​V,​MK> - Class in org.infinispan.atomic.impl
Implementation of FineGrainedAtomicMap that uses Grouping API to co-locate subkeys on the same node.
FineGrainedAtomicMapProxyImpl(Cache<Object, Object>, FunctionalMap.ReadOnlyMap<Object, Object>, FunctionalMap.ReadWriteMap<Object, Object>, MK, InvocationContextFactory, EntryFactory) - Constructor for class org.infinispan.atomic.impl.FineGrainedAtomicMapProxyImpl
 
finish() - Method in interface org.infinispan.interceptors.distribution.BiasedCollector
 
finish() - Method in class org.infinispan.remoting.transport.impl.FilterMapResponseCollector
 
finish() - Method in class org.infinispan.remoting.transport.impl.MapResponseCollector
 
finish() - Method in class org.infinispan.remoting.transport.impl.PassthroughMapResponseCollector
 
finish() - Method in class org.infinispan.remoting.transport.impl.PassthroughSingleResponseCollector
 
finish() - Method in class org.infinispan.remoting.transport.impl.VoidResponseCollector
 
finish() - Method in class org.infinispan.remoting.transport.RemoteGetResponseCollector
 
finish() - Method in interface org.infinispan.remoting.transport.ResponseCollector
Called after ResponseCollector.addResponse(Address, Response) returns null for the last response.
finish() - Method in class org.infinispan.remoting.transport.ValidResponseCollector
 
finish() - Method in class org.infinispan.remoting.transport.ValidSingleResponseCollector
 
FINISH_RECEIVE - org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand.StateTransferControl
 
FINISH_SEND - org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand.StateTransferControl
 
finishedConflictResolution(String, CacheTopology) - Method in class org.infinispan.util.logging.Log_$logger
 
finishedConflictResolution(String, CacheTopology) - Method in interface org.infinispan.util.logging.Log
 
finishedConflictResolution$str() - Method in class org.infinispan.util.logging.Log_$logger
 
finishedRebalance(String, CacheTopology) - Method in class org.infinispan.util.logging.Log_$logger
 
finishedRebalance(String, CacheTopology) - Method in interface org.infinispan.util.logging.Log
 
finishedRebalance$str() - Method in class org.infinispan.util.logging.Log_$logger
 
finishObjectInput(ObjectInput) - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
finishObjectOutput(ObjectOutput) - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
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
 
FIRST - org.infinispan.configuration.cache.InterceptorConfiguration.Position
Specifies that the new interceptor is placed first in the chain.
firstAddress - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
firstEnlistedResource() - Method in class org.infinispan.transaction.tm.DummyTransaction
Deprecated.
 
firstEnlistedResource() - Method in class org.infinispan.transaction.tm.DummyTransactionManager
Deprecated.
 
firstEnlistedResource() - Method in class org.infinispan.transaction.tm.EmbeddedTransaction
 
firstEnlistedResource() - Method in class org.infinispan.transaction.tm.EmbeddedTransactionManager
 
Flag - Enum in org.infinispan.context
Available flags, which may be set on a per-invocation basis.
Flag.Externalizer - Class in org.infinispan.context
 
FlagAffectedCommand - Interface in org.infinispan.commands
Flags modify behavior of command such as whether or not to invoke certain commands remotely, check cache store etc.
FlagAffectedStore<K,​V> - Interface in org.infinispan.persistence.spi
Implemented by stores that can skip writes based on certain flags present in the invocation.
FlagBitSets - Class in org.infinispan.context.impl
Pre-computed bitsets containing each flag.
FlagBitSets() - Constructor for class org.infinispan.context.impl.FlagBitSets
 
flags - Variable in class org.infinispan.container.entries.ReadCommittedEntry
 
flags() - Method in class org.infinispan.functional.impl.StatsEnvelope
 
flatMap(DoubleFunction<? extends DoubleStream>) - Method in interface org.infinispan.DoubleCacheStream
flatMap(DoubleFunction<? extends DoubleStream>) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
flatMap(DoubleFunction<? extends DoubleStream>) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
flatMap(DoubleFunction<? extends DoubleStream>) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
flatMap(Function<? super R, ? extends Stream<? extends R1>>) - Method in interface org.infinispan.CacheStream
flatMap(Function<? super R, ? extends Stream<? extends R1>>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
flatMap(Function<? super R, ? extends Stream<? extends R1>>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
flatMap(Function<? super R, ? extends Stream<? extends R1>>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
flatMap(Function<? super R, ? extends Stream<? extends R1>>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
flatMap(Function<? super T, ? extends Traversable<? extends R>>) - Method in interface org.infinispan.functional.Traversable
An intermediate operation that returns a traversable containing the results of replacing each element of this traversable with the contents of a traversable produced by applying the provided function to each element.
flatMap(IntFunction<? extends IntStream>) - Method in interface org.infinispan.IntCacheStream
flatMap(IntFunction<? extends IntStream>) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
flatMap(IntFunction<? extends IntStream>) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
flatMap(IntFunction<? extends IntStream>) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
flatMap(LongFunction<? extends LongStream>) - Method in interface org.infinispan.LongCacheStream
flatMap(LongFunction<? extends LongStream>) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
flatMap(LongFunction<? extends LongStream>) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
flatMap(LongFunction<? extends LongStream>) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
flatMap(SerializableDoubleFunction<? extends DoubleStream>) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleCacheStream.flatMap(DoubleFunction) except that the DoubleFunction must also implement Serializable
flatMap(SerializableDoubleFunction<? extends DoubleStream>) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
flatMap(SerializableFunction<? super R, ? extends Stream<? extends R1>>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.flatMap(Function) except that the Function must also implement Serializable
flatMap(SerializableIntFunction<? extends IntStream>) - Method in interface org.infinispan.IntCacheStream
Same as IntCacheStream.flatMap(IntFunction) except that the IntFunction must also implement Serializable
flatMap(SerializableIntFunction<? extends IntStream>) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
flatMap(SerializableLongFunction<? extends LongStream>) - Method in interface org.infinispan.LongCacheStream
Same as LongCacheStream.flatMap(LongFunction) except that the LongFunction must also implement Serializable.
flatMap(SerializableLongFunction<? extends LongStream>) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
FlatMapDoubleOperation - Class in org.infinispan.stream.impl.intops.primitive.d
Performs flat map operation on a DoubleStream
FlatMapDoubleOperation(DoubleFunction<? extends DoubleStream>) - Constructor for class org.infinispan.stream.impl.intops.primitive.d.FlatMapDoubleOperation
 
FlatMapIntOperation - Class in org.infinispan.stream.impl.intops.primitive.i
Performs flat map operation on a IntStream
FlatMapIntOperation(IntFunction<? extends IntStream>) - Constructor for class org.infinispan.stream.impl.intops.primitive.i.FlatMapIntOperation
 
FlatMapLongOperation - Class in org.infinispan.stream.impl.intops.primitive.l
Performs flat map operation on a LongStream
FlatMapLongOperation(LongFunction<? extends LongStream>) - Constructor for class org.infinispan.stream.impl.intops.primitive.l.FlatMapLongOperation
 
FlatMapOperation<I,​O> - Class in org.infinispan.stream.impl.intops.object
Performs flat map operation on a regular Stream
FlatMapOperation(Function<? super I, ? extends Stream<? extends O>>) - Constructor for class org.infinispan.stream.impl.intops.object.FlatMapOperation
 
FlatMappingOperation<InputType,​InputStream extends BaseStream<InputType,​InputStream>,​OutputType,​OutputStream extends BaseStream<OutputType,​OutputStream>> - Interface in org.infinispan.stream.impl.intops
Interface to signify that an IntermediateOperation is a flat map operation.
flatMapToDouble(Function<? super R, ? extends DoubleStream>) - Method in interface org.infinispan.CacheStream
flatMapToDouble(Function<? super R, ? extends DoubleStream>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
flatMapToDouble(Function<? super R, ? extends DoubleStream>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
flatMapToDouble(Function<? super R, ? extends DoubleStream>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
flatMapToDouble(Function<? super R, ? extends DoubleStream>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
flatMapToDouble(SerializableFunction<? super R, ? extends DoubleStream>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.flatMapToDouble(Function) except that the Function must also implement Serializable
FlatMapToDoubleOperation<I> - Class in org.infinispan.stream.impl.intops.object
Performs flat map to double operation on a regular Stream
FlatMapToDoubleOperation(Function<? super I, ? extends DoubleStream>) - Constructor for class org.infinispan.stream.impl.intops.object.FlatMapToDoubleOperation
 
flatMapToInt(Function<? super R, ? extends IntStream>) - Method in interface org.infinispan.CacheStream
flatMapToInt(Function<? super R, ? extends IntStream>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
flatMapToInt(Function<? super R, ? extends IntStream>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
flatMapToInt(Function<? super R, ? extends IntStream>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
flatMapToInt(Function<? super R, ? extends IntStream>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
flatMapToInt(SerializableFunction<? super R, ? extends IntStream>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.flatMapToInt(Function) except that the Function must also implement Serializable
FlatMapToIntOperation<I> - Class in org.infinispan.stream.impl.intops.object
Performs flat map to int operation on a regular Stream
FlatMapToIntOperation(Function<? super I, ? extends IntStream>) - Constructor for class org.infinispan.stream.impl.intops.object.FlatMapToIntOperation
 
flatMapToLong(Function<? super R, ? extends LongStream>) - Method in interface org.infinispan.CacheStream
flatMapToLong(Function<? super R, ? extends LongStream>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
flatMapToLong(Function<? super R, ? extends LongStream>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
flatMapToLong(Function<? super R, ? extends LongStream>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
flatMapToLong(Function<? super R, ? extends LongStream>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
flatMapToLong(SerializableFunction<? super R, ? extends LongStream>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.flatMapToLong(Function) except that the Function must also implement Serializable
FlatMapToLongOperation<I> - Class in org.infinispan.stream.impl.intops.object
Performs flat map to long operation on a regular Stream
FlatMapToLongOperation(Function<? super I, ? extends LongStream>) - Constructor for class org.infinispan.stream.impl.intops.object.FlatMapToLongOperation
 
FlowableFromIntSetFunction<T> - Class in org.infinispan.util.rxjava
Flowable implementation that will produce entries by providing every int in the given set to the provided IntFunction.
FlowableFromIntSetFunction(IntSet, IntFunction<T>) - Constructor for class org.infinispan.util.rxjava.FlowableFromIntSetFunction
 
flush() - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
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(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.
FLUSH_LOCK_TIMEOUT - org.infinispan.configuration.parsing.Attribute
Deprecated.
flushCache(Collection<Object>, Address, boolean) - Method in class org.infinispan.distribution.impl.L1ManagerImpl
 
flushCache(Collection<Object>, Address, boolean) - Method in interface org.infinispan.distribution.L1Manager
 
flushGlobalACLCache() - Method in interface org.infinispan.security.GlobalSecurityManager
Flushes the ACL cache for this node
flushGlobalACLCache() - Method in class org.infinispan.security.impl.GlobalSecurityManagerImpl
 
flushLockTimeout() - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
Deprecated.
flushLockTimeout(long) - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
Deprecated.
flushLockTimeout(long) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
Deprecated.
flushLockTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
Deprecated.
forCacheMode(CacheMode) - Static method in enum org.infinispan.configuration.parsing.Parser.Mode
 
FORCE_ASYNCHRONOUS - org.infinispan.context.Flag
Forces asynchronous network calls where possible, even if otherwise configured to use synchronous network calls.
FORCE_ASYNCHRONOUS - Static variable in class org.infinispan.context.impl.FlagBitSets
 
FORCE_ROLLBACK_MESSAGE - Static variable in class org.infinispan.transaction.tm.DummyTransaction
Deprecated.
 
FORCE_SYNCHRONOUS - org.infinispan.context.Flag
Forces synchronous network calls where possible, even if otherwise configured to use asynchronous network calls.
FORCE_SYNCHRONOUS - Static variable in class org.infinispan.context.impl.FlagBitSets
 
FORCE_WRITE_LOCK - org.infinispan.context.Flag
Forces a write lock, even if the invocation is a read operation.
FORCE_WRITE_LOCK - Static variable in class org.infinispan.context.impl.FlagBitSets
 
forceAvailabilityMode(String, AvailabilityMode) - Method in interface org.infinispan.topology.ClusterTopologyManager
 
forceAvailabilityMode(String, AvailabilityMode) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
forceAvailabilityMode(AvailabilityMode) - Method in class org.infinispan.topology.ClusterCacheStatus
 
forceCommit(int, byte[], byte[]) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
forceCommit(long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
forceOffline() - Method in class org.infinispan.xsite.OfflineStatus
 
forceRebalance() - Method in class org.infinispan.topology.ClusterCacheStatus
 
forceRebalance(String) - Method in interface org.infinispan.topology.ClusterTopologyManager
 
forceRebalance(String) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
forceRollback(int, byte[], byte[]) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
forceRollback(long) - 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(BiConsumer<? super K, ? super V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
forEach(BiConsumer<? super K, ? super V>) - Method in class org.infinispan.cache.impl.EncoderCache
 
forEach(BiConsumer<? super K, ? super V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
forEach(BiConsumer<String, String>) - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
 
forEach(BiConsumer<String, String>) - Method in interface org.infinispan.globalstate.ScopedPersistentState
Performs the specified action on every entry of the state
forEach(BiConsumer<Cache<K, V>, ? super CacheEntry<K, V>>) - Method in interface org.infinispan.LockedStream
Performs an action for each element of this stream on the primary owner of the given key.
forEach(BiConsumer<Cache<K, V>, ? super CacheEntry<K, V>>) - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
forEach(BiConsumer<Cache<K, V>, ? super CacheEntry<K, V>>) - Method in class org.infinispan.stream.impl.TxLockedStreamImpl
 
forEach(BiConsumer<Cache<K, V>, ? super R>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.forEach(Consumer) except that it takes a BiConsumer that provides access to the underlying Cache that is backing this stream.
forEach(BiConsumer<Cache<K, V>, ? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
forEach(BiConsumer<Cache<K, V>, ? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
forEach(BiConsumer<Cache<K, V>, ? super R>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
forEach(BiConsumer<Cache<K, V>, ? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
forEach(Consumer<? super InternalCacheEntry<K, V>>) - Method in class org.infinispan.container.impl.AbstractDelegatingDataContainer
 
forEach(Consumer<? super R>) - Method in interface org.infinispan.CacheStream
forEach(Consumer<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
forEach(Consumer<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
forEach(Consumer<? super R>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
forEach(Consumer<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
forEach(Consumer<? super R>) - Method in class org.infinispan.util.CollectionMapper
 
forEach(Consumer<? super T>) - Method in interface org.infinispan.functional.Traversable
A terminal operation that applies an operation to all elements of this traversable.
forEach(Consumer<Request<?>>) - Method in class org.infinispan.remoting.transport.impl.RequestRepository
 
forEach(DoubleConsumer) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
forEach(DoubleConsumer) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
forEach(DoubleConsumer) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
forEach(IntConsumer) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
forEach(IntConsumer) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
forEach(IntConsumer) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
forEach(LongConsumer) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
forEach(LongConsumer) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
forEach(LongConsumer) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
forEach(ObjDoubleConsumer<Cache<K, V>>) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleStream.forEach(DoubleConsumer) except that it takes an ObjDoubleConsumer that provides access to the underlying Cache that is backing this stream.
forEach(ObjDoubleConsumer<Cache<K, V>>) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
forEach(ObjDoubleConsumer<Cache<K, V>>) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
forEach(ObjDoubleConsumer<Cache<K, V>>) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
forEach(ObjIntConsumer<? super AdvancedLoadWriteStore>) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
Method that allows user to directly invoke some method(s) on the underlying store.
forEach(ObjIntConsumer<Cache<K, V>>) - Method in interface org.infinispan.IntCacheStream
Same as IntStream.forEach(IntConsumer) except that it takes an ObjIntConsumer that provides access to the underlying Cache that is backing this stream.
forEach(ObjIntConsumer<Cache<K, V>>) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
forEach(ObjIntConsumer<Cache<K, V>>) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
forEach(ObjIntConsumer<Cache<K, V>>) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
forEach(ObjLongConsumer<Cache<K, V>>) - Method in interface org.infinispan.LongCacheStream
Same as LongStream.forEach(LongConsumer) except that it takes an ObjLongConsumer that provides access to the underlying Cache that is backing this stream.
forEach(ObjLongConsumer<Cache<K, V>>) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
forEach(ObjLongConsumer<Cache<K, V>>) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
forEach(ObjLongConsumer<Cache<K, V>>) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
forEach(IntSet, Consumer<? super InternalCacheEntry<K, V>>) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
forEach(IntSet, Consumer<? super InternalCacheEntry<K, V>>) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
forEach(IntSet, Consumer<? super InternalCacheEntry<K, V>>) - Method in interface org.infinispan.container.impl.InternalDataContainer
Performs the given action for each element of the container that maps to the given set of segments until all elements have been processed or the action throws an exception.
forEach(SerializableBiConsumer<Cache<K, V>, ? super CacheEntry<K, V>>) - Method in interface org.infinispan.LockedStream
Same as LockedStream.forEach(BiConsumer) except that the BiConsumer must also implement Serializable
forEach(SerializableBiConsumer<Cache<K, V>, ? super R>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.forEach(BiConsumer) except that the BiConsumer must also implement Serializable
forEach(SerializableConsumer<? super R>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.forEach(Consumer) except that the Consumer must also implement Serializable
forEach(SerializableDoubleConsumer) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleStream.forEach(DoubleConsumer) except that the DoubleConsumer must also implement Serializable
forEach(SerializableDoubleConsumer) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
forEach(SerializableIntConsumer) - Method in interface org.infinispan.IntCacheStream
Same as IntStream.forEach(IntConsumer) except that the IntConsumer must also implement Serializable
forEach(SerializableIntConsumer) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
forEach(SerializableLongConsumer) - Method in interface org.infinispan.LongCacheStream
Same as LongStream.forEach(LongConsumer) except that the LongConsumer must also implement Serializable.
forEach(SerializableLongConsumer) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
forEach(SerializableObjDoubleConsumer<Cache<K, V>>) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleCacheStream.forEach(ObjDoubleConsumer) except that the BiConsumer must also implement Serializable
forEach(SerializableObjDoubleConsumer<Cache<K, V>>) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
forEach(SerializableObjIntConsumer<Cache<K, V>>) - Method in interface org.infinispan.IntCacheStream
Same as IntCacheStream.forEach(ObjIntConsumer) except that the BiConsumer must also implement Serializable
forEach(SerializableObjIntConsumer<Cache<K, V>>) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
forEach(SerializableObjLongConsumer<Cache<K, V>>) - Method in interface org.infinispan.LongCacheStream
Same as LongCacheStream.forEach(ObjLongConsumer) except that the BiConsumer must also implement Serializable
forEach(SerializableObjLongConsumer<Cache<K, V>>) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
forEachBackupLock(Consumer<Object>) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
forEachBackupLock(Consumer<Object>) - Method in interface org.infinispan.transaction.xa.CacheTransaction
Invokes the Consumer with each backup lock.
ForEachBiOperation<Original,​K,​V> - Class in org.infinispan.stream.impl.termop.object
Terminal operation that handles for each where no map operations are defined
ForEachBiOperation(Iterable<IntermediateOperation>, Supplier<Stream<Original>>, Function<? super Original, ? extends K>, int, BiConsumer<Cache<K, ?>, ? super V>) - Constructor for class org.infinispan.stream.impl.termop.object.ForEachBiOperation
 
ForEachDoubleOperation<Original,​K> - Class in org.infinispan.stream.impl.termop.primitive
Terminal rehash aware operation that handles for each where no flat map operations are defined on a DoubleStream.
ForEachDoubleOperation(Iterable<IntermediateOperation>, Supplier<Stream<Original>>, Function<? super Original, ? extends K>, int, DoubleConsumer) - Constructor for class org.infinispan.stream.impl.termop.primitive.ForEachDoubleOperation
 
forEachEntry(BiConsumer<Object, CacheEntry>) - Method in interface org.infinispan.context.EntryLookup
Execute an action for each entry in the context.
forEachEntry(BiConsumer<Object, CacheEntry>) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
forEachEntry(BiConsumer<Object, CacheEntry>) - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
Deprecated.
 
ForEachFlatMapDoubleOperation<Original,​K> - Class in org.infinispan.stream.impl.termop.primitive
Terminal rehash aware operation that handles for each where flat map operation is performed on a DoubleStream.
ForEachFlatMapDoubleOperation(Iterable<IntermediateOperation>, Supplier<Stream<Original>>, Function<? super Original, ? extends K>, int, DoubleConsumer) - Constructor for class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapDoubleOperation
 
ForEachFlatMapIntOperation<Original,​K> - Class in org.infinispan.stream.impl.termop.primitive
Terminal rehash aware operation that handles for each where flat map operation is performed on a IntStream.
ForEachFlatMapIntOperation(Iterable<IntermediateOperation>, Supplier<Stream<Original>>, Function<? super Original, ? extends K>, int, IntConsumer) - Constructor for class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapIntOperation
 
ForEachFlatMapLongOperation<Original,​K> - Class in org.infinispan.stream.impl.termop.primitive
Terminal rehash aware operation that handles for each where flat map operation is performed on a LongStream.
ForEachFlatMapLongOperation(Iterable<IntermediateOperation>, Supplier<Stream<Original>>, Function<? super Original, ? extends K>, int, LongConsumer) - Constructor for class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapLongOperation
 
ForEachFlatMapObjDoubleOperation<Original,​K> - Class in org.infinispan.stream.impl.termop.primitive
Terminal rehash aware operation that handles for each where flat map operation is performed on a DoubleStream.
ForEachFlatMapObjDoubleOperation(Iterable<IntermediateOperation>, Supplier<Stream<Original>>, Function<? super Original, ? extends K>, int, ObjDoubleConsumer<Cache<K, ?>>) - Constructor for class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapObjDoubleOperation
 
ForEachFlatMapObjIntOperation<Original,​K> - Class in org.infinispan.stream.impl.termop.primitive
Terminal rehash aware operation that handles for each where flat map operation is performed on a IntStream.
ForEachFlatMapObjIntOperation(Iterable<IntermediateOperation>, Supplier<Stream<Original>>, Function<? super Original, ? extends K>, int, ObjIntConsumer<Cache<K, ?>>) - Constructor for class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapObjIntOperation
 
ForEachFlatMapObjLongOperation<Original,​K> - Class in org.infinispan.stream.impl.termop.primitive
Terminal rehash aware operation that handles for each where flat map operation is performed on a LongStream.
ForEachFlatMapObjLongOperation(Iterable<IntermediateOperation>, Supplier<Stream<Original>>, Function<? super Original, ? extends K>, int, ObjLongConsumer<Cache<K, ?>>) - Constructor for class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapObjLongOperation
 
forEachIncludingExpired(ObjIntConsumer<? super InternalCacheEntry<K, V>>) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
forEachIncludingExpired(ObjIntConsumer<? super InternalCacheEntry<K, V>>) - Method in class org.infinispan.container.impl.DefaultDataContainer
 
forEachIncludingExpired(ObjIntConsumer<? super InternalCacheEntry<K, V>>) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
forEachIncludingExpired(ObjIntConsumer<? super InternalCacheEntry<K, V>>) - Method in interface org.infinispan.container.impl.InternalDataContainer
Performs the given action for each element of the container, even if expired.
forEachIncludingExpired(ObjIntConsumer<? super InternalCacheEntry<K, V>>) - Method in class org.infinispan.container.impl.InternalDataContainerAdapter
 
forEachIncludingExpired(ObjIntConsumer<? super InternalCacheEntry<WrappedBytes, WrappedBytes>>) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
ForEachIntOperation<Original,​K> - Class in org.infinispan.stream.impl.termop.primitive
Terminal rehash aware operation that handles for each where no flat map operations are defined on a IntStream.
ForEachIntOperation(Iterable<IntermediateOperation>, Supplier<Stream<Original>>, Function<? super Original, ? extends K>, int, IntConsumer) - Constructor for class org.infinispan.stream.impl.termop.primitive.ForEachIntOperation
 
ForEachLongOperation<Original,​K> - Class in org.infinispan.stream.impl.termop.primitive
Terminal rehash aware operation that handles for each where no flat map operations are defined on a LongStream.
ForEachLongOperation(Iterable<IntermediateOperation>, Supplier<Stream<Original>>, Function<? super Original, ? extends K>, int, LongConsumer) - Constructor for class org.infinispan.stream.impl.termop.primitive.ForEachLongOperation
 
ForEachObjDoubleOperation<Original,​K> - Class in org.infinispan.stream.impl.termop.primitive
Terminal rehash aware operation that handles for each where no flat map operations are defined on a DoubleStream.
ForEachObjDoubleOperation(Iterable<IntermediateOperation>, Supplier<Stream<Original>>, Function<? super Original, ? extends K>, int, ObjDoubleConsumer<Cache<K, ?>>) - Constructor for class org.infinispan.stream.impl.termop.primitive.ForEachObjDoubleOperation
 
ForEachObjIntOperation<Original,​K> - Class in org.infinispan.stream.impl.termop.primitive
Terminal rehash aware operation that handles for each where no flat map operations are defined on a IntStream.
ForEachObjIntOperation(Iterable<IntermediateOperation>, Supplier<Stream<Original>>, Function<? super Original, ? extends K>, int, ObjIntConsumer<Cache<K, ?>>) - Constructor for class org.infinispan.stream.impl.termop.primitive.ForEachObjIntOperation
 
ForEachObjLongOperation<Original,​K> - Class in org.infinispan.stream.impl.termop.primitive
Terminal rehash aware operation that handles for each where no flat map operations are defined on a LongStream.
ForEachObjLongOperation(Iterable<IntermediateOperation>, Supplier<Stream<Original>>, Function<? super Original, ? extends K>, int, ObjLongConsumer<Cache<K, ?>>) - Constructor for class org.infinispan.stream.impl.termop.primitive.ForEachObjLongOperation
 
ForEachOperation<Original,​K,​V> - Class in org.infinispan.stream.impl.termop.object
Terminal operation that handles for each where no map operations are defined
ForEachOperation(Iterable<IntermediateOperation>, Supplier<Stream<Original>>, Function<? super Original, ? extends K>, int, Consumer<? super V>) - Constructor for class org.infinispan.stream.impl.termop.object.ForEachOperation
 
forEachOrdered(Consumer<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
forEachOrdered(Consumer<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
forEachOrdered(Consumer<? super R>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
forEachOrdered(Consumer<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
forEachOrdered(DoubleConsumer) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
forEachOrdered(DoubleConsumer) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
forEachOrdered(DoubleConsumer) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
forEachOrdered(IntConsumer) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
forEachOrdered(IntConsumer) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
forEachOrdered(IntConsumer) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
forEachOrdered(LongConsumer) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
forEachOrdered(LongConsumer) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
forEachOrdered(LongConsumer) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
forEachRemaining(Consumer<? super E>) - Method in class org.infinispan.util.CloseableSuppliedIterator
 
forEachRemaining(Consumer<? super T>) - Method in class org.infinispan.stream.impl.spliterators.IteratorAsSpliterator
 
forEachValue(BiConsumer<Object, CacheEntry>) - Method in interface org.infinispan.context.EntryLookup
Execute an action for each value in the context.
foreignExternalizerUsingNegativeId(AdvancedExternalizer<?>, int) - Method in class org.infinispan.util.logging.Log_$logger
 
foreignExternalizerUsingNegativeId(AdvancedExternalizer<?>, int) - Method in interface org.infinispan.util.logging.Log
 
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
 
forgetOperation(Object) - Method in interface org.infinispan.stream.impl.ClusterStreamManager
Frees any resources related to this operation and signals to any ongoing remote operations to no longer continue processing
forgetOperation(Object) - Method in class org.infinispan.stream.impl.ClusterStreamManagerImpl
 
forgetOperation(Object) - Method in class org.infinispan.stream.impl.tx.TxClusterStreamManager
 
format() - Method in interface org.infinispan.filter.KeyValueFilter
 
format() - Method in interface org.infinispan.notifications.cachelistener.filter.CacheEventConverter
 
format() - Method in interface org.infinispan.notifications.cachelistener.filter.CacheEventFilter
 
format() - Method in interface org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverter
 
format(Thread, String) - Method in class org.infinispan.factories.threads.ThreadNameInfo
Format the thread name string.
format(Configuration) - Method in class org.infinispan.configuration.format.PropertyFormatter
 
format(GlobalConfiguration) - Method in class org.infinispan.configuration.format.PropertyFormatter
 
forName(String) - Static method in enum org.infinispan.configuration.parsing.Attribute
 
forName(String) - Static method in enum org.infinispan.configuration.parsing.Element
 
forwardCommandIfNeeded(TopologyAffectedCommand, Set<Object>, Address) - 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) - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
ForwardingCacheEntry<K,​V> - Class in org.infinispan.container.entries
A class designed to forward all method invocations for a CacheEntry to the provided delegate.
ForwardingCacheEntry() - Constructor for class org.infinispan.container.entries.ForwardingCacheEntry
 
FOUR_PHASE - org.infinispan.statetransfer.RebalanceType
Used by distributed and replicated caches.
FRAGMENTATION_FACTOR - org.infinispan.configuration.parsing.Attribute
 
FRAGMENTATION_FACTOR - Static variable in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
 
fragmentationFactor() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
 
fragmentationFactor(float) - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
The store tries to fit in a new entry into an existing entry from a free entry pool (if one is available) However, this existing free entry may be quite bigger than what is required to contain the new entry It may then make sense to split the free entry into two parts: 1.
freezeModifications() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
freezeModifications() - Method in interface org.infinispan.transaction.xa.CacheTransaction
Prevent new modifications after prepare or commit started.
friendlyCacheModeString() - Method in enum org.infinispan.configuration.cache.CacheMode
 
from(CacheMode) - Static method in enum org.infinispan.statetransfer.RebalanceType
 
from(MetaParams) - Static method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
 
from(Param<?>...) - Static method in class org.infinispan.functional.impl.Params
 
fromCacheLoader(MarshalledEntry) - Static method in class org.infinispan.xsite.statetransfer.XSiteState
 
fromConfiguration(EntryMergePolicy) - Static method in enum org.infinispan.conflict.MergePolicy
 
fromConfiguration(TransactionMode, boolean, boolean, boolean) - Static method in enum org.infinispan.configuration.parsing.Parser.TransactionMode
 
fromDataContainer(InternalCacheEntry) - Static method in class org.infinispan.xsite.statetransfer.XSiteState
 
fromEvent(CacheEntryEvent<K, V>) - Static method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
fromFlagsBitSet(long) - Static method in class org.infinispan.functional.impl.Params
 
fromJGroupsAddress(Address) - Static method in class org.infinispan.remoting.transport.jgroups.JGroupsAddressCache
 
fromMemory(long) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
Create an entry from the off heap pointer
fromMemory(long) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
Assumes the address doesn't contain the linked pointer at the beginning
fromNamespaceURI(String) - Static method in class org.infinispan.configuration.parsing.Schema
 
fromNewTypeFunction - Variable in class org.infinispan.util.WriteableCacheCollectionMapper
 
fromPersistentState(ScopedPersistentState) - Method in interface org.infinispan.distribution.ch.ConsistentHashFactory
Recreates a ConsistentHash from a previously stored persistent state.
fromPersistentState(ScopedPersistentState) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
 
fromPersistentState(ScopedPersistentState) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory
 
fromPersistentState(ScopedPersistentState) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory
 
fromPersistentState(ScopedPersistentState) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory
 
fromPersistentState(ScopedPersistentState) - Method in class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory
 
fromStorage(Object) - Method in class org.infinispan.encoding.DataConversion
 
fromStream(byte) - Method in interface org.infinispan.commands.module.ModuleCommandFactory
Construct and initialize a ReplicableCommand based on the command id.
fromStream(byte, byte) - Method in class org.infinispan.commands.RemoteCommandsFactory
Creates an un-initialized command.
fromStream(byte, byte, ByteString) - Method in class org.infinispan.commands.RemoteCommandsFactory
Resolve an CacheRpcCommand from the stream.
fromStream(byte, byte, ByteString) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
fromStream(byte, ByteString) - Method in interface org.infinispan.commands.module.ModuleCommandFactory
Construct and initialize a CacheRpcCommand based on the command id.
fromString(String) - Static method in enum org.infinispan.conflict.MergePolicy
 
fromString(String) - Static method in class org.infinispan.topology.PersistentUUID
 
fromString(String) - Static method in class org.infinispan.util.ByteString
 
FULL_XA - org.infinispan.configuration.cache.TransactionMode
 
FULL_XA - org.infinispan.configuration.parsing.Parser.TransactionMode
 
function(Converter<? super K, ? super V, C>) - Static method in class org.infinispan.filter.CacheFilters
Creates a new Function using the provided converter as a basis for the operation.
FunctionalCommand<K,​V> - Interface in org.infinispan.commands.functional
A command that carries operation rather than final value.
FunctionalMap<K,​V> - Interface in org.infinispan.functional
Top level functional map interface offering common functionality for the read-only, read-write, and write-only operations that can be run against a functional map asynchronously.
FunctionalMap.ReadOnlyMap<K,​V> - Interface in org.infinispan.functional
Exposes read-only operations that can be executed against the functional map.
FunctionalMap.ReadWriteMap<K,​V> - Interface in org.infinispan.functional
Exposes read-write operations that can be executed against the functional map.
FunctionalMap.WriteOnlyMap<K,​V> - Interface in org.infinispan.functional
Exposes write-only operations that can be executed against the functional map.
FunctionalMapImpl<K,​V> - Class in org.infinispan.functional.impl
Functional map implementation.
functionalNotifier - Variable in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
functionalNotifier - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
FunctionalNotifier<K,​V> - Interface in org.infinispan.functional.impl
Listener notifier.
FunctionalNotifierImpl<K,​V> - Class in org.infinispan.functional.impl
 
FunctionalNotifierImpl() - Constructor for class org.infinispan.functional.impl.FunctionalNotifierImpl
 
FunctionExternalizer() - Constructor for class org.infinispan.atomic.impl.AtomicKeySetImpl.FunctionExternalizer
 
FunctionMapper - Class in org.infinispan.compat
 
FunctionMapper(Function, DataConversion, DataConversion) - Constructor for class org.infinispan.compat.FunctionMapper
 
FunctionMapper.Externalizer - Class in org.infinispan.compat
 
future - Variable in class org.infinispan.interceptors.impl.SimpleAsyncInvocationStage
 

G

GATHER - org.infinispan.functional.Param.StatisticsMode
Statistics from this command are recorded
generateId(Address) - Static method in class org.infinispan.commands.CommandInvocationId
 
generateIdFrom(CommandInvocationId) - Static method in class org.infinispan.commands.CommandInvocationId
 
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
 
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() - Method in interface org.infinispan.functional.EntryView.ReadEntryView
Returns a non-null value if the key has a value associated with it or throws NoSuchElementException if no value is associated with the entry.
get() - Method in interface org.infinispan.functional.MetaParam
Returns the value of the meta parameter.
get() - Method in class org.infinispan.functional.MetaParam.MetaEntryVersion
 
get() - Method in class org.infinispan.functional.MetaParam.MetaLoadedFromPersistence
 
get() - Method in class org.infinispan.functional.MetaParam.MetaLong
 
get() - Method in enum org.infinispan.functional.Param.ExecutionMode
 
get() - Method in interface org.infinispan.functional.Param
Parameter's value.
get() - Method in enum org.infinispan.functional.Param.LockingMode
 
get() - Method in enum org.infinispan.functional.Param.PersistenceMode
 
get() - Method in enum org.infinispan.functional.Param.ReplicationMode
 
get() - Method in enum org.infinispan.functional.Param.StatisticsMode
 
get() - Method in class org.infinispan.interceptors.distribution.L1WriteSynchronizer
 
get() - Method in class org.infinispan.interceptors.impl.SimpleAsyncInvocationStage
 
get() - Method in class org.infinispan.interceptors.InvocationStage
Wait for the invocation to complete and return its value.
get() - Method in class org.infinispan.interceptors.SyncInvocationStage
 
get() - Method in class org.infinispan.persistence.util.PersistenceManagerCloseableSupplier
Deprecated.
 
get() - Method in class org.infinispan.stream.impl.spliterators.IteratorAsSpliterator.Builder
 
get(int) - Method in class org.infinispan.functional.impl.Params
Retrieve a param given its identifier.
get(int, Object) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
get(int, Object) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
get(int, Object) - Method in interface org.infinispan.container.impl.InternalDataContainer
Same as DataContainer.get(Object) except that the segment of the key can provided to lookup entries without calculating the segment for the given key
get(int, Object) - Method in class org.infinispan.container.impl.InternalDataContainerAdapter
 
get(long, TimeUnit) - Method in class org.infinispan.interceptors.distribution.L1WriteSynchronizer
 
get(Object) - Method in class org.infinispan.atomic.impl.AtomicMapProxyImpl
 
get(Object) - Method in class org.infinispan.atomic.impl.FineGrainedAtomicMapProxyImpl
 
get(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
get(Object) - Method in class org.infinispan.cache.impl.CacheImpl
 
get(Object) - Method in class org.infinispan.cache.impl.DecoratedCache
 
get(Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
get(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
get(Object) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
get(Object) - Method in interface org.infinispan.container.DataContainer
Retrieves a cached entry
get(Object) - Method in class org.infinispan.container.impl.AbstractDelegatingDataContainer
 
get(Object) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
get(Object) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
get(Object) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
get(Object) - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
 
get(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
get(String, String) - Method in class org.infinispan.xsite.BackupReceiverRepositoryImpl
 
get(AdvancedCache<K, V>) - Static method in class org.infinispan.conflict.ConflictManagerFactory
 
GET_CACHE_LISTENERS - org.infinispan.statetransfer.StateRequestCommand.Type
 
GET_STATUS - org.infinispan.topology.CacheTopologyControlCommand.Type
 
GET_TRANSACTIONS - org.infinispan.statetransfer.StateRequestCommand.Type
 
getAbsoluteFile() - Method in class org.infinispan.io.GridFile
 
getAbsolutePath() - Method in class org.infinispan.io.GridFile
 
getActions() - Method in class org.infinispan.security.CachePermission
 
getActivationCount() - Method in interface org.infinispan.eviction.ActivationManager
Get number of activations executed.
getActivationCount() - Method in class org.infinispan.eviction.impl.ActivationManagerImpl
 
getActivationCount() - Method in class org.infinispan.eviction.impl.ActivationManagerStub
 
getActivations() - Method in class org.infinispan.eviction.impl.ActivationManagerImpl
 
getActivations() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getActivations() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getActiveCount() - Method in class org.infinispan.executors.ManageableExecutorService
 
getActualAddressCount(int) - Static method in class org.infinispan.container.offheap.OffHeapDataContainer
 
getActualMembers() - Method in class org.infinispan.topology.CacheTopology
 
getActualNumOwners() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
getAddress() - Method in class org.infinispan.commands.CommandInvocationId
 
getAddress() - Method in class org.infinispan.container.entries.RemoteMetadata
 
getAddress() - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
getAddress() - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
 
getAddress() - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
 
getAddress() - Method in class org.infinispan.manager.DefaultCacheManager
Warning: the address may be null before the first clustered cache starts and after all the clustered caches have been stopped.
getAddress() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Warning: the address may be null before the first clustered cache starts and after all the clustered caches have been stopped.
getAddress() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
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
 
getAddress(PersistentUUID) - Method in interface org.infinispan.topology.PersistentUUIDManager
Retrieves the Address of a node given its PersistentUUID
getAddress(PersistentUUID) - Method in class org.infinispan.topology.PersistentUUIDManagerImpl
 
getAddress2KeysMapping() - Method in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
 
getAdvancedCache() - Method in interface org.infinispan.Cache
 
getAdvancedCache() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getAdvancedCache() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getAdvancedCache() - Method in class org.infinispan.cache.impl.CacheImpl
 
getAdvancedCache() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getAdvancedCache() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getAffectedKeys() - Method in class org.infinispan.commands.functional.ReadWriteManyCommand
 
getAffectedKeys() - Method in class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
getAffectedKeys() - Method in class org.infinispan.commands.functional.WriteOnlyManyCommand
 
getAffectedKeys() - Method in class org.infinispan.commands.functional.WriteOnlyManyEntriesCommand
 
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.InvalidateCommand
 
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.persistence.support.BatchModification
 
getAffectedKeys() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getAffinitySegmentId() - Method in interface org.infinispan.distribution.ch.AffinityTaggedKey
This numeric id is used exclusively for storage affinity in Infinispan.
getAll(Set<?>) - Method in interface org.infinispan.AdvancedCache
Gets a collection of entries, returning them as Map of the values associated with the set of keys requested.
getAll(Set<?>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getAll(Set<?>) - Method in class org.infinispan.cache.impl.CacheImpl
 
getAll(Set<?>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
getAll(Set<?>) - Method in class org.infinispan.cache.impl.EncoderCache
 
getAll(Set<?>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getAll(Set<?>) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
getAll(Set<?>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getAllAsync(Set<?>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getAllAsync(Set<?>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getAllAsync(Set<?>) - Method in class org.infinispan.cache.impl.CacheImpl
 
getAllAsync(Set<?>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
getAllAsync(Set<?>) - Method in class org.infinispan.cache.impl.EncoderCache
 
getAllAsync(Set<?>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getAllAsync(Set<?>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getAllCacheEntries(Set<?>) - Method in interface org.infinispan.AdvancedCache
Gets a collection of entries from the AdvancedCache, returning them as Map of the cache entries associated with the set of keys requested.
getAllCacheEntries(Set<?>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getAllCacheEntries(Set<?>) - Method in class org.infinispan.cache.impl.CacheImpl
 
getAllCacheEntries(Set<?>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
getAllCacheEntries(Set<?>) - Method in class org.infinispan.cache.impl.EncoderCache
 
getAllCacheEntries(Set<?>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getAllCacheEntries(Set<?>) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
getAllCacheEntries(Set<?>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getAllCacheEntries(Set<?>, long, InvocationContext) - Method in class org.infinispan.cache.impl.CacheImpl
 
GetAllCommand - Class in org.infinispan.commands.read
Retrieves multiple entries at once.
GetAllCommand(Collection<?>, long, boolean, InternalEntryFactory) - Constructor for class org.infinispan.commands.read.GetAllCommand
 
getAllLoaders() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
getAllMachinesCount() - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getAllModifications() - Method in class org.infinispan.transaction.impl.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
 
getAllocatedAmount() - Method in interface org.infinispan.container.offheap.OffHeapMemoryAllocator
 
getAllocatedAmount() - Method in class org.infinispan.container.offheap.UnpooledOffHeapMemoryAllocator
 
getAllowedMethodAnnotations(Listener) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
getAllowedMethodAnnotations(Listener) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
getAllowedMethodAnnotations(Listener) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
 
getAllRacksCount() - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getAllReplicasForSegment(int, LocalizedCacheTopology, long) - Method in interface org.infinispan.conflict.impl.StateReceiver
Return all replicas of a cache entry for a given segment.
getAllReplicasForSegment(int, LocalizedCacheTopology, long) - Method in class org.infinispan.conflict.impl.StateReceiverImpl
 
getAllSites() - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getAllSitesCount() - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getAllTxWriters() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
getAllVersions(K) - Method in interface org.infinispan.conflict.ConflictManager
Get all CacheEntry's that exists for a given key.
getAllVersions(K) - Method in class org.infinispan.conflict.impl.DefaultConflictManager
 
getAllWriters() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
getAndPutAll(Map<? extends K, ? extends V>) - Method in interface org.infinispan.AdvancedCache
Executes an equivalent of Map.putAll(Map), returning previous values of the modified entries.
getAndPutAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getAndPutAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.CacheImpl
 
getAndPutAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
getAndPutAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getAndPutInternal(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getAndPutInternal(K, V, Metadata) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
getAndReplaceInternal(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getAndReplaceInternal(K, V, Metadata) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
getAndUpdateFilteredKeys(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.BaseLockingAction
 
getAnnotation() - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
 
getAnnotation() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
getAnnotation() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
getArgument() - Method in class org.infinispan.commands.functional.ReadWriteKeyValueCommand
 
getArgument() - Method in class org.infinispan.commands.functional.WriteOnlyKeyValueCommand
 
getArguments() - Method in class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
getArguments() - Method in class org.infinispan.commands.functional.WriteOnlyManyEntriesCommand
 
getAsync(K) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getAsync(K) - Method in class org.infinispan.cache.impl.CacheImpl
 
getAsync(K) - Method in class org.infinispan.cache.impl.DecoratedCache
 
getAsync(K) - Method in class org.infinispan.cache.impl.EncoderCache
 
getAsync(K) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getAsync(K) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getAsyncInterceptorChain() - Method in interface org.infinispan.AdvancedCache
Allows the modification of the interceptor chain.
getAsyncInterceptorChain() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getAsyncInterceptorChain() - Method in class org.infinispan.cache.impl.CacheImpl
 
getAsyncInterceptorChain() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getAsyncInterceptorChain() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getAsyncXSiteCount() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getAsyncXSiteRequestsReceived() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
 
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
 
getAttributes(String[]) - Method in class org.infinispan.jmx.ResourceDMBean
 
getAuthorizationManager() - Method in interface org.infinispan.AdvancedCache
Retrieves the AuthorizationManager if the cache has security enabled.
getAuthorizationManager() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getAuthorizationManager() - Method in class org.infinispan.cache.impl.CacheImpl
 
getAuthorizationManager() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getAuthorizationManager() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getAuthorizationPermission() - Method in class org.infinispan.security.CachePermission
 
getAvailability() - Method in interface org.infinispan.AdvancedCache
Returns the cache's availability.
getAvailability() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getAvailability() - Method in class org.infinispan.cache.impl.CacheImpl
 
getAvailability() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getAvailability() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getAvailabilityMode() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getAvailabilityMode() - Method in interface org.infinispan.notifications.cachelistener.event.PartitionStatusChangedEvent
The mode the current cluster is in.
getAvailabilityMode() - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
 
getAvailabilityMode() - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
getAvailabilityMode() - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
 
getAvailabilityMode() - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
getAvailabilityMode() - Method in class org.infinispan.topology.CacheStatusResponse
 
getAvailabilityMode() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
getAvailabilityMode() - Method in class org.infinispan.topology.ClusterCacheStatus
 
getAverageReadTime() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
getAverageReadTime() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getAverageReadTime() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getAverageReadTime() - Method in class org.infinispan.stats.impl.StatsCollector
 
getAverageReadTime() - Method in class org.infinispan.stats.impl.StatsImpl
 
getAverageReadTime() - Method in interface org.infinispan.stats.Stats
 
getAverageReadTimeNanos() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
getAverageReadTimeNanos() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getAverageReadTimeNanos() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getAverageReadTimeNanos() - Method in class org.infinispan.stats.impl.StatsCollector
 
getAverageReadTimeNanos() - Method in class org.infinispan.stats.impl.StatsImpl
 
getAverageReadTimeNanos() - Method in interface org.infinispan.stats.Stats
 
getAverageRemoveTime() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
getAverageRemoveTime() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getAverageRemoveTime() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getAverageRemoveTime() - Method in class org.infinispan.stats.impl.StatsCollector
 
getAverageRemoveTime() - Method in class org.infinispan.stats.impl.StatsImpl
 
getAverageRemoveTime() - Method in interface org.infinispan.stats.Stats
 
getAverageRemoveTimeNanos() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
getAverageRemoveTimeNanos() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getAverageRemoveTimeNanos() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getAverageRemoveTimeNanos() - Method in class org.infinispan.stats.impl.StatsCollector
 
getAverageRemoveTimeNanos() - Method in class org.infinispan.stats.impl.StatsImpl
 
getAverageRemoveTimeNanos() - Method in interface org.infinispan.stats.Stats
 
getAverageReplicationTime() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getAverageWriteTime() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
getAverageWriteTime() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getAverageWriteTime() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getAverageWriteTime() - Method in class org.infinispan.stats.impl.StatsCollector
 
getAverageWriteTime() - Method in class org.infinispan.stats.impl.StatsImpl
 
getAverageWriteTime() - Method in interface org.infinispan.stats.Stats
 
getAverageWriteTimeNanos() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
getAverageWriteTimeNanos() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getAverageWriteTimeNanos() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getAverageWriteTimeNanos() - Method in class org.infinispan.stats.impl.StatsCollector
 
getAverageWriteTimeNanos() - Method in class org.infinispan.stats.impl.StatsImpl
 
getAverageWriteTimeNanos() - Method in interface org.infinispan.stats.Stats
 
getAverageXSiteReplicationTime() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getBackupLockedKeys() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getBackupLockedKeys() - Method in interface org.infinispan.transaction.xa.CacheTransaction
Deprecated.
getBackupOwners(int) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
getBackupReceiver(String, String) - Method in interface org.infinispan.xsite.BackupReceiverRepository
Returns the local cache associated defined as backup for the provided remote (site, cache) combo, or throws an exception if no such site is defined.
getBackupReceiver(String, String) - Method in class org.infinispan.xsite.BackupReceiverRepositoryImpl
Returns the local cache defined as backup for the provided remote (site, cache) combo, or throws an exception if no such site is defined.
getBatchContainer() - Method in interface org.infinispan.AdvancedCache
Returns the component in charge of batching cache operations.
getBatchContainer() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getBatchContainer() - Method in class org.infinispan.cache.impl.CacheImpl
 
getBatchContainer() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getBatchContainer() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getBatchSize() - Method in class org.infinispan.stream.impl.termop.AbstractForEachOperation
 
getBatchSize() - Method in class org.infinispan.stream.impl.termop.primitive.AbstractForEachDoubleOperation
 
getBatchSize() - Method in class org.infinispan.stream.impl.termop.primitive.AbstractForEachIntOperation
 
getBatchSize() - Method in class org.infinispan.stream.impl.termop.primitive.AbstractForEachLongOperation
 
getBatchTransaction() - Method in class org.infinispan.batch.BatchContainer
 
getBiConsumer() - Method in class org.infinispan.commands.functional.WriteOnlyKeyValueCommand
 
getBiConsumer() - Method in class org.infinispan.commands.functional.WriteOnlyManyEntriesCommand
 
getBiFunction() - Method in class org.infinispan.commands.functional.ReadWriteKeyValueCommand
 
getBiFunction() - Method in class org.infinispan.commands.functional.ReadWriteManyCommand
 
getBiFunction() - Method in class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
getBlockingFuture(int) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
getBlockingFuture(int) - Method in interface org.infinispan.scattered.ScatteredVersionManager
 
getBranchQualifier() - Method in class org.infinispan.transaction.tm.DummyNoXaXid
Deprecated.
 
getBranchQualifier() - Method in class org.infinispan.transaction.tm.DummyXid
Deprecated.
 
getBranchQualifier() - Method in class org.infinispan.transaction.xa.recovery.SerializableXid
Deprecated.
 
getBrandName() - Static method in class org.infinispan.Version
 
getBufferSizePredictor(Object) - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
getByteBufferFactory() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getByteBufferFactory() - Method in interface org.infinispan.persistence.spi.InitializationContext
To be used for building ByteBuffer objects.
getCache() - Method in interface org.infinispan.manager.CacheContainer
This method overrides the underlying CacheContainer.getCache(), 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() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getCache() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
getCache() - Method in interface org.infinispan.notifications.cachelistener.event.Event
 
getCache() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getCache() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getCache() - Method in interface org.infinispan.persistence.spi.InitializationContext
 
getCache() - Method in interface org.infinispan.xsite.BackupReceiver
 
getCache() - Method in class org.infinispan.xsite.BaseBackupReceiver
 
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(String) - Method in class org.infinispan.manager.DefaultCacheManager
Retrieves a named cache from the system.
getCache(String) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
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(String, boolean) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getCache(String, String) - Method in class org.infinispan.manager.DefaultCacheManager
 
getCache(String, String) - Method in interface org.infinispan.manager.EmbeddedCacheManager
getCache(String, String) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getCache(String, String, boolean) - Method in class org.infinispan.manager.DefaultCacheManager
 
getCache(String, String, boolean) - Method in interface org.infinispan.manager.EmbeddedCacheManager
getCache(String, String, boolean) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
GetCacheAction - Class in org.infinispan.security.actions
GetCacheAction.
GetCacheAction(EmbeddedCacheManager, String) - Constructor for class org.infinispan.security.actions.GetCacheAction
 
GetCacheAuthorizationManagerAction - Class in org.infinispan.security.actions
GetCacheAuthorizationManagerAction.
GetCacheAuthorizationManagerAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetCacheAuthorizationManagerAction
 
getCacheAvailability() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getCacheAvailability() - Method in class org.infinispan.cache.impl.CacheImpl
 
getCacheAvailability(String) - Method in interface org.infinispan.topology.LocalTopologyManager
Retrieves the availability state of a cache.
getCacheAvailability(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
getCacheAvailability(String) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
GetCacheAvailabilityAction - Class in org.infinispan.security.actions
GetCacheAvailabilityAction.
GetCacheAvailabilityAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetCacheAvailabilityAction
 
GetCacheComponentRegistryAction - Class in org.infinispan.security.actions
GetCacheComponentRegistryAction.
GetCacheComponentRegistryAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetCacheComponentRegistryAction
 
getCacheConfiguration() - Method in interface org.infinispan.Cache
 
getCacheConfiguration() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getCacheConfiguration() - Method in class org.infinispan.cache.impl.CacheImpl
 
getCacheConfiguration() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getCacheConfiguration() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
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.
getCacheConfiguration(String) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
GetCacheConfigurationAction - Class in org.infinispan.security.actions
GetCacheConfigurationAction.
GetCacheConfigurationAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetCacheConfigurationAction
 
getCacheConfigurationNames() - Method in class org.infinispan.manager.DefaultCacheManager
 
getCacheConfigurationNames() - Method in interface org.infinispan.manager.EmbeddedCacheManager
This method returns a collection of cache configuration names which contains the cache configurations that have been defined via XML or programmatically, and the cache configurations that have been defined at runtime via this cache manager instance.
getCacheConfigurationNames() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
GetCacheDistributionManagerAction - Class in org.infinispan.security.actions
GetCacheDistributionManagerAction.
GetCacheDistributionManagerAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetCacheDistributionManagerAction
 
getCacheEntries() - Method in class org.infinispan.statetransfer.StateChunk
 
getCacheEntry() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
Deprecated.
 
getCacheEntry(Object) - Method in interface org.infinispan.AdvancedCache
Retrieves a CacheEntry corresponding to a specific key.
getCacheEntry(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getCacheEntry(Object) - Method in class org.infinispan.cache.impl.CacheImpl
 
getCacheEntry(Object) - Method in class org.infinispan.cache.impl.DecoratedCache
 
getCacheEntry(Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
getCacheEntry(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getCacheEntry(Object) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
getCacheEntry(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
GetCacheEntryAction<K,​V> - Class in org.infinispan.security.actions
GetCacheEntryAction.
GetCacheEntryAction(AdvancedCache<?, ?>, K) - Constructor for class org.infinispan.security.actions.GetCacheEntryAction
 
getCacheEntryAsync(Object) - Method in interface org.infinispan.AdvancedCache
Retrieves a CacheEntry corresponding to a specific key.
getCacheEntryAsync(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getCacheEntryAsync(Object) - Method in class org.infinispan.cache.impl.CacheImpl
 
getCacheEntryAsync(Object) - Method in class org.infinispan.cache.impl.DecoratedCache
 
getCacheEntryAsync(Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
getCacheEntryAsync(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getCacheEntryAsync(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
GetCacheEntryCommand - Class in org.infinispan.commands.read
Used to fetch a full CacheEntry rather than just the value.
GetCacheEntryCommand() - Constructor for class org.infinispan.commands.read.GetCacheEntryCommand
 
GetCacheEntryCommand(Object, int, long, InternalEntryFactory) - Constructor for class org.infinispan.commands.read.GetCacheEntryCommand
 
GetCacheGlobalComponentRegistryAction - Class in org.infinispan.security.actions
GetCacheGlobalComponentRegistryAction.
GetCacheGlobalComponentRegistryAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetCacheGlobalComponentRegistryAction
 
getCacheHealth() - Method in interface org.infinispan.health.Health
Returns per cache health.
getCacheHealth() - Method in class org.infinispan.health.impl.HealthImpl
 
getCacheHealth() - Method in class org.infinispan.health.impl.jmx.HealthJMXExposerImpl
 
getCacheHealth() - Method in interface org.infinispan.health.jmx.HealthJMXExposer
Returns per Cache statuses.
GetCacheInterceptorChainAction - Class in org.infinispan.security.actions
GetCacheInterceptorChainAction.
GetCacheInterceptorChainAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetCacheInterceptorChainAction
 
getCacheJoinInfo() - Method in class org.infinispan.topology.CacheStatusResponse
 
getCacheLoaderLoads() - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
getCacheLoaderLoads() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getCacheLoaderLoads() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getCacheLoaderMisses() - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
getCacheLoaderMisses() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getCacheLoaderMisses() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
GetCacheLockManagerAction - Class in org.infinispan.security.actions
GetCacheLockManagerAction.
GetCacheLockManagerAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetCacheLockManagerAction
 
getCacheManager() - Method in interface org.infinispan.Cache
Retrieves the cache manager responsible for creating this cache instance.
getCacheManager() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getCacheManager() - Method in class org.infinispan.cache.impl.CacheImpl
 
getCacheManager() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getCacheManager() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.Event
 
getCacheManager() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
getCacheManager() - Method in class org.infinispan.security.impl.PrincipalRoleMapperContextImpl
 
getCacheManager() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getCacheManager() - Method in interface org.infinispan.security.PrincipalRoleMapperContext
Returns the EmbeddedCacheManager in which this role mapper is being instantiated
GetCacheManagerAddress - Class in org.infinispan.security.actions
GetCacheManagerAddress.
GetCacheManagerAddress(EmbeddedCacheManager) - Constructor for class org.infinispan.security.actions.GetCacheManagerAddress
 
GetCacheManagerClusterAvailabilityAction - Class in org.infinispan.security.actions
GetCacheManagerClusterAvailabilityAction.
GetCacheManagerClusterAvailabilityAction(EmbeddedCacheManager) - Constructor for class org.infinispan.security.actions.GetCacheManagerClusterAvailabilityAction
 
GetCacheManagerClusterNameAction - Class in org.infinispan.security.actions
GetCacheManagerClusterNameAction.
GetCacheManagerClusterNameAction(EmbeddedCacheManager) - Constructor for class org.infinispan.security.actions.GetCacheManagerClusterNameAction
 
getCacheManagerConfiguration() - Method in class org.infinispan.manager.DefaultCacheManager
 
getCacheManagerConfiguration() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Returns global configuration for this CacheManager
getCacheManagerConfiguration() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
GetCacheManagerCoordinatorAddress - Class in org.infinispan.security.actions
GetCacheManagerCoordinatorAddress.
GetCacheManagerCoordinatorAddress(EmbeddedCacheManager) - Constructor for class org.infinispan.security.actions.GetCacheManagerCoordinatorAddress
 
GetCacheManagerIsCoordinatorAction - Class in org.infinispan.security.actions
GetCacheManagerIsCoordinatorAction.
GetCacheManagerIsCoordinatorAction(EmbeddedCacheManager) - Constructor for class org.infinispan.security.actions.GetCacheManagerIsCoordinatorAction
 
getCacheManagerStatus() - Method in class org.infinispan.manager.DefaultCacheManager
 
GetCacheManagerStatusAction - Class in org.infinispan.security.actions
GetCacheManagerStatusAction.
GetCacheManagerStatusAction(EmbeddedCacheManager) - Constructor for class org.infinispan.security.actions.GetCacheManagerStatusAction
 
getCacheMarshaller() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getComponent(StreamingMarshaller.class, KnownComponentNames.CACHE_MARSHALLER);
getCacheMode() - Method in class org.infinispan.topology.CacheJoinInfo
 
getCacheName() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getCacheName() - Method in class org.infinispan.cache.impl.CacheImpl
Returns the cache name.
getCacheName() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
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 interface org.infinispan.health.CacheHealth
Returns Cache name.
getCacheName() - Method in class org.infinispan.health.impl.CacheHealthImpl
 
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.impl.EventImpl
 
getCacheName() - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
 
getCacheName() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
getCacheName() - Method in class org.infinispan.topology.ClusterCacheStatus
 
getCacheName() - Method in interface org.infinispan.upgrade.SourceMigrator
 
getCacheNames() - Method in class org.infinispan.manager.DefaultCacheManager
 
getCacheNames() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
GetCacheRpcManagerAction - Class in org.infinispan.security.actions
GetCacheRpcManagerAction.
GetCacheRpcManagerAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetCacheRpcManagerAction
 
getCaches() - Method in class org.infinispan.topology.ManagerStatusResponse
 
getCacheStatus() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
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.
getCacheStatus() - Method in class org.infinispan.cache.impl.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.
getCacheStatus() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
GetCacheStatusAction - Class in org.infinispan.security.actions
GetCacheStatusAction.
GetCacheStatusAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetCacheStatusAction
 
getCacheTopology() - Method in interface org.infinispan.distribution.DistributionManager
 
getCacheTopology() - Method in class org.infinispan.distribution.impl.DistributionManagerImpl
 
getCacheTopology() - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
getCacheTopology() - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
 
getCacheTopology() - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
 
getCacheTopology() - Method in interface org.infinispan.statetransfer.StateConsumer
Deprecated.
Since 9.3, please use DistributionManager.getCacheTopology() instead.
getCacheTopology() - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
getCacheTopology() - Method in interface org.infinispan.statetransfer.StateTransferManager
Deprecated.
Since 9.3, please use DistributionManager.getCacheTopology() instead.
getCacheTopology() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
getCacheTopology() - Method in class org.infinispan.topology.CacheStatusResponse
 
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 interface org.infinispan.context.impl.TxInvocationContext
 
getCacheWithFlags(Cache<K, V>, FlagAffectedCommand) - Static method in class org.infinispan.cache.impl.Caches
 
getCacheWithFlags(Cache<K, V>, FlagAffectedCommand) - Method in class org.infinispan.interceptors.base.CommandInterceptor
Deprecated.
 
getCacheWithFlags(FlagAffectedCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
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() - Method in class org.infinispan.topology.CacheJoinInfo
 
getCapacityFactors() - Method in interface org.infinispan.distribution.ch.ConsistentHash
The capacity factor of each member.
getCapacityFactors() - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
getCapacityFactors() - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
 
getCapacityFactors() - Method in class org.infinispan.topology.ClusterCacheStatus
 
getCategory() - Method in interface org.infinispan.util.logging.events.EventLog
 
getChannel() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getChecksum() - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
 
getChecksum() - Method in interface org.infinispan.globalstate.ScopedPersistentState
Returns the checksum of the properties excluding those prefixed with @
getChunk() - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
 
getChunkSize() - Method in class org.infinispan.io.GridFile
Guaranteed to be a power of two
getChunkSize() - Method in class org.infinispan.io.GridFile.Metadata
 
getClassBasedOnConfigurationAnnotation(StoreConfiguration, Log) - Static method in class org.infinispan.persistence.factory.ConfigurationForClassExtractor
 
getClassLoader() - Method in interface org.infinispan.AdvancedCache
Returns the cache loader associated associated with this cache.
getClassLoader() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getClassLoader() - Method in class org.infinispan.cache.impl.CacheImpl
 
getClassLoader() - Method in class org.infinispan.cache.impl.DecoratedCache
 
getClassLoader() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
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
Deprecated.
Not in use any more, implementations might return null.
getClassLoader() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
Deprecated.
 
getClassLoader() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
getClassLoader() - Method in class org.infinispan.factories.ComponentRegistry
 
getClassLoader() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getClassLoader() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
getClassLoader() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getClassWhiteList() - Method in class org.infinispan.manager.DefaultCacheManager
 
getClassWhiteList() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getClassWhiteList() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getClazz() - Method in class org.infinispan.factories.components.ComponentMetadata
 
getClusterAvailability() - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
getClusterHealth() - Method in interface org.infinispan.health.Health
Returns Cluster health.
getClusterHealth() - Method in class org.infinispan.health.impl.HealthImpl
 
getClusterHealth() - Method in class org.infinispan.health.impl.jmx.HealthJMXExposerImpl
 
getClusterHealth() - Method in interface org.infinispan.health.jmx.HealthJMXExposer
Returns cluster health status.
getClusterListenersToInstall() - Method in interface org.infinispan.statetransfer.StateProvider
 
getClusterListenersToInstall() - Method in class org.infinispan.statetransfer.StateProviderImpl
 
getClusterMembers() - Method in class org.infinispan.manager.DefaultCacheManager
 
getClusterName() - Method in interface org.infinispan.health.ClusterHealth
Returns the name of the cluster.
getClusterName() - Method in class org.infinispan.health.impl.ClusterHealthImpl
 
getClusterName() - Method in class org.infinispan.health.impl.jmx.HealthJMXExposerImpl
 
getClusterName() - Method in interface org.infinispan.health.jmx.HealthJMXExposer
Returns cluster name.
getClusterName() - Method in class org.infinispan.manager.DefaultCacheManager
getClusterName() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getClusterName() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getClusterSize() - Method in class org.infinispan.manager.DefaultCacheManager
 
getClusterStatus() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
 
getClusterStatus() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
getCodename() - Static method in class org.infinispan.Version
 
getCoinToss() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
Deprecated.
 
getCollocatedKey(K) - Method in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
 
getCollocatedKey(K) - Method in interface org.infinispan.affinity.KeyAffinityService
Returns a key that will be distributed on the same node as the supplied key.
getCommand() - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
getCommand() - Method in class org.infinispan.remoting.inboundhandler.action.ActionState
 
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.functional.ReadOnlyKeyCommand
 
getCommandId() - Method in class org.infinispan.commands.functional.ReadOnlyManyCommand
 
getCommandId() - Method in class org.infinispan.commands.functional.ReadWriteKeyCommand
 
getCommandId() - Method in class org.infinispan.commands.functional.ReadWriteKeyValueCommand
 
getCommandId() - Method in class org.infinispan.commands.functional.ReadWriteManyCommand
 
getCommandId() - Method in class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
getCommandId() - Method in class org.infinispan.commands.functional.TxReadOnlyKeyCommand
 
getCommandId() - Method in class org.infinispan.commands.functional.TxReadOnlyManyCommand
 
getCommandId() - Method in class org.infinispan.commands.functional.WriteOnlyKeyCommand
 
getCommandId() - Method in class org.infinispan.commands.functional.WriteOnlyKeyValueCommand
 
getCommandId() - Method in class org.infinispan.commands.functional.WriteOnlyManyCommand
 
getCommandId() - Method in class org.infinispan.commands.functional.WriteOnlyManyEntriesCommand
 
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.GetAllCommand
 
getCommandId() - Method in class org.infinispan.commands.read.GetCacheEntryCommand
 
getCommandId() - Method in class org.infinispan.commands.read.GetKeyValueCommand
 
getCommandId() - Method in class org.infinispan.commands.remote.ClusteredGetAllCommand
 
getCommandId() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
getCommandId() - Method in class org.infinispan.commands.remote.expiration.RetrieveLastAccessCommand
 
getCommandId() - Method in class org.infinispan.commands.remote.expiration.UpdateLastAccessCommand
 
getCommandId() - Method in class org.infinispan.commands.remote.GetKeysInGroupCommand
 
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.RenewBiasCommand
 
getCommandId() - Method in class org.infinispan.commands.remote.RevokeBiasCommand
 
getCommandId() - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
getCommandId() - Method in class org.infinispan.commands.RemoveCacheCommand
Deprecated.
 
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.triangle.MultiEntriesFunctionalBackupWriteCommand
 
getCommandId() - Method in class org.infinispan.commands.triangle.MultiKeyFunctionalBackupWriteCommand
 
getCommandId() - Method in class org.infinispan.commands.triangle.PutMapBackupWriteCommand
 
getCommandId() - Method in class org.infinispan.commands.triangle.SingleKeyBackupWriteCommand
 
getCommandId() - Method in class org.infinispan.commands.triangle.SingleKeyFunctionalBackupWriteCommand
 
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
Deprecated.
 
getCommandId() - Method in class org.infinispan.commands.write.BackupAckCommand
 
getCommandId() - Method in class org.infinispan.commands.write.BackupMultiKeyAckCommand
 
getCommandId() - Method in class org.infinispan.commands.write.ClearCommand
 
getCommandId() - Method in class org.infinispan.commands.write.ComputeCommand
 
getCommandId() - Method in class org.infinispan.commands.write.ComputeIfAbsentCommand
 
getCommandId() - Method in class org.infinispan.commands.write.EvictCommand
 
getCommandId() - Method in class org.infinispan.commands.write.ExceptionAckCommand
 
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.InvalidateVersionsCommand
 
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.RemoveExpiredCommand
 
getCommandId() - Method in class org.infinispan.commands.write.ReplaceCommand
 
getCommandId() - Method in class org.infinispan.manager.impl.ReplicableCommandManagerFunction
 
getCommandId() - Method in class org.infinispan.manager.impl.ReplicableCommandRunnable
 
getCommandId() - Method in class org.infinispan.statetransfer.StateRequestCommand
 
getCommandId() - Method in class org.infinispan.statetransfer.StateResponseCommand
 
getCommandId() - Method in class org.infinispan.stream.impl.StreamIteratorCloseCommand
 
getCommandId() - Method in class org.infinispan.stream.impl.StreamIteratorNextCommand
 
getCommandId() - Method in class org.infinispan.stream.impl.StreamIteratorRequestCommand
 
getCommandId() - Method in class org.infinispan.stream.impl.StreamRequestCommand
 
getCommandId() - Method in class org.infinispan.stream.impl.StreamResponseCommand
 
getCommandId() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
getCommandId() - Method in class org.infinispan.topology.HeartBeatCommand
 
getCommandId() - Method in class org.infinispan.xsite.SingleXSiteRpcCommand
 
getCommandId() - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
 
getCommandId() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
 
getCommandId() - Method in class org.infinispan.xsite.XSiteAdminCommand
 
getCommandInvocationId() - Method in class org.infinispan.commands.functional.AbstractWriteManyCommand
 
getCommandInvocationId() - Method in class org.infinispan.commands.triangle.BackupWriteCommand
 
getCommandInvocationId() - Method in class org.infinispan.commands.write.AbstractDataWriteCommand
 
getCommandInvocationId() - Method in class org.infinispan.commands.write.ClearCommand
 
getCommandInvocationId() - Method in class org.infinispan.commands.write.InvalidateCommand
 
getCommandInvocationId() - Method in class org.infinispan.commands.write.PutMapCommand
 
getCommandInvocationId() - Method in interface org.infinispan.commands.write.WriteCommand
 
getCommandsFactory() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getLocalComponent(CommandsFactory.class);
getCommandTopologyId() - Method in class org.infinispan.remoting.inboundhandler.action.ActionState
 
getCommitNodes(Collection<Address>, CacheTopology) - Method in class org.infinispan.transaction.impl.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.impl.TxInterceptor
 
getCommittedViewAsString() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
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
 
getComparator() - Method in class org.infinispan.stream.impl.intops.object.SortedComparatorOperation
 
getComparator() - Method in class org.infinispan.stream.impl.spliterators.IteratorAsSpliterator
 
getCompletedTasks() - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
getCompletedTransactionStatus(GlobalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
 
getComponent(Class<T>) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
Retrieves a component of a specified type from the registry, or null if it cannot be found.
getComponent(Class<T>) - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
Looks up a running component named name in the registry, or registers it if necessary.
getComponent(Class<T>, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
getComponent(String) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
getComponent(String, Class<T>) - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
Looks up a running component named name in the registry, or registers it if necessary.
getComponent(String, Class<T>) - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
 
getComponent(String, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
getComponent(String, String, boolean) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
getComponent(String, String, boolean) - Method in class org.infinispan.factories.ComponentRegistry
 
getComponent0(String, Class<T>, boolean) - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
 
getComponentClass() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
 
getComponentMetadata(Class<?>) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
Look up metadata for a component class.
getComponentMetadataRepo() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
getComponentMetadataRepo() - Method in class org.infinispan.factories.ComponentRegistry
 
getComponentMetadataRepo() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getComponentName() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
 
getComponentName() - Method in class org.infinispan.factories.impl.ComponentAlias
 
getComponentRegistry() - Method in interface org.infinispan.AdvancedCache
 
getComponentRegistry() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getComponentRegistry() - Method in class org.infinispan.cache.impl.CacheImpl
 
getComponentRegistry() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getComponentRegistry() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getComponentType() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
 
getCompositeKeys() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
Deprecated.
 
getConcurrencyLevel() - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
 
getConfiguration() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
Retrieves the configuration component.
getConfiguration() - Method in class org.infinispan.globalstate.impl.CacheState
 
getConfiguration() - Method in class org.infinispan.persistence.file.SingleFileStore
 
getConfiguration() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getConfiguration() - Method in interface org.infinispan.persistence.spi.InitializationContext
 
getConfiguration(String, boolean) - Method in class org.infinispan.configuration.ConfigurationManager
 
getConfiguration(String, String) - Method in class org.infinispan.configuration.ConfigurationManager
 
getConfigurationAsProperties() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getConfigurationAsProperties() - Method in class org.infinispan.cache.impl.CacheImpl
 
getConfigurationAsProperties() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getConfigurations() - Method in class org.infinispan.configuration.serializing.ConfigurationHolder
 
getConflictingTransactionBlocks() - Method in class org.infinispan.transaction.impl.TotalOrderRemoteTransactionState
 
getConflicts() - Method in interface org.infinispan.conflict.ConflictManager
Returns a stream of conflicts detected in the cluster.
getConflicts() - Method in class org.infinispan.conflict.impl.DefaultConflictManager
 
getConflictsAlreadyInProgress() - Method in class org.infinispan.util.logging.Log_$logger
 
getConflictsAlreadyInProgress() - Method in interface org.infinispan.util.logging.Log
 
getConflictsAlreadyInProgress$str() - Method in class org.infinispan.util.logging.Log_$logger
 
getConflictsStateTransferInProgress(String) - Method in class org.infinispan.util.logging.Log_$logger
 
getConflictsStateTransferInProgress(String) - Method in interface org.infinispan.util.logging.Log
 
getConflictsStateTransferInProgress$str() - Method in class org.infinispan.util.logging.Log_$logger
 
getConsistentHash() - Method in interface org.infinispan.distribution.DistributionManager
Deprecated.
Since 9.0, please use DistributionManager.getWriteConsistentHash() instead.
getConsistentHashAtEnd() - Method in interface org.infinispan.notifications.cachelistener.event.DataRehashedEvent
 
getConsistentHashAtEnd() - Method in class org.infinispan.notifications.cachelistener.event.impl.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.impl.EventImpl
 
getConsistentHashAtStart() - Method in interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
getConsistentHashFactory() - Method in class org.infinispan.topology.CacheJoinInfo
 
getConsumer() - Method in class org.infinispan.commands.functional.WriteOnlyKeyCommand
 
getConsumer() - Method in class org.infinispan.commands.functional.WriteOnlyManyCommand
 
getConsumer() - Method in class org.infinispan.stream.impl.intops.object.PeekOperation
 
getConsumer() - Method in class org.infinispan.stream.impl.intops.primitive.d.PeekDoubleOperation
 
getConsumer() - Method in class org.infinispan.stream.impl.intops.primitive.i.PeekIntOperation
 
getConsumer() - Method in class org.infinispan.stream.impl.intops.primitive.l.PeekLongOperation
 
getConsumer() - Method in class org.infinispan.stream.impl.termop.object.ForEachBiOperation
 
getConsumer() - Method in class org.infinispan.stream.impl.termop.object.ForEachOperation
 
getConsumer() - Method in class org.infinispan.stream.impl.termop.primitive.ForEachDoubleOperation
 
getConsumer() - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapDoubleOperation
 
getConsumer() - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapIntOperation
 
getConsumer() - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapLongOperation
 
getConsumer() - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapObjDoubleOperation
 
getConsumer() - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapObjIntOperation
 
getConsumer() - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapObjLongOperation
 
getConsumer() - Method in class org.infinispan.stream.impl.termop.primitive.ForEachIntOperation
 
getConsumer() - Method in class org.infinispan.stream.impl.termop.primitive.ForEachLongOperation
 
getConsumer() - Method in class org.infinispan.stream.impl.termop.primitive.ForEachObjDoubleOperation
 
getConsumer() - Method in class org.infinispan.stream.impl.termop.primitive.ForEachObjIntOperation
 
getConsumer() - Method in class org.infinispan.stream.impl.termop.primitive.ForEachObjLongOperation
 
getContext() - Method in interface org.infinispan.util.logging.events.EventLog
 
getConverter() - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
 
getConverter() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
getConverter() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
getConverter() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
getConverter(Object[]) - Method in interface org.infinispan.notifications.cachelistener.filter.CacheEventConverterFactory
Retrieves a cache event converter instance from this factory.
getCoordinator() - Method in class org.infinispan.manager.DefaultCacheManager
getCoordinator() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getCoordinator() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getCoordinator() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
getCoordinator() - Method in class org.infinispan.remoting.transport.jgroups.ClusterView
 
getCoordinator() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getCoordinator() - Method in interface org.infinispan.remoting.transport.Transport
 
getCoordinatorAddress() - Method in class org.infinispan.manager.DefaultCacheManager
 
getCreated() - Method in interface org.infinispan.container.entries.CacheEntry
 
getCreated() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
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.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.ReadCommittedEntry
 
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
 
getCreationTime() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getCreationTime() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
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 class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getCurrentNumberOfEntries() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getCurrentNumberOfEntries() - Method in class org.infinispan.stats.impl.StatsCollector
 
getCurrentNumberOfEntries() - Method in class org.infinispan.stats.impl.StatsImpl
 
getCurrentNumberOfEntries() - Method in interface org.infinispan.stats.Stats
Returns the number of entries currently in this cache instance.
getCurrentNumberOfEntriesInMemory() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getCurrentNumberOfEntriesInMemory() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getCurrentNumberOfEntriesInMemory() - Method in class org.infinispan.stats.impl.StatsCollector
 
getCurrentNumberOfEntriesInMemory() - Method in class org.infinispan.stats.impl.StatsImpl
 
getCurrentNumberOfEntriesInMemory() - Method in interface org.infinispan.stats.Stats
The same as Stats.getCurrentNumberOfEntries(), however passivated entries are not included.
getCurrentSize() - Method in class org.infinispan.interceptors.impl.TransactionalExceptionEvictionInterceptor
 
getCurrentStateSending() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateProvider
 
getCurrentStateSending() - Method in class org.infinispan.xsite.statetransfer.XSiteStateProviderImpl
 
getCurrentTopology() - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
 
getCurrentTopology() - Method in class org.infinispan.topology.ClusterCacheStatus
 
getCustomInterceptorsBuilder() - Method in class org.infinispan.configuration.cache.AbstractCustomInterceptorsConfigurationChildBuilder
 
getDataContainer() - Method in interface org.infinispan.AdvancedCache
Returns the container where data is stored in the cache.
getDataContainer() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getDataContainer() - Method in class org.infinispan.cache.impl.CacheImpl
 
getDataContainer() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getDataContainer() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getDataMemoryUsed() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
getDataMemoryUsed() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getDataMemoryUsed() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getDataMemoryUsed() - Method in class org.infinispan.stats.impl.StatsCollector
 
getDataMemoryUsed() - Method in class org.infinispan.stats.impl.StatsImpl
 
getDataMemoryUsed() - Method in interface org.infinispan.stats.Stats
Provides how much memory the current eviction algorithm estimates is in use for data.
getDefaultCacheConfiguration() - Method in class org.infinispan.manager.DefaultCacheManager
 
getDefaultCacheConfiguration() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Returns default configuration for this CacheManager
getDefaultCacheConfiguration() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getDefaultConfigurationBuilder() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
GetDefaultExecutorServiceAction - Class in org.infinispan.security.actions
GetDefaultExecutorServiceAction.
GetDefaultExecutorServiceAction(Cache<?, ?>) - Constructor for class org.infinispan.security.actions.GetDefaultExecutorServiceAction
 
getDefaultQueueSize(String) - Static method in class org.infinispan.factories.KnownComponentNames
 
getDefaultRpcOptions(boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
Deprecated.
Since 9.2, please use RpcManager.getSyncRpcOptions() instead.
getDefaultRpcOptions(boolean) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getDefaultRpcOptions(boolean, DeliverOrder) - Method in interface org.infinispan.remoting.rpc.RpcManager
Deprecated.
getDefaultRpcOptions(boolean, DeliverOrder) - 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
 
getDefinedCacheConfigurationNames() - Method in class org.infinispan.manager.DefaultCacheManager
 
getDefinedCacheCount() - Method in class org.infinispan.manager.DefaultCacheManager
 
getDefinedCacheNames() - Method in class org.infinispan.manager.DefaultCacheManager
 
getDefinedCaches() - Method in class org.infinispan.configuration.ConfigurationManager
 
getDefinedConfigurations() - Method in class org.infinispan.configuration.ConfigurationManager
 
getDelegate() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getDelegate() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
getDelegate() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getDelta() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
Deprecated.
 
getDeltaAwareValueKey() - Method in class org.infinispan.atomic.DeltaCompositeKey
Deprecated.
 
getDependencies() - Method in class org.infinispan.factories.components.ComponentMetadata
 
getDependencyName() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
 
getDependencyName(int) - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMethodMetadata
 
getDependents(T) - Method in class org.infinispan.util.DependencyGraph
Return the dependents
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
 
getDetail() - Method in interface org.infinispan.util.logging.events.EventLog
 
getDistinctLocationsCount(TopologyLevel, int) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getDistribution(Object) - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
getDistributionForSegment(int) - Method in class org.infinispan.distribution.LocalizedCacheTopology
Deprecated.
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.cache.impl.AbstractDelegatingAdvancedCache
 
getDistributionManager() - Method in class org.infinispan.cache.impl.CacheImpl
 
getDistributionManager() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getDistributionManager() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getComponent(DistributionManager.class);
getDistributionManager() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getElapsedTime() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
getElement() - Method in enum org.infinispan.configuration.cache.StorageType
 
getEncoder() - Method in class org.infinispan.encoding.DataConversion
 
getEncoder(Class<? extends Encoder>, Short) - Method in interface org.infinispan.marshall.core.EncoderRegistry
 
getEncoder(Class<? extends Encoder>, Short) - Method in class org.infinispan.marshall.core.EncoderRegistryImpl
 
getEncoderClass() - Method in class org.infinispan.encoding.DataConversion
 
getEnlistedResources() - Method in class org.infinispan.transaction.tm.DummyTransaction
Deprecated.
 
getEnlistedSynchronization() - Method in class org.infinispan.transaction.tm.DummyTransaction
Deprecated.
 
getEntries() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntriesEvictedEvent
Retrieves entries being evicted.
getEntries() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getEvent() - Method in class org.infinispan.notifications.cachelistener.EventWrapper
 
getEventLogger() - Method in interface org.infinispan.util.logging.events.EventLogManager
 
getEventLogger() - Method in class org.infinispan.util.logging.events.impl.EventLogManagerImpl
 
getEventLogger(EmbeddedCacheManager) - Static method in interface org.infinispan.util.logging.events.EventLogManager
 
getEvents(Instant, int, Optional<EventLogCategory>, Optional<EventLogLevel>) - Method in interface org.infinispan.util.logging.events.EventLogger
Retrieves the event logs from the cluster within the specified range
getEvents(Instant, int, Optional<EventLogCategory>, Optional<EventLogLevel>) - Method in class org.infinispan.util.logging.events.impl.BasicEventLogger
The basic event logger doesn't collect anything.
getEvents(Instant, int, Optional<EventLogCategory>, Optional<EventLogLevel>) - Method in class org.infinispan.util.logging.events.impl.DecoratedEventLogger
 
getEvictionManager() - Method in interface org.infinispan.AdvancedCache
 
getEvictionManager() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getEvictionManager() - Method in class org.infinispan.cache.impl.CacheImpl
 
getEvictionManager() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getEvictionManager() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getEvictions() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
getEvictions() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getEvictions() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getEvictions() - Method in class org.infinispan.stats.impl.StatsCollector
 
getEvictions() - Method in class org.infinispan.stats.impl.StatsImpl
 
getEvictions() - Method in interface org.infinispan.stats.Stats
 
getEvictionSize() - Method in class org.infinispan.cache.impl.CacheConfigurationMBean
 
getException() - Method in class org.infinispan.remoting.responses.ExceptionResponse
 
getExecutor() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getExecutor() - Method in interface org.infinispan.persistence.spi.InitializationContext
Returns the preferred executor to be used by stores if needed.
getExecutor(Properties) - Method in class org.infinispan.executors.DefaultExecutorFactory
 
getExecutor(Properties) - Method in class org.infinispan.executors.WithinThreadExecutorFactory
 
getExecutor(Properties, AccessControlContext) - Method in class org.infinispan.executors.DefaultExecutorFactory
 
getExecutorService() - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
getExecutorService() - Method in class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
 
getExpectedMembers() - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
The members of the cache.
getExpectedMembers() - Method in class org.infinispan.topology.ClusterCacheStatus
 
getExpirationManager() - Method in interface org.infinispan.AdvancedCache
 
getExpirationManager() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getExpirationManager() - Method in class org.infinispan.cache.impl.CacheImpl
 
getExpirationManager() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getExpirationManager() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
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
 
getFactory(Class<?>) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
Retrieves a component factory instance capable of constructing components of a specified type.
getFailedBackups() - Method in class org.infinispan.remoting.transport.AggregateBackupResponse
 
getFailedBackups() - Method in interface org.infinispan.remoting.transport.BackupResponse
 
getFailedBackups() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsBackupResponse
 
getFailureCount() - Method in class org.infinispan.xsite.OfflineStatus
 
getFailurePolicy(String) - Method in class org.infinispan.configuration.cache.SitesConfiguration
 
getField() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
 
getFieldClassName() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
 
getFieldName() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
 
getFile(File, String) - Method in class org.infinispan.io.GridFilesystem
 
getFile(File, String, int) - Method in class org.infinispan.io.GridFilesystem
 
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
 
getFilter() - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
 
getFilter() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
getFilter() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
getFilter() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
getFilter(Object[]) - Method in interface org.infinispan.notifications.cachelistener.filter.CacheEventFilterFactory
Retrieves a cache event filter instance from this factory.
getFilterAnnotations() - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
 
getFilterAnnotations() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
getFilterAnnotations() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
getFilterConverter() - Method in interface org.infinispan.filter.KeyValueFilterConverterFactory
 
getFilterConverter() - Method in interface org.infinispan.filter.ParamKeyValueFilterConverterFactory
 
getFilterConverter(Object[]) - Method in interface org.infinispan.filter.ParamKeyValueFilterConverterFactory
Create an instance of KeyValueFilterConverter
getFilterConverter(Object[]) - Method in interface org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverterFactory
Retrieves a cache event filter and converter instance from this factory.
getFilteredKeys() - Method in class org.infinispan.remoting.inboundhandler.action.ActionState
 
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.
getFirstException() - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
getFirstInChain() - Method in class org.infinispan.interceptors.InterceptorChain
Deprecated.
getFirstTopologyAsMember() - Method in class org.infinispan.remoting.inboundhandler.AbstractDelegatingHandler
 
getFirstTopologyAsMember() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
 
getFirstTopologyAsMember() - Method in interface org.infinispan.remoting.inboundhandler.PerCacheInboundInvocationHandler
 
getFirstTopologyAsMember() - Method in interface org.infinispan.statetransfer.StateTransferManager
Deprecated.
Since 9.4, will be removed.
getFirstTopologyAsMember() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
getFlags() - Method in interface org.infinispan.commands.FlagAffectedCommand
 
getFlags() - Method in class org.infinispan.commands.triangle.BackupWriteCommand
 
getFlags() - Method in class org.infinispan.globalstate.impl.CacheState
 
getFlagsBitSet() - Method in class org.infinispan.cache.impl.DecoratedCache
 
getFlagsBitSet() - Method in class org.infinispan.commands.AbstractFlagAffectedCommand
 
getFlagsBitSet() - Method in class org.infinispan.commands.control.LockControlCommand
 
getFlagsBitSet() - Method in interface org.infinispan.commands.FlagAffectedCommand
 
getFlagsBitSet() - Method in class org.infinispan.commands.functional.AbstractWriteManyCommand
 
getFlagsBitSet() - Method in class org.infinispan.commands.read.AbstractDataCommand
 
getFlagsBitSet() - Method in class org.infinispan.commands.remote.BaseClusteredReadCommand
 
getFloatProperty(String) - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
 
getFloatProperty(String) - Method in interface org.infinispan.globalstate.ScopedPersistentState
Retrieves a float state property
getFormatId() - Method in class org.infinispan.transaction.tm.DummyNoXaXid
Deprecated.
 
getFormatId() - Method in class org.infinispan.transaction.tm.DummyXid
Deprecated.
 
getFormatId() - Method in class org.infinispan.transaction.xa.recovery.SerializableXid
Deprecated.
 
getFreeMemoryInKb() - Method in interface org.infinispan.health.HostInfo
Gets free memory in KB.
getFreeMemoryInKb() - Method in class org.infinispan.health.impl.HostInfoImpl
 
getFreeMemoryKb() - Method in class org.infinispan.health.impl.jmx.HealthJMXExposerImpl
 
getFreeMemoryKb() - Method in interface org.infinispan.health.jmx.HealthJMXExposer
Returns the amount of free memory (KB) in the host.
getFreeSpace() - Method in class org.infinispan.io.GridFile
 
getFunction() - Method in class org.infinispan.commands.functional.ReadWriteKeyCommand
 
getFunction() - Method in class org.infinispan.stream.impl.intops.object.FlatMapOperation
 
getFunction() - Method in class org.infinispan.stream.impl.intops.object.FlatMapToDoubleOperation
 
getFunction() - Method in class org.infinispan.stream.impl.intops.object.FlatMapToIntOperation
 
getFunction() - Method in class org.infinispan.stream.impl.intops.object.FlatMapToLongOperation
 
getFunction() - Method in class org.infinispan.stream.impl.intops.object.MapOperation
 
getFunction() - Method in class org.infinispan.stream.impl.intops.object.MapToDoubleOperation
 
getFunction() - Method in class org.infinispan.stream.impl.intops.object.MapToIntOperation
 
getFunction() - Method in class org.infinispan.stream.impl.intops.object.MapToLongOperation
 
getFunction() - Method in class org.infinispan.stream.impl.intops.primitive.d.FlatMapDoubleOperation
 
getFunction() - Method in class org.infinispan.stream.impl.intops.primitive.d.MapToIntDoubleOperation
 
getFunction() - Method in class org.infinispan.stream.impl.intops.primitive.d.MapToLongDoubleOperation
 
getFunction() - Method in class org.infinispan.stream.impl.intops.primitive.d.MapToObjDoubleOperation
 
getFunction() - Method in class org.infinispan.stream.impl.intops.primitive.i.FlatMapIntOperation
 
getFunction() - Method in class org.infinispan.stream.impl.intops.primitive.i.MapToDoubleIntOperation
 
getFunction() - Method in class org.infinispan.stream.impl.intops.primitive.i.MapToLongIntOperation
 
getFunction() - Method in class org.infinispan.stream.impl.intops.primitive.i.MapToObjIntOperation
 
getFunction() - Method in class org.infinispan.stream.impl.intops.primitive.l.FlatMapLongOperation
 
getFunction() - Method in class org.infinispan.stream.impl.intops.primitive.l.MapToDoubleLongOperation
 
getFunction() - Method in class org.infinispan.stream.impl.intops.primitive.l.MapToIntLongOperation
 
getFunction() - Method in class org.infinispan.stream.impl.intops.primitive.l.MapToObjLongOperation
 
getFunction() - Method in class org.infinispan.stream.impl.termop.SegmentRetryingOperation
 
getFunction() - Method in class org.infinispan.stream.impl.termop.SingleRunOperation
 
getFuture() - Method in interface org.infinispan.interceptors.distribution.Collector
 
getFuture() - Method in class org.infinispan.interceptors.distribution.PrimaryOwnerOnlyCollector
 
getGlobalComponentRegistry() - Method in class org.infinispan.factories.ComponentRegistry
 
getGlobalComponentRegistry() - Method in class org.infinispan.manager.DefaultCacheManager
 
getGlobalComponentRegistry() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getGlobalComponentRegistry() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
GetGlobalComponentRegistryAction - Class in org.infinispan.security.actions
GetGlobalComponentRegistryAction.
GetGlobalComponentRegistryAction(EmbeddedCacheManager) - Constructor for class org.infinispan.security.actions.GetGlobalComponentRegistryAction
 
getGlobalConfiguration() - Method in class org.infinispan.configuration.ConfigurationManager
 
getGlobalConfiguration() - Method in class org.infinispan.configuration.serializing.ConfigurationHolder
 
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
 
getGlobalTransaction() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
Deprecated.
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.AbstractTxInvocationContext
 
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.cluster.ClusterEvent
 
getGlobalTransaction() - Method in class org.infinispan.notifications.cachelistener.event.impl.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.impl.AbstractCacheTransaction
 
getGlobalTransaction() - Method in class org.infinispan.transaction.impl.TotalOrderRemoteTransactionState
 
getGlobalTransaction() - Method in interface org.infinispan.transaction.xa.CacheTransaction
Returns the transaction identifier.
getGlobalTransaction(Transaction) - Method in class org.infinispan.transaction.impl.TransactionTable
 
getGlobalTransaction(Transaction) - Method in interface org.infinispan.transaction.TransactionTable
 
getGlobalTransactionId() - Method in class org.infinispan.transaction.tm.DummyNoXaXid
Deprecated.
 
getGlobalTransactionId() - Method in class org.infinispan.transaction.tm.DummyXid
Deprecated.
 
getGlobalTransactionId() - Method in class org.infinispan.transaction.xa.recovery.SerializableXid
Deprecated.
 
getGroup(Object) - Method in interface org.infinispan.distribution.group.impl.GroupManager
Get the group for a given key
getGroup(Object) - Method in class org.infinispan.distribution.group.impl.GroupManagerImpl
 
getGroup(String) - Method in interface org.infinispan.AdvancedCache
It fetches all the keys which belong to the group.
getGroup(String) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getGroup(String) - Method in class org.infinispan.cache.impl.CacheImpl
 
getGroup(String) - Method in class org.infinispan.cache.impl.DecoratedCache
 
getGroup(String) - Method in class org.infinispan.cache.impl.EncoderCache
 
getGroup(String) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getGroup(String) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getGroupName() - Method in class org.infinispan.commands.remote.GetKeysInGroupCommand
 
getHash() - Method in class org.infinispan.distribution.ch.impl.HashFunctionPartitioner
 
getHashCode(long) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
Returns the hashCode of the address.
getHashCode(long) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
 
getHashFunction() - Method in interface org.infinispan.distribution.ch.ConsistentHash
Deprecated.
Since 8.2, the Hash is optional - replaced in the configuration by the KeyPartitioner
getHashFunction() - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
getHashFunction() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
getHashFunction() - Method in class org.infinispan.distribution.group.impl.PartitionerConsistentHash
 
getHashFunction() - Method in class org.infinispan.topology.CacheJoinInfo
 
getHealth() - Method in class org.infinispan.manager.DefaultCacheManager
 
getHealth() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Returns an entry point for a Health Check API.
getHealth() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getHealthStatus() - Method in interface org.infinispan.health.ClusterHealth
Returns total cluster health.
getHealthStatus() - Method in class org.infinispan.health.impl.ClusterHealthImpl
 
getHitRatio() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
getHitRatio() - Method in interface org.infinispan.stats.CacheContainerStats
 
getHitRatio() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getHitRatio() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getHitRatio() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getHitRatio() - Method in class org.infinispan.stats.impl.StatsCollector
 
getHits() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
getHits() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getHits() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getHits() - Method in class org.infinispan.stats.impl.StatsCollector
 
getHits() - Method in class org.infinispan.stats.impl.StatsImpl
 
getHits() - Method in interface org.infinispan.stats.Stats
 
getHostInfo() - Method in interface org.infinispan.health.Health
Gets basic information about the host.
getHostInfo() - Method in class org.infinispan.health.impl.HealthImpl
 
getId() - Method in class org.infinispan.atomic.DeltaCompositeKey.DeltaCompositeKeyExternalizer
Deprecated.
 
getId() - Method in class org.infinispan.atomic.impl.ApplyDelta.Externalizer
Deprecated.
 
getId() - Method in class org.infinispan.atomic.impl.AtomicKeySetImpl.Externalizer
 
getId() - Method in class org.infinispan.atomic.impl.AtomicKeySetImpl.FunctionExternalizer
 
getId() - Method in class org.infinispan.atomic.impl.AtomicMapProxyImpl.Externalizer
 
getId() - Method in class org.infinispan.cache.impl.EncoderEntryMapper.Externalizer
 
getId() - Method in class org.infinispan.cache.impl.EncoderKeyMapper.Externalizer
 
getId() - Method in class org.infinispan.cache.impl.EncoderValueMapper.Externalizer
 
getId() - Method in class org.infinispan.commands.CommandInvocationId
 
getId() - Method in class org.infinispan.commands.functional.functions.MergeFunction.Externalizer
 
getId() - Method in class org.infinispan.compat.BiFunctionMapper.Externalizer
 
getId() - Method in class org.infinispan.compat.FunctionMapper.Externalizer
 
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.RemoteMetadata.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.impl.DefaultConsistentHash.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.impl.TopologyAwareConsistentHashFactory.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory.Externalizer
 
getId() - Method in class org.infinispan.encoding.DataConversion.Externalizer
 
getId() - Method in class org.infinispan.filter.AcceptAllKeyValueFilter.Externalizer
 
getId() - Method in class org.infinispan.filter.CacheFilters.CacheFiltersExternalizer
 
getId() - Method in class org.infinispan.filter.CollectionKeyFilter.Externalizer
 
getId() - Method in class org.infinispan.filter.CompositeKeyFilter.Externalizer
 
getId() - Method in class org.infinispan.filter.CompositeKeyValueFilter.Externalizer
 
getId() - Method in class org.infinispan.filter.KeyFilterAsKeyValueFilter.Externalizer
 
getId() - Method in class org.infinispan.filter.KeyValueFilterAsKeyFilter.Externalizer
 
getId() - Method in class org.infinispan.functional.impl.EntryViews.NoValueReadOnlyViewExternalizer
 
getId() - Method in class org.infinispan.functional.impl.EntryViews.ReadOnlySnapshotViewExternalizer
 
getId() - Method in class org.infinispan.functional.impl.EntryViews.ReadWriteSnapshotViewExternalizer
 
getId() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata.Externalizer
 
getId() - Method in class org.infinispan.functional.impl.StatsEnvelope.Externalizer
 
getId() - Method in class org.infinispan.globalstate.impl.CacheState.Externalizer
 
getId() - Method in class org.infinispan.globalstate.ScopedState.Externalizer
 
getId() - Method in class org.infinispan.globalstate.ScopeFilter.Externalizer
 
getId() - Method in class org.infinispan.interceptors.distribution.VersionedResult.Externalizer
 
getId() - Method in class org.infinispan.interceptors.distribution.VersionedResults.Externalizer
 
getId() - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.ConstantLambdaExternalizer
 
getId() - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.LambdaWithMetasExternalizer
 
getId() - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.SetValueIfEqualsReturnBooleanExternalizer
 
getId() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl.Externalizer
 
getId() - Method in class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.CollectionExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.DoubleSummaryStatisticsExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.EnumSetExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.IntSummaryStatisticsExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.LongSummaryStatisticsExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.MapExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.EntryVersionParamExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.LifespanExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.MaxIdleExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.OptionalExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.TriangleAckExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.UuidExternalizer
 
getId() - Method in class org.infinispan.metadata.EmbeddedMetadata.Externalizer
 
getId() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl.Externalizer
 
getId() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent.Externalizer
 
getId() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEventCallable.Externalizer
 
getId() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerRemoveCallable.Externalizer
 
getId() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerReplicateCallable.Externalizer
 
getId() - Method in class org.infinispan.notifications.cachelistener.cluster.MultiClusterEventCallable.Externalizer
 
getId() - Method in class org.infinispan.notifications.cachelistener.cluster.RemoteClusterListener
 
getId() - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventConverterAsConverter.Externalizer
 
getId() - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterAsKeyValueFilter.Externalizer
 
getId() - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverterAsKeyValueFilterConverter.Externalizer
 
getId() - Method in class org.infinispan.notifications.cachelistener.filter.KeyFilterAsCacheEventFilter.Externalizer
 
getId() - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterAsCacheEventFilter.Externalizer
 
getId() - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter.Externalizer
 
getId() - Method in class org.infinispan.partitionhandling.AvailabilityMode.Externalizer
 
getId() - Method in class org.infinispan.remoting.MIMECacheEntry.Externalizer
 
getId() - Method in class org.infinispan.remoting.responses.BiasRevocationResponse.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.stream.impl.AbstractCacheStream.MapOpsExternalizer
 
getId() - Method in class org.infinispan.stream.impl.EndIterator.EndIteratorExternalizer
 
getId() - Method in class org.infinispan.stream.impl.intops.IntermediateOperationExternalizer
 
getId() - Method in class org.infinispan.stream.impl.IteratorResponses.IteratorResponsesExternalizer
 
getId() - Method in class org.infinispan.stream.impl.StreamIteratorCloseCommand
 
getId() - Method in class org.infinispan.stream.impl.StreamIteratorNextCommand
 
getId() - Method in class org.infinispan.stream.impl.StreamRequestCommand
 
getId() - Method in class org.infinispan.stream.impl.termop.TerminalOperationExternalizer
 
getId() - Method in class org.infinispan.stream.StreamMarshalling.StreamMarshallingExternalizer
 
getId() - Method in class org.infinispan.topology.CacheJoinInfo.Externalizer
 
getId() - Method in class org.infinispan.topology.CacheStatusResponse.Externalizer
 
getId() - Method in class org.infinispan.topology.CacheTopology.Externalizer
 
getId() - Method in class org.infinispan.topology.ManagerStatusResponse.Externalizer
 
getId() - Method in class org.infinispan.topology.PersistentUUID.Externalizer
 
getId() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction.Externalizer
Deprecated.
 
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
Deprecated.
 
getId() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction.Externalizer
 
getId() - Method in class org.infinispan.transaction.xa.recovery.SerializableXid.XidExternalizer
Deprecated.
 
getId() - Method in class org.infinispan.util.IntSetExternalizer
 
getId() - Method in class org.infinispan.util.KeyValuePair.Externalizer
 
getId() - Method in class org.infinispan.xsite.statetransfer.XSiteState.XSiteStateExternalizer
 
getIdentifier() - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
 
getIdentifier() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
getIdentifier() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
getIdentifier() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
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(ByteString) - 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(ByteString) - Constructor for class org.infinispan.commands.remote.recovery.GetInDoubtTxInfoCommand
 
getInjectFields() - Method in class org.infinispan.factories.components.ComponentMetadata
 
getInjectMethods() - Method in class org.infinispan.factories.components.ComponentMetadata
 
getInput(File) - Method in class org.infinispan.io.GridFilesystem
Opens an InputStream for reading from the given file.
getInput(String) - Method in class org.infinispan.io.GridFilesystem
Opens an InputStream for reading from the file denoted by pathname.
getInstance() - Static method in class org.infinispan.container.entries.ClearCacheEntry
 
getInstance() - Static method in class org.infinispan.container.entries.NullCacheEntry
 
getInstance() - Static method in class org.infinispan.distexec.spi.DistributedTaskLifecycleService
 
getInstance() - Static method in class org.infinispan.distribution.ch.impl.SingleSegmentKeyPartitioner
 
getInstance() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
Deprecated.
 
getInstance() - Static method in class org.infinispan.filter.AcceptAllKeyValueFilter
 
getInstance() - Static method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
getInstance() - Static method in class org.infinispan.stream.impl.EndIterator
 
getInstance() - Static method in class org.infinispan.stream.impl.intops.object.DistinctOperation
 
getInstance() - Static method in class org.infinispan.stream.impl.intops.object.SortedOperation
 
getInstance() - Static method in class org.infinispan.stream.impl.intops.primitive.d.BoxedDoubleOperation
 
getInstance() - Static method in class org.infinispan.stream.impl.intops.primitive.d.DistinctDoubleOperation
 
getInstance() - Static method in class org.infinispan.stream.impl.intops.primitive.d.SortedDoubleOperation
 
getInstance() - Static method in class org.infinispan.stream.impl.intops.primitive.i.AsDoubleIntOperation
 
getInstance() - Static method in class org.infinispan.stream.impl.intops.primitive.i.AsLongIntOperation
 
getInstance() - Static method in class org.infinispan.stream.impl.intops.primitive.i.BoxedIntOperation
 
getInstance() - Static method in class org.infinispan.stream.impl.intops.primitive.i.DistinctIntOperation
 
getInstance() - Static method in class org.infinispan.stream.impl.intops.primitive.i.SortedIntOperation
 
getInstance() - Static method in class org.infinispan.stream.impl.intops.primitive.l.AsDoubleLongOperation
 
getInstance() - Static method in class org.infinispan.stream.impl.intops.primitive.l.BoxedLongOperation
 
getInstance() - Static method in class org.infinispan.stream.impl.intops.primitive.l.DistinctLongOperation
 
getInstance() - Static method in class org.infinispan.stream.impl.intops.primitive.l.SortedLongOperation
 
getInstance() - Static method in class org.infinispan.transaction.tm.BatchModeTransactionManager
 
getInstance() - Static method in class org.infinispan.transaction.tm.DummyTransactionManager
Deprecated.
 
getInstance() - Static method in class org.infinispan.transaction.tm.EmbeddedTransactionManager
 
getInstance() - Static method in class org.infinispan.util.concurrent.locks.impl.NoOpPendingLockManager
 
getInstance() - Static method in class org.infinispan.xsite.status.OfflineSiteStatus
 
getInstance() - Static method in class org.infinispan.xsite.status.OnlineSiteStatus
 
getInstance(ComponentRegistry, Configuration) - Static method in class org.infinispan.factories.InterceptorChainFactory
Deprecated.
Since 9.4, not used.
getInterceptorChain() - Method in interface org.infinispan.AdvancedCache
Deprecated.
getInterceptorChain() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getInterceptorChain() - Method in class org.infinispan.cache.impl.CacheImpl
 
getInterceptorChain() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getInterceptorChain() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getInterceptors() - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
 
getInterceptors() - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
getInterceptors() - Method in class org.infinispan.interceptors.impl.AsyncInterceptorChainImpl
 
getInterceptorsWhichExtend(Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
Deprecated.
Returns all interceptors which extend the given command interceptor.
getInterceptorsWithClass(Class) - Method in class org.infinispan.interceptors.InterceptorChain
Deprecated.
Returns all the interceptors that have the fully qualified name of their class equal with the supplied class name.
getIntermediateOperations() - Method in class org.infinispan.stream.impl.termop.BaseTerminalOperation
 
getInternalCacheNames() - Method in class org.infinispan.registry.impl.InternalCacheRegistryImpl
 
getInternalCacheNames() - Method in interface org.infinispan.registry.InternalCacheRegistry
Retrieves the names of all the internal caches
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
Deprecated.
 
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) - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
 
getIntProperty(String) - Method in interface org.infinispan.globalstate.ScopedPersistentState
Retrieves an integer state property
getInvalidations() - Method in class org.infinispan.interceptors.impl.InvalidationInterceptor
 
getInvalidations() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getInvalidations() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getInvocationContext(boolean) - Method in interface org.infinispan.context.InvocationContextContainer
Deprecated.
Returns the InvocationContext that is currently associated with the calling thread.
getInvocationContextContainer() - Method in interface org.infinispan.AdvancedCache
Deprecated.
No longer in use, implementations might return null.
getInvocationContextContainer() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getInvocationContextContainer() - Method in class org.infinispan.cache.impl.CacheImpl
 
getInvocationContextContainer() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getInvocationContextContainer() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getIterator() - Method in class org.infinispan.stream.impl.IteratorResponses
 
getIterator(Object) - Method in class org.infinispan.stream.impl.IteratorHandler
 
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
 
getJoinInfo() - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
 
getJoinInfo() - Method in class org.infinispan.topology.ClusterCacheStatus
 
getKeepAliveTime() - Method in class org.infinispan.executors.ManageableExecutorService
 
getKey() - Method in class org.infinispan.affinity.impl.RndKeyGenerator
 
getKey() - Method in interface org.infinispan.affinity.KeyGenerator
 
getKey() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntryChange
 
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.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.ClearCacheEntry
 
getKey() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
getKey() - Method in class org.infinispan.container.entries.NullCacheEntry
 
getKey() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getKey() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
Deprecated.
 
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 class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
getKey() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryEvent
 
getKey() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getKey() - Method in class org.infinispan.notifications.cachelistener.EventWrapper
 
getKey() - Method in class org.infinispan.persistence.modifications.Remove
 
getKey() - Method in class org.infinispan.persistence.modifications.Store
 
getKey() - Method in exception org.infinispan.transaction.WriteSkewException
 
getKey() - Method in class org.infinispan.util.KeyValuePair
 
getKey(long) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
Returns the key of the address.
getKey(long) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
 
getKeyBytes() - Method in interface org.infinispan.marshall.core.MarshalledEntry
Returns the key in serialized format.
getKeyBytes() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl
 
getKeyDataConversion() - Method in interface org.infinispan.AdvancedCache
 
getKeyDataConversion() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getKeyDataConversion() - Method in class org.infinispan.cache.impl.CacheImpl
 
getKeyDataConversion() - Method in class org.infinispan.cache.impl.EncoderCache
 
getKeyDataConversion() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getKeyDataConversion() - Method in class org.infinispan.commands.functional.AbstractWriteKeyCommand
 
getKeyDataConversion() - Method in class org.infinispan.commands.functional.AbstractWriteManyCommand
 
getKeyDataConversion() - Method in interface org.infinispan.commands.functional.FunctionalCommand
 
getKeyDataConversion() - Method in class org.infinispan.commands.functional.ReadOnlyKeyCommand
 
getKeyDataConversion() - Method in class org.infinispan.commands.functional.ReadOnlyManyCommand
 
getKeyDataConversion() - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
 
getKeyDataConversion() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
getKeyDataConversion() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
getKeyDataConversion() - Method in class org.infinispan.notifications.cachelistener.ListenerHolder
 
getKeyDataConversion() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getKeyEncoder() - Method in interface org.infinispan.AdvancedCache
getKeyEncoder() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getKeyEncoder() - Method in class org.infinispan.cache.impl.CacheImpl
 
getKeyEncoder() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getKeyEncoder() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getKeyForAddress(Address) - Method in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
 
getKeyForAddress(Address) - Method in interface org.infinispan.affinity.KeyAffinityService
Returns a key that will be distributed on the cluster node identified by address.
getKeyLockOwner() - Method in class org.infinispan.commands.control.LockControlCommand
 
getKeyLockOwner() - Method in class org.infinispan.commands.functional.AbstractWriteManyCommand
 
getKeyLockOwner() - Method in class org.infinispan.commands.tx.PrepareCommand
 
getKeyLockOwner() - Method in class org.infinispan.commands.write.AbstractDataWriteCommand
 
getKeyLockOwner() - Method in class org.infinispan.commands.write.InvalidateCommand
 
getKeyLockOwner() - Method in class org.infinispan.commands.write.PutMapCommand
 
getKeyLockOwner() - Method in interface org.infinispan.util.concurrent.locks.RemoteLockCommand
It returns the lock owner of the key.
getKeyMapper() - Method in class org.infinispan.persistence.support.AbstractSegmentedAdvancedLoadWriteStore
 
getKeyMapper() - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
getKeyMapping(String) - Method in class org.infinispan.persistence.keymappers.DefaultTwoWayKey2StringMapper
 
getKeyMapping(String) - Method in interface org.infinispan.persistence.keymappers.TwoWayKey2StringMapper
Maps a String back to its original key
getKeyMapping(String) - Method in class org.infinispan.persistence.keymappers.WrappedByteArrayOrPrimitiveMapper
 
getKeyPartitioner() - Method in class org.infinispan.distribution.group.impl.PartitionerConsistentHash
 
getKeyPartitioner() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getKeyPartitioner() - Method in interface org.infinispan.persistence.spi.InitializationContext
The configured partitioner that can be used to determine which segment a given key belongs to.
getKeys() - Method in class org.infinispan.commands.control.LockControlCommand
 
getKeys() - Method in class org.infinispan.commands.functional.ReadOnlyManyCommand
 
getKeys() - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
getKeys() - Method in class org.infinispan.commands.read.GetAllCommand
 
getKeys() - Method in class org.infinispan.commands.remote.ClusteredGetAllCommand
 
getKeys() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
Deprecated.
 
getKeys() - Method in class org.infinispan.commands.write.InvalidateCommand
 
GetKeysInGroupCommand - Class in org.infinispan.commands.remote
VisitableCommand that fetches the keys belonging to a group.
GetKeysInGroupCommand() - Constructor for class org.infinispan.commands.remote.GetKeysInGroupCommand
 
GetKeysInGroupCommand(long, Object) - Constructor for class org.infinispan.commands.remote.GetKeysInGroupCommand
 
getKeysToLock() - Method in class org.infinispan.commands.control.LockControlCommand
 
getKeysToLock() - Method in class org.infinispan.commands.functional.ReadWriteManyCommand
 
getKeysToLock() - Method in class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
getKeysToLock() - Method in class org.infinispan.commands.functional.WriteOnlyManyCommand
 
getKeysToLock() - Method in class org.infinispan.commands.functional.WriteOnlyManyEntriesCommand
 
getKeysToLock() - Method in class org.infinispan.commands.tx.PrepareCommand
 
getKeysToLock() - Method in class org.infinispan.commands.write.AbstractDataWriteCommand
 
getKeysToLock() - Method in class org.infinispan.commands.write.InvalidateCommand
 
getKeysToLock() - Method in class org.infinispan.commands.write.InvalidateL1Command
 
getKeysToLock() - Method in class org.infinispan.commands.write.PutMapCommand
 
getKeysToLock() - Method in interface org.infinispan.util.concurrent.locks.RemoteLockCommand
It returns a Collection with the keys to be lock.
getKeysToRemove() - Method in class org.infinispan.persistence.support.BatchModification
 
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() - Constructor for class org.infinispan.commands.read.GetKeyValueCommand
 
GetKeyValueCommand(Object, int, long) - Constructor for class org.infinispan.commands.read.GetKeyValueCommand
 
getKeyWrapper() - Method in interface org.infinispan.AdvancedCache
getKeyWrapper() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getKeyWrapper() - Method in class org.infinispan.cache.impl.CacheImpl
 
getKeyWrapper() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getKeyWrapper() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getLargestPoolSize() - Method in class org.infinispan.executors.ManageableExecutorService
 
getLastStableTopology() - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
getLastStableTopology() - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
Deprecated.
getLastStableTopology() - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
getLastUsed() - Method in interface org.infinispan.container.entries.CacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
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.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.ReadCommittedEntry
 
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
 
getLeastSignificantBits() - Method in class org.infinispan.topology.PersistentUUID
 
getLength() - Method in class org.infinispan.io.GridFile.Metadata
 
getLevel() - Method in interface org.infinispan.util.logging.events.EventLog
 
getLifespan() - Method in interface org.infinispan.container.entries.CacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.ClearCacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
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.NullCacheEntry
 
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
 
getLimit() - Method in class org.infinispan.stream.impl.intops.object.LimitOperation
 
getLimit() - Method in class org.infinispan.stream.impl.intops.primitive.d.LimitDoubleOperation
 
getLimit() - Method in class org.infinispan.stream.impl.intops.primitive.i.LimitIntOperation
 
getLimit() - Method in class org.infinispan.stream.impl.intops.primitive.l.LimitLongOperation
 
getList() - Method in class org.infinispan.persistence.modifications.ModificationsList
 
getListAttributeValue(int) - Method in interface org.infinispan.configuration.parsing.XMLExtendedStreamReader
Get the value of an attribute as a space-delimited string list.
getListAttributeValue(String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
 
getListener() - Method in class org.infinispan.notifications.cachelistener.ListenerHolder
 
getListenerCollectionForAnnotation(Class<? extends Annotation>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
getListenerCollectionForAnnotation(Class<? extends Annotation>) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
 
getListeners() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getListeners() - Method in class org.infinispan.cache.impl.CacheImpl
 
getListeners() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getListeners() - Method in class org.infinispan.manager.DefaultCacheManager
 
getListeners() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getListeners() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
 
getListeners() - Method in interface org.infinispan.notifications.Listenable
 
getListeners() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getLocalAddress() - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
getLocalAddress() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
getLocalAddress() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
 
getLocalCacheName() - Method in exception org.infinispan.xsite.BackupFailureException
 
getLocalComponent(Class<T>) - Method in class org.infinispan.factories.ComponentRegistry
 
getLocalComponent(String, String, boolean) - Method in class org.infinispan.factories.ComponentRegistry
 
getLocalGlobalTransaction() - Method in class org.infinispan.transaction.impl.TransactionTable
 
getLocalGlobalTransaction() - Method in interface org.infinispan.transaction.TransactionTable
 
getLocality(Object) - Method in interface org.infinispan.distribution.DistributionManager
Deprecated.
Since 9.0, please use getCacheTopology().getDistributionInfo(key) instead.
getLocality(Object) - Method in class org.infinispan.distribution.impl.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.
getLocalPreparedXids() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
 
getLocalReadSegments() - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
getLocalTransaction() - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
getLocalTransaction(Transaction) - Method in class org.infinispan.transaction.impl.TransactionTable
 
getLocalTransaction(Xid) - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
getLocalTransaction(GlobalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
Looks up a LocalTransaction given a GlobalTransaction.
getLocalTransactions() - Method in class org.infinispan.transaction.impl.TransactionTable
 
getLocalTxCount() - Method in class org.infinispan.transaction.impl.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.container.offheap.StripedLock
Retrieves the read write lock attributed to the given object using its hashCode for lookup.
getLock(Object) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
 
getLock(Object) - Method in interface org.infinispan.util.concurrent.locks.impl.LockContainer
 
getLock(Object) - Method in class org.infinispan.util.concurrent.locks.impl.PerKeyLockContainer
 
getLock(Object) - Method in class org.infinispan.util.concurrent.locks.impl.StripedLockContainer
 
getLock(Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
 
getLockAcquisitionTimeout(FlagAffectedCommand, boolean) - Method in class org.infinispan.interceptors.base.CommandInterceptor
Deprecated.
 
getLockedKeys() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
getLockedKeys() - Method in class org.infinispan.context.impl.ClearInvocationContext
 
getLockedKeys() - Method in class org.infinispan.context.impl.ImmutableContext
 
getLockedKeys() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
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
Deprecated.
 
getLockedKeys() - Method in class org.infinispan.statetransfer.TransactionInfo
 
getLockedKeys() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getLockedKeys() - Method in class org.infinispan.transaction.impl.TotalOrderRemoteTransactionState
 
getLockedKeys() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
getLockFromHashCode(int) - Method in class org.infinispan.container.offheap.StripedLock
Retrieves the lock associated with the given hashCode
getLockIntention() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
Deprecated.
Returns the key this transaction intends to lock.
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.cache.impl.AbstractDelegatingAdvancedCache
 
getLockManager() - Method in class org.infinispan.cache.impl.CacheImpl
 
getLockManager() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getLockManager() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getLockOwner() - Method in class org.infinispan.cache.impl.DecoratedCache
 
getLockOwner() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
getLockOwner() - Method in class org.infinispan.context.impl.ClearInvocationContext
 
getLockOwner() - Method in class org.infinispan.context.impl.ImmutableContext
 
getLockOwner() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
getLockOwner() - Method in interface org.infinispan.context.InvocationContext
Returns the in behalf of which locks will be acquired.
getLockOwner() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
Deprecated.
 
getLockOwner() - Method in class org.infinispan.util.concurrent.locks.impl.InfinispanLock
 
getLocks() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
getLocksHeldAtOrigin() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
Deprecated.
 
getLockTimeoutMillis(FlagAffectedCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
getLockWithOffset(int) - Method in class org.infinispan.container.offheap.StripedLock
Retrieves the given lock at a provided offset.
getLog() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
getLog() - Method in class org.infinispan.factories.ComponentRegistry
 
getLog() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getLog() - Method in class org.infinispan.interceptors.base.CommandInterceptor
Deprecated.
 
getLog() - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
getLog() - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
 
getLog() - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
getLog() - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
getLog() - Method in class org.infinispan.interceptors.distribution.VersionedDistributionInterceptor
 
getLog() - Method in class org.infinispan.interceptors.impl.BaseRpcInterceptor
 
getLog() - Method in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor
 
getLog() - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
getLog() - Method in class org.infinispan.interceptors.impl.DistCacheWriterInterceptor
 
getLog() - Method in class org.infinispan.interceptors.impl.InvalidationInterceptor
 
getLog() - Method in class org.infinispan.interceptors.impl.PassivationWriterInterceptor
 
getLog() - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor
 
getLog() - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
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.totalorder.TotalOrderDistributionInterceptor
 
getLog() - Method in class org.infinispan.interceptors.totalorder.TotalOrderStateTransferInterceptor
 
getLog() - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedDistributionInterceptor
 
getLog() - Method in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
 
getLog() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
getLog() - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
getLog() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
 
getLog() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
 
getLog() - Method in class org.infinispan.remoting.inboundhandler.NonTotalOrderPerCacheInboundInvocationHandler
 
getLog() - Method in class org.infinispan.remoting.inboundhandler.NonTotalOrderTxPerCacheInboundInvocationHandler
 
getLog() - Method in class org.infinispan.remoting.inboundhandler.TotalOrderTxPerCacheInboundInvocationHandler
 
getLog() - Method in class org.infinispan.remoting.inboundhandler.TrianglePerCacheInboundInvocationHandler
 
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.stream.impl.AbstractCacheStream
 
getLog() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
getLog() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
getLog() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
getLog() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
getLog(Class<?>) - Static method in class org.infinispan.util.logging.LogFactory
 
getLog(Class<?>, Class<T>) - Static method in class org.infinispan.util.logging.LogFactory
 
getLogger(String) - Static method in class org.infinispan.util.logging.LogFactory
 
getLoggingLocale() - Method in class org.infinispan.security.impl.AuditMessages_$logger
 
getLoggingLocale() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
getLoggingLocale() - Method in class org.infinispan.util.logging.Log_$logger
 
getLookedUpEntries() - Method in interface org.infinispan.context.EntryLookup
Deprecated.
getLookedUpEntries() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
getLookedUpEntries() - Method in class org.infinispan.context.impl.ClearInvocationContext
 
getLookedUpEntries() - Method in class org.infinispan.context.impl.ImmutableContext
 
getLookedUpEntries() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
getLookedUpEntries() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
Deprecated.
 
getLookedUpEntries() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getLookedUpEntries() - Method in class org.infinispan.transaction.impl.LocalTransaction
 
getLookedUpEntries() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
getLookedUpRemoteVersion(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
Deprecated.
since 9.0
getMachineId() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
 
getMachineId() - Method in interface org.infinispan.remoting.transport.TopologyAwareAddress
 
getMachineNodes(String, String, String) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getMajor() - Method in class org.infinispan.configuration.parsing.Schema
 
getMajor() - Static method in class org.infinispan.Version
 
getMajorMinor() - Static method in class org.infinispan.Version
 
getMap() - Method in class org.infinispan.commands.write.PutMapCommand
 
getMapForSegment(int) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
getMapForSegment(int) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
getMapForSegment(int) - Method in class org.infinispan.container.impl.DefaultDataContainer
 
getMapForSegment(int) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
getMapForSegment(int) - Method in class org.infinispan.container.impl.L1SegmentedDataContainer
 
getMapForSegment(int) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
getMappingFunction() - Method in class org.infinispan.commands.write.ComputeIfAbsentCommand
 
getMapThatContainsKey(byte[]) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
getMapThatContainsKey(byte[]) - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
getMarshalledEntries() - Method in class org.infinispan.persistence.support.BatchModification
 
getMarshalledEntryFactory() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getMarshalledEntryFactory() - Method in interface org.infinispan.persistence.spi.InitializationContext
To be used for building MarshalledEntry objects.
getMarshaller() - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
getMarshaller() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getMarshaller() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
getMarshaller() - Method in interface org.infinispan.persistence.spi.InitializationContext
 
getMarshallVersion() - Static method in class org.infinispan.Version
 
getMask() - Method in enum org.infinispan.security.AuthorizationPermission
 
getMask() - Method in class org.infinispan.security.impl.CacheRoleImpl
 
getMask() - Method in class org.infinispan.security.impl.SubjectACL
 
getMask() - Method in interface org.infinispan.security.Role
Returns a pre-computed access mask which contains the permissions specified by this role
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 interface org.infinispan.container.entries.CacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.ClearCacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
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.NullCacheEntry
 
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
 
getMaximumPoolSize() - Method in class org.infinispan.executors.ManageableExecutorService
 
getMaximumXSiteReplicationTime() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getMaxNumberOfKeys() - Method in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
 
getMaxSize() - Method in class org.infinispan.interceptors.impl.TransactionalExceptionEvictionInterceptor
 
getMBeanInfo() - Method in class org.infinispan.jmx.ResourceDMBean
 
getMBeanServer(Properties) - Method in class org.infinispan.jmx.JBossMBeanServerLookup
Deprecated.
 
getMBeanServer(Properties) - Method in class org.infinispan.jmx.PlatformMBeanServerLookup
Deprecated.
 
getMembers() - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
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.impl.AbstractConsistentHash
 
getMembers() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
getMembers() - Method in class org.infinispan.distribution.group.impl.PartitionerConsistentHash
 
getMembers() - Method in class org.infinispan.manager.DefaultCacheManager
getMembers() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getMembers() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
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.ClusterView
 
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
 
getMembersAtEnd() - Method in interface org.infinispan.notifications.cachelistener.event.DataRehashedEvent
 
getMembersAtEnd() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getMembersAtStart() - Method in interface org.infinispan.notifications.cachelistener.event.DataRehashedEvent
 
getMembersAtStart() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getMembersPersistentUUIDs() - Method in class org.infinispan.topology.CacheTopology
 
getMembersSet() - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
getMembersSet() - Method in class org.infinispan.remoting.transport.jgroups.ClusterView
 
getMemoryAddress(Object) - Method in class org.infinispan.container.offheap.MemoryAddressHash
 
getMemoryAddressOffset(int) - Method in class org.infinispan.container.offheap.MemoryAddressHash
 
getMemoryAddressOffsetNoTraceIfAbsent(int) - Method in class org.infinispan.container.offheap.MemoryAddressHash
 
getMemoryAvailable() - Method in interface org.infinispan.stats.ClusterContainerStats
 
getMemoryAvailable() - Method in class org.infinispan.stats.impl.ClusterContainerStatsImpl
 
getMemoryMax() - Method in interface org.infinispan.stats.ClusterContainerStats
 
getMemoryMax() - Method in class org.infinispan.stats.impl.ClusterContainerStatsImpl
 
getMemoryTotal() - Method in interface org.infinispan.stats.ClusterContainerStats
 
getMemoryTotal() - Method in class org.infinispan.stats.impl.ClusterContainerStatsImpl
 
getMemoryUsed() - Method in interface org.infinispan.stats.ClusterContainerStats
 
getMemoryUsed() - Method in class org.infinispan.stats.impl.ClusterContainerStatsImpl
 
getMessage() - Method in interface org.infinispan.util.logging.events.EventLog
 
getMessage() - Method in exception org.infinispan.xsite.BackupFailureException
 
getMetadata() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.ValueAndMetadata
 
getMetadata() - Method in interface org.infinispan.commands.MetadataAwareCommand
Get metadata of this command.
getMetadata() - Method in class org.infinispan.commands.write.ComputeCommand
 
getMetadata() - Method in class org.infinispan.commands.write.ComputeIfAbsentCommand
 
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.RemoveCommand
 
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.ClearCacheEntry
 
getMetadata() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
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.NullCacheEntry
 
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
Deprecated.
 
getMetadata() - Method in interface org.infinispan.marshall.core.MarshalledEntry
 
getMetadata() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl
 
getMetadata() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
getMetadata() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryEvent
Retrieves the metadata associated with the entry.
getMetadata() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
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
 
getMethod() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMethodMetadata
 
getMethod() - Method in class org.infinispan.factories.components.ComponentMetadata.PrioritizedMethodMetadata
 
getMethod() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
getMethodName() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMethodMetadata
 
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
 
getMinimumXSiteReplicationTime() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getMinor() - Method in class org.infinispan.configuration.parsing.Schema
 
getMinSize() - Method in class org.infinispan.interceptors.impl.TransactionalExceptionEvictionInterceptor
 
getMinTopologyId() - Method in class org.infinispan.transaction.impl.TransactionTable
 
getMisses() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
getMisses() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getMisses() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getMisses() - Method in class org.infinispan.stats.impl.StatsCollector
 
getMisses() - Method in class org.infinispan.stats.impl.StatsImpl
 
getMisses() - Method in interface org.infinispan.stats.Stats
 
getMixedCaches() - Method in class org.infinispan.xsite.status.ContainerMixedSiteStatus
 
getMode() - Method in enum org.infinispan.configuration.cache.TransactionMode
 
getMode() - Method in enum org.infinispan.configuration.parsing.Parser.TransactionMode
 
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.AbstractTxInvocationContext
 
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.impl.AbstractCacheTransaction
 
getModifications() - Method in interface org.infinispan.transaction.xa.CacheTransaction
Returns the modifications visible within the current transaction.
getModificationTime() - Method in class org.infinispan.io.GridFile.Metadata
 
getModuleCommandFactory() - Method in interface org.infinispan.commands.module.ModuleCommandExtensions
 
getModuleCommandInitializer() - Method in interface org.infinispan.commands.module.ModuleCommandExtensions
 
getModuleCommandInitializers() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getModuleCommands() - Method in interface org.infinispan.commands.module.ModuleCommandFactory
Provides a map of command IDs to command types of all the commands handled by the command factory instance.
getModuleMetadataFiles(ClassLoader) - Static method in class org.infinispan.util.ModuleProperties
Retrieves an Iterable containing metadata file finders declared by each module.
getModuleProperties() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getModuleSlot() - Static method in class org.infinispan.Version
 
getMostSignificantBits() - Method in class org.infinispan.topology.PersistentUUID
 
getName() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getName() - Method in class org.infinispan.cache.impl.CacheImpl
 
getName() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getName() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
Deprecated.
 
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 interface org.infinispan.factories.impl.ComponentRef
 
getName() - Method in class org.infinispan.factories.threads.DefaultThreadFactory
 
getName() - Method in interface org.infinispan.functional.FunctionalMap
Functional map's name.
getName() - Method in class org.infinispan.functional.impl.FunctionalMapImpl
 
getName() - Method in class org.infinispan.globalstate.ScopedState
 
getName() - Method in class org.infinispan.io.GridFile
 
getName() - Method in class org.infinispan.manager.DefaultCacheManager
 
getName() - Method in class org.infinispan.security.impl.CacheRoleImpl
 
getName() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getName() - Method in interface org.infinispan.security.Role
Returns the name of this role
getName() - Method in interface org.infinispan.upgrade.TargetMigrator
Returns the name of this migrator
getNamedComponentRegistry(String) - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getNamedComponentRegistry(ByteString) - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getNamedConfigurationBuilders() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
getNamespaceAnnotations(Class<?>) - Static method in class org.infinispan.configuration.parsing.ParseUtils
 
getNamespaceContext() - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
getNamespaces() - Method in interface org.infinispan.configuration.parsing.ConfigurationParser
 
getNamespaces() - Method in class org.infinispan.configuration.parsing.Parser
 
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.
getNewMembers() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.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.impl.EventImpl
 
getNewTopologyId() - Method in interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
 
getNewTopologyId(Throwable, int, TopologyAffectedCommand) - Method in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor
 
getNewValue() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntryChange
 
getNewValue() - Method in class org.infinispan.commands.write.ReplaceCommand
 
getNext() - Method in class org.infinispan.container.impl.AbstractInternalDataContainer.EntryIterator
 
getNext() - Method in class org.infinispan.interceptors.base.CommandInterceptor
Deprecated.
Retrieves the next interceptor in the chain.
getNext(long) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
Returns the address to the next linked pointer if there is one for this bucket or 0 if there isn't one
getNext(long) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
 
getNodeAddress() - Method in class org.infinispan.manager.DefaultCacheManager
 
getNodeNames() - Method in interface org.infinispan.health.ClusterHealth
Returns node names.
getNodeNames() - Method in class org.infinispan.health.impl.ClusterHealthImpl
 
getNonCacheComponents(Collection<ResourceDMBean>) - Method in class org.infinispan.jmx.CacheJmxRegistration
 
getNormalizedHash(Object) - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
getNumberOfCpus() - Method in interface org.infinispan.health.HostInfo
Returns the number of CPUs installed in the host.
getNumberOfCpus() - Method in class org.infinispan.health.impl.HostInfoImpl
 
getNumberOfCpus() - Method in class org.infinispan.health.impl.jmx.HealthJMXExposerImpl
 
getNumberOfCpus() - Method in interface org.infinispan.health.jmx.HealthJMXExposer
Returns the total amount of CPUs for the JVM.
getNumberOfEntries() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
getNumberOfEntries() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getNumberOfEntries() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getNumberOfEntries() - Method in class org.infinispan.stats.impl.StatsCollector
 
getNumberOfEntriesInMemory() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
getNumberOfLocksAvailable() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getNumberOfLocksAvailable() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getNumberOfLocksAvailable() - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
 
getNumberOfLocksHeld() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getNumberOfLocksHeld() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getNumberOfLocksHeld() - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
 
getNumberOfLocksHeld() - Method in interface org.infinispan.util.concurrent.locks.LockManager
 
getNumberOfNodes() - Method in interface org.infinispan.health.ClusterHealth
Returns the number of nodes in the cluster.
getNumberOfNodes() - Method in class org.infinispan.health.impl.ClusterHealthImpl
 
getNumberOfNodes() - Method in class org.infinispan.health.impl.jmx.HealthJMXExposerImpl
 
getNumberOfNodes() - Method in interface org.infinispan.health.jmx.HealthJMXExposer
Returns total nodes in the cluster.
getNumberOfPersistedEntries() - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
getNumLocksHeld() - Method in interface org.infinispan.util.concurrent.locks.impl.LockContainer
 
getNumLocksHeld() - Method in class org.infinispan.util.concurrent.locks.impl.PerKeyLockContainer
 
getNumLocksHeld() - Method in class org.infinispan.util.concurrent.locks.impl.StripedLockContainer
 
getNumOwners() - Method in interface org.infinispan.distribution.ch.ConsistentHash
Deprecated.
Since 9.1, it should not be used to obtain the number of owners of a particular key.
getNumOwners() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
 
getNumOwners() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
getNumOwners() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
 
getNumOwners() - Method in class org.infinispan.distribution.group.impl.PartitionerConsistentHash
 
getNumOwners() - Method in class org.infinispan.topology.CacheJoinInfo
 
getNumSegments() - Method in interface org.infinispan.distribution.ch.ConsistentHash
 
getNumSegments() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
 
getNumSegments() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
getNumSegments() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
getNumSegments() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
 
getNumSegments() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
getNumSegments() - Method in class org.infinispan.distribution.group.impl.PartitionerConsistentHash
 
getNumSegments() - Method in class org.infinispan.topology.CacheJoinInfo
 
getNumSegments() - Method in class org.infinispan.util.StripedHashFunction
 
getObjectName() - Method in class org.infinispan.jmx.ResourceDMBean
 
getObjectName(String) - Method in class org.infinispan.jmx.ComponentsJmxRegistration
 
getObjectName(String, String, String) - Static method in class org.infinispan.jmx.ComponentsJmxRegistration
 
getObservation() - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
 
getObservation() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
getObservation() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
getObservation() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
getOffHeapMemoryUsed() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
getOffHeapMemoryUsed() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getOffHeapMemoryUsed() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getOffHeapMemoryUsed() - Method in class org.infinispan.stats.impl.StatsCollector
 
getOffHeapMemoryUsed() - Method in class org.infinispan.stats.impl.StatsImpl
 
getOffHeapMemoryUsed() - Method in interface org.infinispan.stats.Stats
The amount of off-heap memory used by this cache
getOffline() - Method in class org.infinispan.xsite.status.AbstractMixedSiteStatus
 
getOfflineStatus(String) - Method in interface org.infinispan.xsite.BackupSender
 
getOfflineStatus(String) - Method in class org.infinispan.xsite.BackupSenderImpl
 
getOldMembers() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
getOldMembers() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
Gets the previous list of members.
getOldMetadata() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntryChange
 
getOldMetadata() - Method in class org.infinispan.container.entries.RepeatableReadEntry
 
getOldMetadata() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getOldValue() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntryChange
 
getOldValue() - Method in class org.infinispan.commands.write.ReplaceCommand
 
getOldValue() - Method in class org.infinispan.container.entries.RepeatableReadEntry
 
getOldValue() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
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.impl.EventImpl
 
getOnline() - Method in class org.infinispan.xsite.status.AbstractMixedSiteStatus
 
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
 
getOperator() - Method in class org.infinispan.stream.impl.intops.primitive.d.MapDoubleOperation
 
getOperator() - Method in class org.infinispan.stream.impl.intops.primitive.i.MapIntOperation
 
getOperator() - Method in class org.infinispan.stream.impl.intops.primitive.l.MapLongOperation
 
getOptionalComponent(Class<T>) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
getOrCreateCache(String, String) - Method in class org.infinispan.manager.DefaultCacheManagerAdmin
 
getOrCreateCache(String, String) - Method in interface org.infinispan.manager.EmbeddedCacheManagerAdmin
Retrieves an existing cache or creates one using the specified template if it doesn't exist
getOrCreateCache(String, String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.GlobalConfigurationManager
Defines a cluster-wide cache configuration using the supplied template or retrieves an existing one
getOrCreateCache(String, String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.GlobalConfigurationManagerImpl
 
getOrCreateCache(String, Configuration) - Method in class org.infinispan.manager.DefaultCacheManagerAdmin
 
getOrCreateCache(String, Configuration) - Method in interface org.infinispan.manager.EmbeddedCacheManagerAdmin
Retrieves an existing cache or creates one across the cluster using the specified configuration.
getOrCreateCache(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.GlobalConfigurationManager
Defines a cluster-wide cache configuration or retrieves an existing one
getOrCreateCache(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.GlobalConfigurationManagerImpl
 
getOrCreateComponent(Class<T>) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
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
Deprecated.
 
getOrCreateComponent(Class<T>, String, boolean) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
getOrCreateComponent(Class<T>, String, boolean) - Method in class org.infinispan.factories.ComponentRegistry
 
getOrCreateLocalTransaction(Transaction, boolean) - Method in class org.infinispan.transaction.impl.TransactionTable
Returns the TransactionXaAdapter corresponding to the supplied transaction.
getOrCreateLocalTransaction(Transaction, boolean, Supplier<GlobalTransaction>) - Method in class org.infinispan.transaction.impl.TransactionTable
Similar to TransactionTable.getOrCreateLocalTransaction(Transaction, boolean) but with a custom global transaction factory.
getOrCreateRemoteTransaction(GlobalTransaction, WriteCommand[]) - Method in class org.infinispan.transaction.impl.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.cache.impl.AbstractDelegatingCache
 
getOrDefault(Object, V) - Method in class org.infinispan.cache.impl.EncoderCache
 
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
 
getOrigin() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
Deprecated.
 
getOrigin() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
getOriginSite() - Method in class org.infinispan.xsite.XSiteReplicateCommand
 
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.
getOwned(Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
getOwned(Address) - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
 
getOwned(Address) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
getOwnedPerCapacity(Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
getOwnedSegments(ConsistentHash) - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
getOwner() - Method in interface org.infinispan.util.concurrent.locks.ExtendedLockPromise
 
getOwner(Object) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
 
getOwner(Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Retrieves the owner of the lock for the key.
getOwnerAddress() - Method in class org.infinispan.notifications.cachelistener.cluster.RemoteClusterListener
 
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.
getOwners(int) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
getOwners(Object) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
Deprecated.
Since 9.0, please use getCacheTopology().getWriteOwners(key) instead.
getOwners(Object) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.ReplicationLogic
 
getOwners(Collection<Object>) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
Deprecated.
Since 9.0, please use getCacheTopology().getWriteOwners(keys) instead.
getOwners(Collection<Object>) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.ReplicationLogic
 
getParameterClasses() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMethodMetadata
 
getParameterLazy(int) - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMethodMetadata
 
getParameterName(int) - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMethodMetadata
Deprecated.
getParameters() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMethodMetadata
 
getParams() - Method in class org.infinispan.commands.functional.AbstractWriteKeyCommand
 
getParams() - Method in class org.infinispan.commands.functional.AbstractWriteManyCommand
 
getParams() - Method in interface org.infinispan.commands.functional.FunctionalCommand
 
getParams() - Method in class org.infinispan.commands.functional.ReadOnlyKeyCommand
 
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
 
getPartialTransactions() - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
getPartialTransactions() - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
 
getPartialTransactions() - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
getPassivations() - Method in class org.infinispan.eviction.impl.PassivationManagerImpl
 
getPassivations() - Method in class org.infinispan.eviction.impl.PassivationManagerStub
 
getPassivations() - Method in interface org.infinispan.eviction.PassivationManager
 
getPassivations() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getPassivations() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
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
 
getPendingCommands() - Method in class org.infinispan.util.concurrent.CommandAckCollector
 
getPendingViewAsString() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getPerCacheInboundInvocationHandler() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getComponent(PerCacheInboundInvocationHandler.class);
getPermissions() - Method in class org.infinispan.security.impl.CacheRoleImpl
 
getPermissions() - Method in interface org.infinispan.security.Role
Returns the list of permissions associated with this role
getPersistentStateChecksum() - Method in class org.infinispan.topology.CacheJoinInfo
 
getPersistentUuid(Address) - Method in interface org.infinispan.topology.PersistentUUIDManager
Retrieves the PersistentUUID of a node given its Address
getPersistentUuid(Address) - Method in class org.infinispan.topology.PersistentUUIDManagerImpl
 
getPersistentUUID() - Method in class org.infinispan.topology.CacheJoinInfo
 
getPersistentUUID() - Method in interface org.infinispan.topology.LocalTopologyManager
Returns the local UUID of this node.
getPersistentUUID() - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
getPersistentUUID() - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
getPhase() - Method in class org.infinispan.topology.CacheTopology
 
getPhase() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
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.
getPoolSize() - Method in class org.infinispan.executors.ManageableExecutorService
 
getPostStartMethods() - Method in class org.infinispan.factories.components.ComponentMetadata
 
getPredicate() - Method in class org.infinispan.stream.impl.intops.object.FilterOperation
 
getPredicate() - Method in class org.infinispan.stream.impl.intops.primitive.d.FilterDoubleOperation
 
getPredicate() - Method in class org.infinispan.stream.impl.intops.primitive.i.FilterIntOperation
 
getPredicate() - Method in class org.infinispan.stream.impl.intops.primitive.l.FilterLongOperation
 
getPrefix(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
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.impl.TxInterceptor
 
getPrevMetadata() - Method in class org.infinispan.commands.functional.ReadWriteKeyValueCommand
 
getPrevValue() - Method in class org.infinispan.commands.functional.ReadWriteKeyValueCommand
 
getPrimaryLocation(Object) - Method in interface org.infinispan.distribution.DistributionManager
Deprecated.
Since 9.0, please use getCacheTopology().getDistributionInfo(key) instead.
getPrimaryLocation(Object) - Method in class org.infinispan.distribution.impl.DistributionManagerImpl
 
getPrimaryOwned(Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
getPrimaryOwned(Address) - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
 
getPrimaryOwned(Address) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
getPrimaryOwnedPerCapacity(Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
getPrimaryOwner(int) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
getPrimaryOwner(int) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
getPrimaryOwner(Object) - Method in interface org.infinispan.distribution.group.impl.GroupManager
Deprecated.
Since 9.0, please use DistributionManager.getCacheTopology() instead.
getPrimaryOwner(Object) - Method in class org.infinispan.distribution.group.impl.GroupManagerImpl
 
getPrimaryOwner(Object) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
Deprecated.
Since 9.0, please use getCacheTopology().getDistributionInfo(key).primary() instead.
getPrimarySegmentsForOwner(Address) - Method in interface org.infinispan.distribution.ch.ConsistentHash
Returns the segments that this cache member is the primary owner for.
getPrimarySegmentsForOwner(Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
 
getPrimarySegmentsForOwner(Address) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
getPrimarySegmentsForOwner(Address) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
 
getPrimarySegmentsForOwner(Address) - Method in class org.infinispan.distribution.group.impl.PartitionerConsistentHash
 
getPriority() - Method in class org.infinispan.factories.components.ComponentMetadata.PrioritizedMethodMetadata
 
getPrivateSingletonSetClass() - Static method in class org.infinispan.marshall.exts.CollectionExternalizer
 
getPrivateSynchronizedSetClass() - Static method in class org.infinispan.marshall.exts.CollectionExternalizer
 
getProperty(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
getProperty(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
getProperty(String) - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
 
getProperty(String) - Method in interface org.infinispan.globalstate.ScopedPersistentState
Retrieves a state property
getPushStateStatus() - Method in class org.infinispan.xsite.XSiteAdminOperations
 
getQueueSize() - Method in class org.infinispan.executors.ManageableExecutorService
 
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
 
getRawBuffer() - Method in class org.infinispan.io.ExposedByteArrayOutputStream
Deprecated.
Gets the internal buffer array.
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.impl.DistributionManagerImpl
 
getReadConsistentHash() - Method in class org.infinispan.topology.CacheTopology
Read operations should always go to the "current" owners.
getReadConsistentHashAtEnd() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getReadConsistentHashAtEnd() - Method in interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
 
getReadConsistentHashAtStart() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getReadConsistentHashAtStart() - Method in interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
 
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.impl.CacheMgmtInterceptor
 
getReadWriteRatio() - Method in interface org.infinispan.stats.CacheContainerStats
 
getReadWriteRatio() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getReadWriteRatio() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getReadWriteRatio() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getReadWriteRatio() - Method in class org.infinispan.stats.impl.StatsCollector
 
getRebalanceId() - Method in class org.infinispan.topology.CacheTopology
The id of the latest started rebalance.
getRebalancingStatus() - Method in interface org.infinispan.statetransfer.StateTransferManager
 
getRebalancingStatus() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
getRebalancingStatus() - Method in class org.infinispan.topology.ClusterCacheStatus
 
getRebalancingStatus(String) - Method in interface org.infinispan.topology.ClusterTopologyManager
Retrieves the rebalancing status of a cache
getRebalancingStatus(String) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
getRebalancingStatus(String) - Method in interface org.infinispan.topology.LocalTopologyManager
Retrieve the rebalancing status for the specified cache
getRebalancingStatus(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
getRebalancingStatus(String) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
getRegisteredComponents() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
Returns an immutable set containing all the components that exists in the repository at this moment.
getRegisteredComponents() - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
Run consumer for each registered component in the current scope.
getRegisteredComponents() - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
 
getReleaseFutureForKey(Object) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getReleaseFutureForKey(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
It returns a CompletableFuture that completes when the lock for the key is released.
getReleaseFutureForKeys(Collection<Object>) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getReleaseFutureForKeys(Collection<Object>) - Method in interface org.infinispan.transaction.xa.CacheTransaction
Same as CacheTransaction.getReleaseFutureForKey(Object) but it returns a pair with the key and the future.
getRemainingTimeout() - Method in interface org.infinispan.util.concurrent.locks.PendingLockPromise
 
getRemappingBiFunction() - Method in class org.infinispan.commands.write.ComputeCommand
 
getRemoteBias(Object) - Method in interface org.infinispan.scattered.BiasManager
 
getRemoteBias(Object) - Method in class org.infinispan.scattered.impl.BiasManagerImpl
 
getRemoteExecutor() - Method in class org.infinispan.remoting.inboundhandler.TrianglePerCacheInboundInvocationHandler
 
getRemoteGlobalTransaction() - Method in class org.infinispan.transaction.impl.TransactionTable
 
getRemoteGlobalTransaction() - Method in interface org.infinispan.transaction.TransactionTable
 
getRemoteLockIntention() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
Deprecated.
 
getRemoteLocksAcquired() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
getRemoteLocksAcquired() - Method in class org.infinispan.transaction.impl.LocalTransaction
 
getRemoteSiteNames() - Method in exception org.infinispan.xsite.BackupFailureException
 
getRemoteTransaction(GlobalTransaction) - Method in class org.infinispan.transaction.impl.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.impl.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.impl.TransactionTable
 
getRemoveHits() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
getRemoveHits() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getRemoveHits() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getRemoveHits() - Method in class org.infinispan.stats.impl.StatsCollector
 
getRemoveHits() - Method in class org.infinispan.stats.impl.StatsImpl
 
getRemoveHits() - Method in interface org.infinispan.stats.Stats
 
getRemoveMisses() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
getRemoveMisses() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getRemoveMisses() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getRemoveMisses() - Method in class org.infinispan.stats.impl.StatsCollector
 
getRemoveMisses() - Method in class org.infinispan.stats.impl.StatsImpl
 
getRemoveMisses() - Method in interface org.infinispan.stats.Stats
 
getReplicationCount() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getReplicationFailures() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getRequestId() - Method in class org.infinispan.remoting.transport.AbstractRequest
 
getRequestId() - Method in interface org.infinispan.remoting.transport.impl.Request
 
getRequestMediaType() - Method in class org.infinispan.encoding.DataConversion
 
getRequestor() - Method in interface org.infinispan.util.concurrent.locks.ExtendedLockPromise
 
getRequiredMinimumNumberOfNodes() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
getRequiredMinimumNumberOfNodes() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getRequiredMinimumNumberOfNodes() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getRequiredMinimumNumberOfNodes() - Method in class org.infinispan.stats.impl.StatsCollector
 
getRequiredMinimumNumberOfNodes() - Method in class org.infinispan.stats.impl.StatsImpl
 
getRequiredMinimumNumberOfNodes() - Method in interface org.infinispan.stats.Stats
 
getResourceDMBean(Object) - Method in class org.infinispan.jmx.AbstractJmxRegistration
 
getResourceDMBean(Object, String) - Method in class org.infinispan.jmx.AbstractJmxRegistration
 
getResourceDMBeansFromComponents(Collection<ComponentRef<?>>) - Method in class org.infinispan.jmx.AbstractJmxRegistration
 
getResponse(CacheRpcCommand, Object) - Method in class org.infinispan.remoting.responses.DefaultResponseGenerator
 
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
 
getResponseValue() - Method in class org.infinispan.remoting.responses.UnsuccessfulResponse
 
getResponseValue() - Method in class org.infinispan.remoting.responses.UnsureResponse
 
getResponseValue() - Method in class org.infinispan.remoting.responses.ValidResponse
 
getRetrievals() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getRetrievals() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getRetrievals() - Method in class org.infinispan.stats.impl.StatsCollector
 
getRetrievals() - Method in class org.infinispan.stats.impl.StatsImpl
 
getRetrievals() - Method in interface org.infinispan.stats.Stats
 
getReturnType() - Method in class org.infinispan.factories.components.JmxOperationMetadata
 
getRoles() - Method in class org.infinispan.security.impl.SubjectACL
 
getRollbacks() - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
getRootCause(Throwable) - Method in class org.infinispan.jmx.ResourceDMBean
 
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.impl.DefaultConsistentHash
 
getRoutingTableAsString() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
getRoutingTableAsString() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
 
getRoutingTableAsString() - Method in class org.infinispan.distribution.group.impl.PartitionerConsistentHash
 
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.cache.impl.AbstractDelegatingAdvancedCache
 
getRpcManager() - Method in class org.infinispan.cache.impl.CacheImpl
 
getRpcManager() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getRpcManager() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getRpcOptionsBuilder(ResponseMode) - Method in interface org.infinispan.remoting.rpc.RpcManager
Deprecated.
Since 9.2, please use RpcManager.getSyncRpcOptions() instead.
getRpcOptionsBuilder(ResponseMode) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getRpcOptionsBuilder(ResponseMode, DeliverOrder) - Method in interface org.infinispan.remoting.rpc.RpcManager
Deprecated.
Since 9.2, please use RpcManager.getSyncRpcOptions() instead.
getRpcOptionsBuilder(ResponseMode, DeliverOrder) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getRunningCacheCount() - Method in class org.infinispan.manager.DefaultCacheManager
 
getRunningStateTransfer() - Method in class org.infinispan.xsite.XSiteAdminOperations
for debug only!
getRunningStateTransfers() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
 
getRunningStateTransfers() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
getScheduledExecutor(Properties) - Method in class org.infinispan.executors.DefaultScheduledExecutorFactory
 
getScheduledExecutor(Properties) - Method in interface org.infinispan.executors.ScheduledExecutorFactory
 
getScheduledExecutor(Properties, AccessControlContext) - Method in class org.infinispan.executors.DefaultScheduledExecutorFactory
 
getScheduledExecutor(Properties, AccessControlContext) - Method in interface org.infinispan.executors.SecurityAwareScheduledExecutorFactory
 
getScheduledTasks() - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
getSchema() - Method in interface org.infinispan.configuration.parsing.XMLExtendedStreamReader
Returns the schema of currently being processed
getSchemaVersion() - Static method in class org.infinispan.Version
 
getScope() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
getScope() - Method in class org.infinispan.factories.components.ComponentMetadata
 
getScope() - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
 
getScope() - Method in interface org.infinispan.globalstate.ScopedPersistentState
Returns the name of this persistent state's scope
getScope() - Method in class org.infinispan.globalstate.ScopedState
 
getScope() - Method in interface org.infinispan.util.logging.events.EventLog
 
getSecurityPermission() - Method in enum org.infinispan.security.AuthorizationPermission
 
getSegment() - Method in class org.infinispan.commands.read.AbstractDataCommand
 
getSegment() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
getSegment() - Method in class org.infinispan.commands.remote.expiration.RetrieveLastAccessCommand
 
getSegment() - Method in class org.infinispan.commands.remote.expiration.UpdateLastAccessCommand
 
getSegment() - Method in interface org.infinispan.commands.SegmentSpecificCommand
Returns the segment that this key maps to.
getSegment(Object) - Method in interface org.infinispan.distribution.ch.ConsistentHash
getSegment(Object) - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
getSegment(Object) - Method in class org.infinispan.distribution.ch.impl.AffinityPartitioner
 
getSegment(Object) - Method in class org.infinispan.distribution.ch.impl.HashFunctionPartitioner
 
getSegment(Object) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
getSegment(Object) - Method in class org.infinispan.distribution.ch.impl.SingleSegmentKeyPartitioner
 
getSegment(Object) - Method in interface org.infinispan.distribution.ch.KeyPartitioner
Obtains the segment for a key.
getSegment(Object) - Method in class org.infinispan.distribution.group.impl.GroupingPartitioner
 
getSegment(Object) - Method in class org.infinispan.distribution.group.impl.PartitionerConsistentHash
 
getSegment(Object) - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
getSegmentDistribution(int) - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
getSegmentEndHashes() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
Deprecated.
getSegmentEndHashes() - Method in class org.infinispan.distribution.ch.impl.HashFunctionPartitioner
 
getSegmentForKey(Object) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
getSegmentForKey(Object) - Method in class org.infinispan.container.impl.DefaultDataContainer
 
getSegmentForKey(Object) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
getSegmentForKey(Object) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
getSegmentId() - Method in class org.infinispan.commands.triangle.BackupWriteCommand
 
getSegmentId() - Method in class org.infinispan.statetransfer.StateChunk
 
getSegments() - Method in class org.infinispan.statetransfer.InboundTransferTask
Returns a copy of segments currently tied to this task
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.impl.DefaultConsistentHash
 
getSegmentsForOwner(Address) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
getSegmentsForOwner(Address) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
 
getSegmentsForOwner(Address) - Method in class org.infinispan.distribution.group.impl.PartitionerConsistentHash
 
getSegmentState(int) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
getSegmentState(int) - Method in interface org.infinispan.scattered.ScatteredVersionManager
 
getSendingSiteName() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateConsumer
 
getSendingSiteName() - Method in class org.infinispan.xsite.statetransfer.XSiteStateConsumerImpl
 
getSendingSiteName() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
 
getSendingSiteName() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
getSendingSiteName() - Method in class org.infinispan.xsite.XSiteAdminOperations
 
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
 
getSequence() - Method in class org.infinispan.commands.triangle.BackupWriteCommand
 
getSharedLockCount() - Method in class org.infinispan.util.concurrent.locks.StripedLock
 
getSingleKey() - Method in class org.infinispan.commands.control.LockControlCommand
 
getSingleResponse(Map<Address, Response>) - Static method in class org.infinispan.interceptors.impl.ClusteringInterceptor
 
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.statetransfer.XSiteStateTransferControlCommand
 
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
 
getSitesMissingCoordinator(Collection<Address>) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateProvider
 
getSitesMissingCoordinator(Collection<Address>) - Method in class org.infinispan.xsite.statetransfer.XSiteStateProviderImpl
 
getSitesView() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getSitesView() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
getSitesView() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getSitesView() - Method in interface org.infinispan.remoting.transport.Transport
Get the view of interconnected sites.
getSize(long) - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
getSize(long, boolean) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
Returns how many bytes in memory this address location uses assuming it is an InternalCacheEntry.
getSize(long, boolean) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
 
getSource() - Method in class org.infinispan.statetransfer.InboundTransferTask
 
getSpliterator() - Method in interface org.infinispan.stream.impl.IteratorResponse
The spliterator containing the elements from the response.
getSpliterator() - Method in class org.infinispan.stream.impl.IteratorResponses
 
getStableCacheTopology(String) - Method in interface org.infinispan.topology.LocalTopologyManager
 
getStableCacheTopology(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
getStableCacheTopology(String) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
getStableTopology() - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
Whenever a new cache topology without a pendingCH and with at least numOwners owners for each segment is installed, and the cache is AvailabilityMode.AVAILABLE, the current cache topology is marked as the stable topology.
getStableTopology() - Method in class org.infinispan.topology.CacheStatusResponse
 
getStableTopology() - Method in class org.infinispan.topology.ClusterCacheStatus
 
getStaleStatsThreshold() - Method in class org.infinispan.stats.impl.AbstractClusterStats
 
getStartMethods() - Method in class org.infinispan.factories.components.ComponentMetadata
 
getState() - Method in class org.infinispan.persistence.async.AsyncCacheWriter
 
getStateCache() - Method in class org.infinispan.globalstate.impl.GlobalConfigurationManagerImpl
 
getStateChunks() - Method in class org.infinispan.statetransfer.StateResponseCommand
 
getStateFlags() - Method in interface org.infinispan.container.entries.StateChangingEntry
Deprecated.
getStateTransferFlag() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
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
 
getStateTransferProvider() - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
getStatisticsEnabled() - Method in class org.infinispan.eviction.impl.PassivationManagerImpl
 
getStatisticsEnabled() - Method in class org.infinispan.eviction.impl.PassivationManagerStub
 
getStatisticsEnabled() - Method in class org.infinispan.interceptors.impl.InvalidationInterceptor
 
getStatisticsEnabled() - Method in class org.infinispan.interceptors.impl.JmxStatsCommandInterceptor
Returns whether an interceptor's statistics are being captured.
getStatisticsEnabled() - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
getStatisticsEnabled() - Method in interface org.infinispan.jmx.JmxStatisticsExposer
Returns whether an interceptor's statistics are being captured.
getStatisticsEnabled() - Method in class org.infinispan.remoting.inboundhandler.AbstractDelegatingHandler
 
getStatisticsEnabled() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
 
getStatisticsEnabled() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getStatisticsEnabled() - Method in class org.infinispan.stats.impl.AbstractClusterStats
 
getStatisticsEnabled() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getStatisticsEnabled() - Method in class org.infinispan.stats.impl.StatsCollector
 
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.cache.impl.AbstractDelegatingAdvancedCache
 
getStats() - Method in class org.infinispan.cache.impl.CacheImpl
 
getStats() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getStats() - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
getStats() - Method in class org.infinispan.manager.DefaultCacheManager
 
getStats() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Returns statistics for this cache manager since 7.1
getStats() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getStats() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getStatus() - Method in interface org.infinispan.Cache
 
getStatus() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getStatus() - Method in class org.infinispan.cache.impl.CacheImpl
 
getStatus() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getStatus() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
Retrieves the state of the registry
getStatus() - Method in interface org.infinispan.functional.FunctionalMap
Functional map's status.
getStatus() - Method in class org.infinispan.functional.impl.FunctionalMapImpl
 
getStatus() - Method in interface org.infinispan.health.CacheHealth
Returns Cache health status.
getStatus() - Method in class org.infinispan.health.impl.CacheHealthImpl
 
getStatus() - Method in class org.infinispan.manager.DefaultCacheManager
 
getStatus() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getStatus() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getStatus() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getStatus() - Method in interface org.infinispan.topology.ClusterTopologyManager
 
getStatus() - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
getStatus() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Deprecated.
Get the status of the transaction associated with the calling thread.
getStatus() - Method in class org.infinispan.transaction.tm.DummyTransaction
Deprecated.
Get the status of the transaction.
getStatus() - Method in class org.infinispan.transaction.tm.DummyUserTransaction
Deprecated.
Get the status of the transaction.
getStatus() - Method in class org.infinispan.transaction.tm.EmbeddedUserTransaction
 
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.
getStatus() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
 
getStatus() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
getStopMethods() - Method in class org.infinispan.factories.components.ComponentMetadata
 
getStorageMediaType() - Method in class org.infinispan.encoding.DataConversion
 
getStoredValue() - Method in class org.infinispan.persistence.modifications.Store
 
getStores() - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
getStores() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
getStores() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getStores() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getStores() - Method in class org.infinispan.stats.impl.StatsCollector
 
getStores() - Method in class org.infinispan.stats.impl.StatsImpl
 
getStores() - Method in interface org.infinispan.stats.Stats
 
getStores(Class<T>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
 
getStores(Class<T>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
getStores(Class<T>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
getStoresAsString() - Method in interface org.infinispan.persistence.manager.PersistenceManager
 
getStoresAsString() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
getStoresAsString() - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
getStoreWrites() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getStoreWrites() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getStream(boolean) - Method in class org.infinispan.stream.impl.interceptor.AbstractDelegatingEntryCacheSet
 
getStream(boolean) - Method in class org.infinispan.stream.impl.interceptor.AbstractDelegatingKeyCacheSet
 
getStreamSupplier(boolean) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
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.WrappedByteArrayOrPrimitiveMapper
 
getSubgroupsMerged() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
getSubgroupsMerged() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.MergeEvent
 
getSubject() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
getSubject() - Static method in class org.infinispan.security.Security
If using Security.doAs(Subject, PrivilegedAction) or Security.doAs(Subject, PrivilegedExceptionAction), returns the Subject associated with the current thread otherwise it returns the Subject associated with the current AccessControlContext
getSubjectUserPrincipal(Subject) - Static method in class org.infinispan.security.Security
Returns the first principal of a subject which is not of type Group
getSuccessfulResponseOrFail(Map<Address, Response>, CompletableFuture<?>, Consumer<Response>) - Static method in class org.infinispan.interceptors.impl.ClusteringInterceptor
 
getSuccessRatio() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getSuccessRatioFloatingPoint() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getSuspect() - Method in exception org.infinispan.remoting.transport.jgroups.SuspectException
 
getSuspectedSegments() - Method in interface org.infinispan.stream.impl.IteratorResponse
The segments that were lost during the iteration process
getSyncRpcOptions() - Method in interface org.infinispan.remoting.rpc.RpcManager
 
getSyncRpcOptions() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getSyncXSiteCount() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getSyncXSiteRequestsReceived() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
 
GetSystemPropertyAction - Class in org.infinispan.security.actions
GetSystemPropertyAction.
GetSystemPropertyAction(String) - Constructor for class org.infinispan.security.actions.GetSystemPropertyAction
 
GetSystemPropertyAsBooleanAction - Class in org.infinispan.security.actions
Wrapper for Boolean.getBoolean(propertyName)
GetSystemPropertyAsBooleanAction(String) - Constructor for class org.infinispan.security.actions.GetSystemPropertyAsBooleanAction
 
GetSystemPropertyAsIntegerAction - Class in org.infinispan.security.actions
Wrapper for Integer.getInteger(propertyName, defaultValue).
GetSystemPropertyAsIntegerAction(String, int) - Constructor for class org.infinispan.security.actions.GetSystemPropertyAsIntegerAction
 
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
 
getTarget() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
getTarget() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
getTarget() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
getTarget() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.ListenerInvocationImpl
 
getTarget() - Method in interface org.infinispan.notifications.impl.ListenerInvocation
The listener instance that is notified of events
getTarget(int) - Method in class org.infinispan.remoting.transport.impl.MultiTargetRequest
 
getTargetsSize() - Method in class org.infinispan.remoting.transport.impl.MultiTargetRequest
 
getTask() - Method in class org.infinispan.distexec.RunnableAdapter
 
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
getTemplate() - Method in class org.infinispan.globalstate.impl.CacheState
 
getThrowable() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
getTimeout() - Method in class org.infinispan.remoting.inboundhandler.action.ActionState
 
getTimeout() - Method in class org.infinispan.topology.CacheJoinInfo
 
getTimeout() - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
 
getTimeout() - Method in class org.infinispan.xsite.XSiteBackup
 
getTimeService() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
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 interface org.infinispan.persistence.spi.InitializationContext
 
getTimeSinceReset() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
getTimeSinceReset() - Method in class org.infinispan.stats.impl.AbstractClusterStats
 
getTimeSinceReset() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getTimeSinceReset() - Method in class org.infinispan.stats.impl.StatsCollector
 
getTimeSinceReset() - Method in class org.infinispan.stats.impl.StatsImpl
 
getTimeSinceReset() - Method in interface org.infinispan.stats.Stats
 
getTimeSinceStart() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
getTimeSinceStart() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getTimeSinceStart() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getTimeSinceStart() - Method in class org.infinispan.stats.impl.StatsCollector
 
getTimeSinceStart() - Method in class org.infinispan.stats.impl.StatsImpl
 
getTimeSinceStart() - Method in interface org.infinispan.stats.Stats
 
getToKeyFunction() - Method in class org.infinispan.stream.impl.termop.AbstractForEachOperation
 
getToKeyFunction() - Method in class org.infinispan.stream.impl.termop.primitive.AbstractForEachDoubleOperation
 
getToKeyFunction() - Method in class org.infinispan.stream.impl.termop.primitive.AbstractForEachIntOperation
 
getToKeyFunction() - Method in class org.infinispan.stream.impl.termop.primitive.AbstractForEachLongOperation
 
getTopologyId() - Method in class org.infinispan.commands.AbstractTopologyAffectedCommand
 
getTopologyId() - Method in class org.infinispan.commands.functional.AbstractWriteManyCommand
 
getTopologyId() - Method in class org.infinispan.commands.read.AbstractDataCommand
 
getTopologyId() - Method in class org.infinispan.commands.remote.BaseClusteredReadCommand
 
getTopologyId() - Method in class org.infinispan.commands.remote.expiration.RetrieveLastAccessCommand
 
getTopologyId() - Method in class org.infinispan.commands.remote.expiration.UpdateLastAccessCommand
 
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.triangle.BackupWriteCommand
 
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.OutboundTransferTask
 
getTopologyId() - Method in class org.infinispan.statetransfer.StateRequestCommand
 
getTopologyId() - Method in class org.infinispan.statetransfer.StateResponseCommand
 
getTopologyId() - Method in class org.infinispan.statetransfer.TransactionInfo
 
getTopologyId() - Method in class org.infinispan.stream.impl.StreamIteratorNextCommand
 
getTopologyId() - Method in class org.infinispan.stream.impl.StreamRequestCommand
 
getTopologyId() - Method in class org.infinispan.topology.CacheTopology
 
getTopologyId() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
getTopologyId() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getTopologyId() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
getTotalLockCount() - Method in class org.infinispan.util.concurrent.locks.StripedLock
Returns the total number of locks held by this class.
getTotalMemoryKb() - Method in interface org.infinispan.health.HostInfo
Gets total memory in KB.
getTotalMemoryKb() - Method in class org.infinispan.health.impl.HostInfoImpl
 
getTotalMemoryKb() - Method in class org.infinispan.health.impl.jmx.HealthJMXExposerImpl
 
getTotalMemoryKb() - Method in interface org.infinispan.health.jmx.HealthJMXExposer
Returns the amount of total memory (KB) in the host.
getTotalNumberOfEntries() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
getTotalNumberOfEntries() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getTotalNumberOfEntries() - Method in class org.infinispan.stats.impl.StatsCollector
 
getTotalNumberOfEntries() - Method in class org.infinispan.stats.impl.StatsImpl
 
getTotalNumberOfEntries() - Method in interface org.infinispan.stats.Stats
Number of entries stored in cache since the cache started running.
getTotalReadLockCount() - Method in class org.infinispan.util.concurrent.locks.StripedLock
 
getTotalSpace() - Method in class org.infinispan.io.GridFile
 
getTotalSyncRpcOptions() - Method in interface org.infinispan.remoting.rpc.RpcManager
 
getTotalSyncRpcOptions() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getTotalWriteLockCount() - Method in class org.infinispan.util.concurrent.locks.StripedLock
 
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.impl.LocalTransaction
 
getTransaction() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Deprecated.
Get the transaction associated with the calling thread.
getTransaction() - Method in class org.infinispan.transaction.tm.EmbeddedBaseTransactionManager
 
getTransactionManager() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getTransactionManager() - Method in class org.infinispan.cache.impl.CacheImpl
 
getTransactionManager() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getTransactionManager() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getTransactionManager() - Method in class org.infinispan.transaction.lookup.DummyTransactionManagerLookup
Deprecated.
 
getTransactionManager() - Method in class org.infinispan.transaction.lookup.EmbeddedTransactionManagerLookup
 
getTransactionManager() - Method in class org.infinispan.transaction.lookup.GenericTransactionManagerLookup
Get the system-wide used TransactionManager
getTransactionManager() - Method in class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
 
getTransactionManager() - Method in class org.infinispan.transaction.lookup.WildflyTransactionManagerLookup
 
getTransactionsForSegments(Address, int, IntSet) - Method in interface org.infinispan.statetransfer.StateProvider
Gets the list of transactions that affect keys from the given segments.
getTransactionsForSegments(Address, int, IntSet) - Method in class org.infinispan.statetransfer.StateProviderImpl
 
getTransactionState() - Method in class org.infinispan.transaction.impl.RemoteTransaction
 
getTransactionSynchronizationRegistry() - Method in interface org.infinispan.transaction.lookup.TransactionSynchronizationRegistryLookup
Returns a new TransactionSynchronizationRegistry.
getTransactionSynchronizedBlock() - Method in class org.infinispan.transaction.impl.TotalOrderRemoteTransactionState
 
getTransactionTable() - Method in class org.infinispan.factories.ComponentRegistry
 
getTransactionTimeout() - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
getTranscoder(MediaType, MediaType) - Method in interface org.infinispan.marshall.core.EncoderRegistry
Obtain an instance of Transcoder from the registry.
getTranscoder(MediaType, MediaType) - Method in class org.infinispan.marshall.core.EncoderRegistryImpl
 
getTransport() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
getTransport() - Method in class org.infinispan.manager.DefaultCacheManager
 
getTransport() - Method in interface org.infinispan.manager.EmbeddedCacheManager
getTransport() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getTransport() - Method in interface org.infinispan.remoting.rpc.RpcManager
 
getTransport() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getTriangleOrderManager() - Method in class org.infinispan.remoting.inboundhandler.TrianglePerCacheInboundInvocationHandler
 
getType() - Method in class org.infinispan.factories.components.JmxAttributeMetadata
 
getType() - Method in class org.infinispan.factories.components.JmxOperationParameter
 
getType() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
getType() - Method in interface org.infinispan.notifications.cachelistener.event.Event
 
getType() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getType() - Method in class org.infinispan.notifications.cachelistener.filter.EventType
 
getType() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.Event
 
getType() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.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.DeltaCompositeKey.DeltaCompositeKeyExternalizer
Deprecated.
 
getTypeClasses() - Method in class org.infinispan.atomic.impl.ApplyDelta.Externalizer
Deprecated.
 
getTypeClasses() - Method in class org.infinispan.atomic.impl.AtomicKeySetImpl.Externalizer
 
getTypeClasses() - Method in class org.infinispan.atomic.impl.AtomicKeySetImpl.FunctionExternalizer
 
getTypeClasses() - Method in class org.infinispan.atomic.impl.AtomicMapProxyImpl.Externalizer
 
getTypeClasses() - Method in class org.infinispan.cache.impl.EncoderEntryMapper.Externalizer
 
getTypeClasses() - Method in class org.infinispan.cache.impl.EncoderKeyMapper.Externalizer
 
getTypeClasses() - Method in class org.infinispan.cache.impl.EncoderValueMapper.Externalizer
 
getTypeClasses() - Method in class org.infinispan.commands.functional.functions.MergeFunction.Externalizer
 
getTypeClasses() - Method in class org.infinispan.compat.BiFunctionMapper.Externalizer
 
getTypeClasses() - Method in class org.infinispan.compat.FunctionMapper.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.ImmortalCacheEntry.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.ImmortalCacheValue.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.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.RemoteMetadata.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.impl.DefaultConsistentHash.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.impl.TopologyAwareConsistentHashFactory.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory.Externalizer
 
getTypeClasses() - Method in class org.infinispan.encoding.DataConversion.Externalizer
 
getTypeClasses() - Method in class org.infinispan.filter.AcceptAllKeyValueFilter.Externalizer
 
getTypeClasses() - Method in class org.infinispan.filter.CacheFilters.CacheFiltersExternalizer
 
getTypeClasses() - Method in class org.infinispan.filter.CollectionKeyFilter.Externalizer
 
getTypeClasses() - Method in class org.infinispan.filter.CompositeKeyFilter.Externalizer
 
getTypeClasses() - Method in class org.infinispan.filter.CompositeKeyValueFilter.Externalizer
 
getTypeClasses() - Method in class org.infinispan.filter.KeyFilterAsKeyValueFilter.Externalizer
 
getTypeClasses() - Method in class org.infinispan.filter.KeyValueFilterAsKeyFilter.Externalizer
 
getTypeClasses() - Method in class org.infinispan.functional.impl.EntryViews.NoValueReadOnlyViewExternalizer
 
getTypeClasses() - Method in class org.infinispan.functional.impl.EntryViews.ReadOnlySnapshotViewExternalizer
 
getTypeClasses() - Method in class org.infinispan.functional.impl.EntryViews.ReadWriteSnapshotViewExternalizer
 
getTypeClasses() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata.Externalizer
 
getTypeClasses() - Method in class org.infinispan.functional.impl.StatsEnvelope.Externalizer
 
getTypeClasses() - Method in class org.infinispan.globalstate.impl.CacheState.Externalizer
 
getTypeClasses() - Method in class org.infinispan.globalstate.ScopedState.Externalizer
 
getTypeClasses() - Method in class org.infinispan.globalstate.ScopeFilter.Externalizer
 
getTypeClasses() - Method in class org.infinispan.interceptors.distribution.VersionedResult.Externalizer
 
getTypeClasses() - Method in class org.infinispan.interceptors.distribution.VersionedResults.Externalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.ConstantLambdaExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.LambdaWithMetasExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.SetValueIfEqualsReturnBooleanExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl.Externalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.CollectionExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.DoubleSummaryStatisticsExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.EnumSetExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.IntSummaryStatisticsExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.LongSummaryStatisticsExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.MapExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.EntryVersionParamExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.LifespanExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.MaxIdleExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.OptionalExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.TriangleAckExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.UuidExternalizer
 
getTypeClasses() - Method in class org.infinispan.metadata.EmbeddedMetadata.Externalizer
 
getTypeClasses() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl.Externalizer
 
getTypeClasses() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent.Externalizer
 
getTypeClasses() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEventCallable.Externalizer
 
getTypeClasses() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerRemoveCallable.Externalizer
 
getTypeClasses() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerReplicateCallable.Externalizer
 
getTypeClasses() - Method in class org.infinispan.notifications.cachelistener.cluster.MultiClusterEventCallable.Externalizer
 
getTypeClasses() - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventConverterAsConverter.Externalizer
 
getTypeClasses() - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterAsKeyValueFilter.Externalizer
 
getTypeClasses() - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverterAsKeyValueFilterConverter.Externalizer
 
getTypeClasses() - Method in class org.infinispan.notifications.cachelistener.filter.KeyFilterAsCacheEventFilter.Externalizer
 
getTypeClasses() - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterAsCacheEventFilter.Externalizer
 
getTypeClasses() - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter.Externalizer
 
getTypeClasses() - Method in class org.infinispan.partitionhandling.AvailabilityMode.Externalizer
 
getTypeClasses() - Method in class org.infinispan.remoting.MIMECacheEntry.Externalizer
 
getTypeClasses() - Method in class org.infinispan.remoting.responses.BiasRevocationResponse.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.stream.impl.AbstractCacheStream.MapOpsExternalizer
 
getTypeClasses() - Method in class org.infinispan.stream.impl.EndIterator.EndIteratorExternalizer
 
getTypeClasses() - Method in class org.infinispan.stream.impl.intops.IntermediateOperationExternalizer
 
getTypeClasses() - Method in class org.infinispan.stream.impl.IteratorResponses.IteratorResponsesExternalizer
 
getTypeClasses() - Method in class org.infinispan.stream.impl.termop.TerminalOperationExternalizer
 
getTypeClasses() - Method in class org.infinispan.stream.StreamMarshalling.StreamMarshallingExternalizer
 
getTypeClasses() - Method in class org.infinispan.topology.CacheJoinInfo.Externalizer
 
getTypeClasses() - Method in class org.infinispan.topology.CacheStatusResponse.Externalizer
 
getTypeClasses() - Method in class org.infinispan.topology.CacheTopology.Externalizer
 
getTypeClasses() - Method in class org.infinispan.topology.ManagerStatusResponse.Externalizer
 
getTypeClasses() - Method in class org.infinispan.topology.PersistentUUID.Externalizer
 
getTypeClasses() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction.Externalizer
Deprecated.
 
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
Deprecated.
 
getTypeClasses() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction.Externalizer
 
getTypeClasses() - Method in class org.infinispan.transaction.xa.recovery.SerializableXid.XidExternalizer
Deprecated.
 
getTypeClasses() - Method in class org.infinispan.util.IntSetExternalizer
 
getTypeClasses() - Method in class org.infinispan.util.KeyValuePair.Externalizer
 
getTypeClasses() - Method in class org.infinispan.xsite.statetransfer.XSiteState.XSiteStateExternalizer
 
getUnfinishedSegments() - Method in class org.infinispan.statetransfer.InboundTransferTask
Returns a copy of the unfinished segments
getUnionCH() - Method in class org.infinispan.topology.CacheTopology
The union of the current and future consistent hashes.
getUnionConsistentHash() - Method in interface org.infinispan.notifications.cachelistener.event.DataRehashedEvent
Deprecated.
Since 9.0
getUnionConsistentHash() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getUpdatedEntryVersions() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getUpdatedEntryVersions() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
getUpdatedVersions() - Method in class org.infinispan.commands.tx.VersionedCommitCommand
 
getUsableSpace() - Method in class org.infinispan.io.GridFile
 
getUserTransaction() - Static method in class org.infinispan.transaction.lookup.DummyTransactionManagerLookup
Deprecated.
 
getUserTransaction() - Static method in class org.infinispan.transaction.lookup.EmbeddedTransactionManagerLookup
 
getUserTransaction() - Method in class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
 
getUserTransaction() - Method in class org.infinispan.transaction.lookup.WildflyTransactionManagerLookup
 
getUserTransaction() - Static method in class org.infinispan.transaction.tm.DummyTransactionManager
Deprecated.
 
getUserTransaction() - Static method in class org.infinispan.transaction.tm.EmbeddedTransactionManager
 
getUUID() - Method in interface org.infinispan.commands.CancellableCommand
Returns UUID of a command
getUUID() - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
getValue() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.ValueAndMetadata
 
getValue() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
getValue() - Method in class org.infinispan.commands.write.RemoveCommand
 
getValue() - Method in interface org.infinispan.container.entries.CacheEntry
Retrieves the value of this entry
getValue() - Method in class org.infinispan.container.entries.ClearCacheEntry
 
getValue() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
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.NullCacheEntry
 
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 class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
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.CacheEntryEvent
Retrieves the value of the affected cache entry
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryExpiredEvent
Retrieves the value of the entry being expired.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryInvalidatedEvent
Retrieves the value of the entry being invalidated.
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.impl.EventImpl
 
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
 
getValueDataConversion() - Method in interface org.infinispan.AdvancedCache
 
getValueDataConversion() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getValueDataConversion() - Method in class org.infinispan.cache.impl.CacheImpl
 
getValueDataConversion() - Method in class org.infinispan.cache.impl.EncoderCache
 
getValueDataConversion() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getValueDataConversion() - Method in class org.infinispan.commands.functional.AbstractWriteKeyCommand
 
getValueDataConversion() - Method in class org.infinispan.commands.functional.AbstractWriteManyCommand
 
getValueDataConversion() - Method in interface org.infinispan.commands.functional.FunctionalCommand
 
getValueDataConversion() - Method in class org.infinispan.commands.functional.ReadOnlyKeyCommand
 
getValueDataConversion() - Method in class org.infinispan.commands.functional.ReadOnlyManyCommand
 
getValueDataConversion() - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
 
getValueDataConversion() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
getValueDataConversion() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
getValueDataConversion() - Method in class org.infinispan.notifications.cachelistener.ListenerHolder
 
getValueDataConversion() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getValueEncoder() - Method in interface org.infinispan.AdvancedCache
getValueEncoder() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getValueEncoder() - Method in class org.infinispan.cache.impl.CacheImpl
 
getValueEncoder() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getValueEncoder() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getValueFromCtx(K, InvocationContext) - Method in interface org.infinispan.container.impl.InternalEntryFactory
Retrieve an InternalCacheValue from the provided InvocationContext if an InternalCacheEntry exists, otherwise create InternalCacheEntry from the context's CacheEntry and return its value.
getValueFromCtx(K, InvocationContext) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
 
getValueMatcher() - Method in class org.infinispan.commands.functional.AbstractWriteKeyCommand
 
getValueMatcher() - Method in class org.infinispan.commands.functional.AbstractWriteManyCommand
 
getValueMatcher() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
Deprecated.
 
getValueMatcher() - Method in class org.infinispan.commands.write.ClearCommand
 
getValueMatcher() - Method in class org.infinispan.commands.write.ComputeCommand
 
getValueMatcher() - Method in class org.infinispan.commands.write.ComputeIfAbsentCommand
 
getValueMatcher() - Method in class org.infinispan.commands.write.InvalidateCommand
 
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
 
getValueWrapper() - Method in interface org.infinispan.AdvancedCache
getValueWrapper() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getValueWrapper() - Method in class org.infinispan.cache.impl.CacheImpl
 
getValueWrapper() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getValueWrapper() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getVersion() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getVersion() - Method in class org.infinispan.cache.impl.CacheImpl
Returns the version of Infinispan.
getVersion() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getVersion() - Method in interface org.infinispan.container.entries.versioned.Versioned
 
getVersion() - Method in class org.infinispan.container.entries.VersionedRepeatableReadEntry
 
getVersion() - Method in class org.infinispan.container.versioning.NumericVersion
 
getVersion() - Method in class org.infinispan.container.versioning.SimpleClusteredVersion
 
getVersion() - Method in class org.infinispan.manager.DefaultCacheManager
 
getVersion() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getVersion() - Static method in class org.infinispan.Version
 
getVersionGenerator() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getLocalComponent(VersionGenerator.class)
getVersionShort() - Static method in class org.infinispan.Version
 
getVersionShort(String) - Static method in class org.infinispan.Version
 
getVersionsRead() - Method in class org.infinispan.transaction.impl.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.impl.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.ClusterView
 
getViewId() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getViewId() - Method in interface org.infinispan.remoting.transport.Transport
 
getWaitList() - Method in class org.infinispan.remoting.responses.BiasRevocationResponse
 
getWarningMessage(String, Location) - Static method in class org.infinispan.configuration.parsing.ParseUtils
 
getWhen() - Method in interface org.infinispan.util.logging.events.EventLog
 
getWho() - Method in interface org.infinispan.util.logging.events.EventLog
 
getWrapper() - Method in class org.infinispan.encoding.DataConversion
 
getWrapper(Class<? extends Wrapper>, Byte) - Method in interface org.infinispan.marshall.core.EncoderRegistry
 
getWrapper(Class<? extends Wrapper>, Byte) - Method in class org.infinispan.marshall.core.EncoderRegistryImpl
 
getWrapperClass() - Method in class org.infinispan.encoding.DataConversion
 
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.impl.DistributionManagerImpl
 
getWriteConsistentHash() - Method in class org.infinispan.topology.CacheTopology
When there is a rebalance in progress, write operations should go to the union of the "current" and "future" owners.
getWriteConsistentHashAtEnd() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getWriteConsistentHashAtEnd() - Method in interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
 
getWriteConsistentHashAtStart() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getWriteConsistentHashAtStart() - Method in interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
 
getWriteOwners(Object) - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
getWriteOwners(Collection<?>) - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
getWritesToTheStores() - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
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.cache.impl.AbstractDelegatingAdvancedCache
 
getXAResource() - Method in class org.infinispan.cache.impl.CacheImpl
 
getXAResource() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getXAResource() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getXid() - Method in class org.infinispan.transaction.tm.DummyTransaction
Deprecated.
 
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
Deprecated.
 
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 - org.infinispan.configuration.parsing.Element
 
GLOBAL - org.infinispan.configuration.parsing.ParserScope
The top-level scope at which cache containers, jgroups and threads are defined
GLOBAL - org.infinispan.factories.scopes.Scopes
Components bounded to this scope can only be created by a DefaultCacheManager and exist in the DefaultCacheManager's ComponentRegistry.
GLOBAL - org.infinispan.registry.InternalCacheRegistry.Flag
means that this cache will be global to all nodes when running in clustered mode
GLOBAL_SCOPE - Static variable in interface org.infinispan.globalstate.ScopedPersistentState
 
GLOBAL_STATE - org.infinispan.configuration.parsing.Element
 
globalACLCache() - Method in interface org.infinispan.security.GlobalSecurityManager
Returns the global ACL cache
globalACLCache() - Method in class org.infinispan.security.impl.GlobalSecurityManagerImpl
 
GlobalAuthorizationConfiguration - Class in org.infinispan.configuration.global
GlobalAuthorizationConfiguration.
GlobalAuthorizationConfiguration(AttributeSet) - Constructor for class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
GlobalAuthorizationConfigurationBuilder - Class in org.infinispan.configuration.global
GlobalAuthorizationConfigurationBuilder.
GlobalAuthorizationConfigurationBuilder(GlobalSecurityConfigurationBuilder) - Constructor for class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
 
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 - Variable in class org.infinispan.factories.AbstractComponentFactory
 
globalConfiguration - Variable in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
 
GlobalConfiguration - Class in org.infinispan.configuration.global
Configuration component that exposes the global configuration.
GlobalConfigurationBuilder - Class in org.infinispan.configuration.global
 
GlobalConfigurationBuilder() - Constructor for class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
GlobalConfigurationChildBuilder - Interface in org.infinispan.configuration.global
 
GlobalConfigurationManager - Interface in org.infinispan.globalstate
The GlobalConfigurationManager is the main interface for sharing runtime configuration state across a cluster.
GlobalConfigurationManagerImpl - Class in org.infinispan.globalstate.impl
Implementation of GlobalConfigurationManager
GlobalConfigurationManagerImpl() - Constructor for class org.infinispan.globalstate.impl.GlobalConfigurationManagerImpl
 
GlobalConfigurationManagerPostStart - Class in org.infinispan.globalstate.impl
 
GlobalConfigurationManagerPostStart() - Constructor for class org.infinispan.globalstate.impl.GlobalConfigurationManagerPostStart
 
GlobalConfigurationStateListener - Class in org.infinispan.globalstate.impl
Listens to events on the global state cache and manages cache configuration creation / removal accordingly
globalId() - Method in class org.infinispan.transaction.xa.GlobalTransaction
Returns a simplified representation of the transaction.
GlobalInboundInvocationHandler - Class in org.infinispan.remoting.inboundhandler
InboundInvocationHandler implementation that handles all the ReplicableCommand.
GlobalInboundInvocationHandler() - Constructor for class org.infinispan.remoting.inboundhandler.GlobalInboundInvocationHandler
 
globalJmxRegistration - Variable in class org.infinispan.jmx.CacheJmxRegistration
 
globalJmxStatistics() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
globalJmxStatistics() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
globalJmxStatistics() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
Global JMX configuration
GlobalJmxStatisticsConfiguration - Class in org.infinispan.configuration.global
 
GlobalJmxStatisticsConfigurationBuilder - Class in org.infinispan.configuration.global
Configures whether global statistics are gathered and reported via JMX for all caches under this cache manager.
GlobalMarshaller - Class in org.infinispan.marshall.core
A globally-scoped marshaller.
GlobalMarshaller() - Constructor for class org.infinispan.marshall.core.GlobalMarshaller
 
GlobalMarshaller(Marshaller) - Constructor for class org.infinispan.marshall.core.GlobalMarshaller
 
GlobalRoleConfigurationBuilder - Class in org.infinispan.configuration.global
GlobalRoleConfigurationBuilder.
GlobalRoleConfigurationBuilder(String, GlobalAuthorizationConfigurationBuilder) - Constructor for class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
 
GlobalRolesConfigurationChildBuilder - Interface in org.infinispan.configuration.global
 
globalSecurityAuthShouldBeEnabled() - Method in class org.infinispan.util.logging.Log_$logger
 
globalSecurityAuthShouldBeEnabled() - Method in interface org.infinispan.util.logging.Log
 
globalSecurityAuthShouldBeEnabled$str() - Method in class org.infinispan.util.logging.Log_$logger
 
GlobalSecurityConfiguration - Class in org.infinispan.configuration.global
GlobalSecurityConfiguration.
GlobalSecurityConfigurationBuilder - Class in org.infinispan.configuration.global
GlobalSecurityConfigurationBuilder.
GlobalSecurityConfigurationBuilder(GlobalConfigurationBuilder) - Constructor for class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
 
GlobalSecurityConfigurationChildBuilder - Interface in org.infinispan.configuration.global
GlobalSecurityConfigurationChildBuilder.
GlobalSecurityManager - Interface in org.infinispan.security
GlobalSecurityManager.
GlobalSecurityManagerFactory - Class in org.infinispan.security.impl
Factory for GlobalSecurityManager implementations
GlobalSecurityManagerFactory() - Constructor for class org.infinispan.security.impl.GlobalSecurityManagerFactory
 
GlobalSecurityManagerImpl - Class in org.infinispan.security.impl
GlobalSecurityManagerImpl.
GlobalSecurityManagerImpl() - Constructor for class org.infinispan.security.impl.GlobalSecurityManagerImpl
 
globalState() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
globalState() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
globalState() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
Global state configuration
globalStateCannotAcquireLockFile(Throwable, File) - Method in class org.infinispan.util.logging.Log_$logger
 
globalStateCannotAcquireLockFile(Throwable, File) - Method in interface org.infinispan.util.logging.Log
 
globalStateCannotAcquireLockFile$str() - Method in class org.infinispan.util.logging.Log_$logger
 
GlobalStateConfiguration - Class in org.infinispan.configuration.global
GlobalStateConfiguration.
GlobalStateConfiguration(AttributeSet) - Constructor for class org.infinispan.configuration.global.GlobalStateConfiguration
 
GlobalStateConfigurationBuilder - Class in org.infinispan.configuration.global
GlobalStateConfigurationBuilder.
globalStateDisabled() - Method in class org.infinispan.util.logging.Log_$logger
 
globalStateDisabled() - Method in interface org.infinispan.util.logging.Log
 
globalStateDisabled$str() - Method in class org.infinispan.util.logging.Log_$logger
 
globalStateLoad(String, String) - Method in class org.infinispan.util.logging.Log_$logger
 
globalStateLoad(String, String) - Method in interface org.infinispan.util.logging.Log
 
globalStateLoad$str() - Method in class org.infinispan.util.logging.Log_$logger
 
GlobalStateManager - Interface in org.infinispan.globalstate
GlobalStateManager.
GlobalStateManagerImpl - Class in org.infinispan.globalstate.impl
GlobalStateManagerImpl.
GlobalStateManagerImpl() - Constructor for class org.infinispan.globalstate.impl.GlobalStateManagerImpl
 
GlobalStateProvider - Interface in org.infinispan.globalstate
GlobalStateProvider.
globalStateWrite(String, String) - Method in class org.infinispan.util.logging.Log_$logger
 
globalStateWrite(String, String) - Method in interface org.infinispan.util.logging.Log
 
globalStateWrite$str() - Method in class org.infinispan.util.logging.Log_$logger
 
globalStatus() - Method in class org.infinispan.xsite.GlobalXSiteAdminOperations
 
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
 
GlobalXSiteAdminOperations - Class in org.infinispan.xsite
A per-container (cache manager) cross-site admin operations.
GlobalXSiteAdminOperations() - Constructor for class org.infinispan.xsite.GlobalXSiteAdminOperations
 
grant(String, String) - Method in class org.infinispan.security.impl.ClusterRoleMapper
 
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>) - Constructor for class org.infinispan.io.GridFilesystem
 
GridFilesystem(Cache<String, byte[]>, Cache<String, GridFile.Metadata>, int) - Constructor for class org.infinispan.io.GridFilesystem
Creates an instance.
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.
GROUP_NAME - org.infinispan.configuration.parsing.Attribute
 
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.
GROUPER - org.infinispan.configuration.parsing.Element
 
groupers() - Method in class org.infinispan.configuration.cache.GroupsConfiguration
Get's the current groupers in use
GROUPERS - Static variable in class org.infinispan.configuration.cache.GroupsConfiguration
 
GroupFilter<K> - Class in org.infinispan.distribution.group.impl
A key filter that accepts keys which belongs to the group.
GroupFilter(Object, GroupManager) - Constructor for class org.infinispan.distribution.group.impl.GroupFilter
 
GroupingInterceptor - Class in org.infinispan.interceptors.impl
An interceptor that keeps track of the keys added/removed during the processing of a GetKeysInGroupCommand
GroupingInterceptor() - Constructor for class org.infinispan.interceptors.impl.GroupingInterceptor
 
GroupingInterceptor.KeyListener - Class in org.infinispan.interceptors.impl
 
groupingOnlyCompatibleWithObjectStorage(StorageType) - Method in class org.infinispan.util.logging.Log_$logger
 
groupingOnlyCompatibleWithObjectStorage(StorageType) - Method in interface org.infinispan.util.logging.Log
 
groupingOnlyCompatibleWithObjectStorage$str() - Method in class org.infinispan.util.logging.Log_$logger
 
GroupingPartitioner - Class in org.infinispan.distribution.group.impl
Key partitioner that uses Group annotations to map grouped keys to the same segment.
GroupingPartitioner(KeyPartitioner, GroupManager) - Constructor for class org.infinispan.distribution.group.impl.GroupingPartitioner
 
groupManager - Variable in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
GroupManager - Interface in org.infinispan.distribution.group.impl
Control's key grouping.
GroupManagerFactory - Class in org.infinispan.distribution.group.impl
 
GroupManagerFactory() - Constructor for class org.infinispan.distribution.group.impl.GroupManagerFactory
 
GroupManagerImpl - Class in org.infinispan.distribution.group.impl
 
GroupManagerImpl(List<Grouper<?>>) - Constructor for class org.infinispan.distribution.group.impl.GroupManagerImpl
 
groups() - Method in class org.infinispan.configuration.cache.HashConfiguration
Configuration for various grouper definitions.
groups() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
 
GROUPS - org.infinispan.configuration.parsing.Element
 
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
 
GUARANTEED_DELIVERY - org.infinispan.context.Flag
Using a synchronous cache (whether replicated or distributed) provides the cache caller guarantees that data has been sent to other cluster nodes correctly and has been applied successfully.
GUARANTEED_DELIVERY - Static variable in class org.infinispan.context.impl.FlagBitSets
 

H

handle(CacheRpcCommand, Reply, DeliverOrder) - Method in class org.infinispan.remoting.inboundhandler.AbstractDelegatingHandler
 
handle(CacheRpcCommand, Reply, DeliverOrder) - Method in class org.infinispan.remoting.inboundhandler.NonTotalOrderPerCacheInboundInvocationHandler
 
handle(CacheRpcCommand, Reply, DeliverOrder) - Method in class org.infinispan.remoting.inboundhandler.NonTotalOrderTxPerCacheInboundInvocationHandler
 
handle(CacheRpcCommand, Reply, DeliverOrder) - Method in interface org.infinispan.remoting.inboundhandler.PerCacheInboundInvocationHandler
Handles the CacheRpcCommand from other node.
handle(CacheRpcCommand, Reply, DeliverOrder) - Method in class org.infinispan.remoting.inboundhandler.TotalOrderTxPerCacheInboundInvocationHandler
 
handle(CacheRpcCommand, Reply, DeliverOrder) - Method in class org.infinispan.remoting.inboundhandler.TrianglePerCacheInboundInvocationHandler
 
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.
handleArray(double[], int) - Method in class org.infinispan.stream.impl.termop.primitive.AbstractForEachDoubleOperation
 
handleArray(double[], int) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachDoubleOperation
 
handleArray(double[], int) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachObjDoubleOperation
 
handleArray(int[], int) - Method in class org.infinispan.stream.impl.termop.primitive.AbstractForEachIntOperation
 
handleArray(int[], int) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachIntOperation
 
handleArray(int[], int) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachObjIntOperation
 
handleArray(long[], int) - Method in class org.infinispan.stream.impl.termop.primitive.AbstractForEachLongOperation
 
handleArray(long[], int) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachLongOperation
 
handleArray(long[], int) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachObjLongOperation
 
handleCacheShutdown(String) - Method in interface org.infinispan.topology.LocalTopologyManager
Handles the local operations related to gracefully shutting down a cache
handleCacheShutdown(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
handleCacheShutdown(String) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
handleCacheStopped(CacheStoppedEvent) - Method in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
 
handleCacheStopped(CacheStoppedEvent) - Method in class org.infinispan.affinity.ListenerRegistration
 
handleClear(InvocationContext, VisitableCommand, Object) - Method in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor
 
handleClear(InvocationContext, VisitableCommand, Object) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
handleClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
Deprecated.
 
handleClearFailure(String) - Method in class org.infinispan.xsite.AbstractCustomFailurePolicy
 
handleClearFailure(String) - Method in interface org.infinispan.xsite.CustomFailurePolicy
 
handleClusterEvents(CacheEntryEvent) - Method in class org.infinispan.notifications.cachelistener.cluster.RemoteClusterListener
 
handleCommitCommand(InvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
Deprecated.
 
handleCommitFailure(String, Transaction) - Method in class org.infinispan.xsite.AbstractCustomFailurePolicy
 
handleCommitFailure(String, Transaction) - Method in interface org.infinispan.xsite.CustomFailurePolicy
 
handleCompose(Supplier<CompletionStage<T>>) - Method in interface org.infinispan.scattered.BiasManager.Revocation
Similar to CompletableFuture.thenCompose(Function), returns future provided by the supplier after the current revocation has been finished
handleComputeFailure(String, K, BiFunction<? super K, ? super V, ? extends V>, boolean) - Method in interface org.infinispan.xsite.CustomFailurePolicy
 
handleComputeIfAbsentFailure(String, K, Function<? super K, ? extends V>) - Method in interface org.infinispan.xsite.CustomFailurePolicy
 
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
Deprecated.
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.DDAsyncInterceptor
 
handleDefault(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.impl.BatchingInterceptor
Simply check if there is an ongoing tx.
handleDefault(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderStateTransferInterceptor
 
handleDefault(InvocationContext, VisitableCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
handleEvent(EventWrapper<K, V, E>, ListenerInvocation<Event<K, V>>) - Method in interface org.infinispan.notifications.cachelistener.QueueingSegmentListener
This should be called by any listener when an event is generated to possibly queue it.
handleEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
Deprecated.
 
handleFromCluster(Address, ReplicableCommand, Reply, DeliverOrder) - Method in class org.infinispan.remoting.inboundhandler.GlobalInboundInvocationHandler
 
handleFromCluster(Address, ReplicableCommand, Reply, DeliverOrder) - Method in interface org.infinispan.remoting.inboundhandler.InboundInvocationHandler
Handles the ReplicableCommand from other node belonging to local site.
handleFromRemoteSite(String, XSiteReplicateCommand, Reply, DeliverOrder) - Method in class org.infinispan.remoting.inboundhandler.GlobalInboundInvocationHandler
 
handleFromRemoteSite(String, XSiteReplicateCommand, Reply, DeliverOrder) - Method in interface org.infinispan.remoting.inboundhandler.InboundInvocationHandler
Handles the ReplicableCommand from remote site.
handleFunctionalReadManyCommand(InvocationContext, C, BaseDistributionInterceptor.ReadManyCommandHelper<C>) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
handleGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
Deprecated.
 
handleInjection(ComponentRegistry) - Method in interface org.infinispan.stream.impl.intops.IntermediateOperation
Handles injection of components for various dependencies that the intermediate operation has
handleInjection(ComponentRegistry) - Method in class org.infinispan.stream.impl.intops.object.MapOperation
 
handleInjection(ComponentRegistry) - Method in class org.infinispan.stream.impl.intops.object.PeekOperation
 
handleInjection(ComponentRegistry) - Method in interface org.infinispan.stream.impl.KeyTrackingTerminalOperation
Handles injection of components for various intermediate and this operation.
handleInjection(ComponentRegistry) - Method in interface org.infinispan.stream.impl.TerminalOperation
Handles injection of components for various intermediate and this operation.
handleInjection(ComponentRegistry) - Method in class org.infinispan.stream.impl.termop.BaseTerminalOperation
 
handleInjection(ComponentRegistry) - Method in class org.infinispan.stream.impl.termop.object.ForEachBiOperation
 
handleInjection(ComponentRegistry) - Method in class org.infinispan.stream.impl.termop.object.ForEachOperation
 
handleInjection(ComponentRegistry) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachDoubleOperation
 
handleInjection(ComponentRegistry) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapDoubleOperation
 
handleInjection(ComponentRegistry) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapIntOperation
 
handleInjection(ComponentRegistry) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapLongOperation
 
handleInjection(ComponentRegistry) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapObjDoubleOperation
 
handleInjection(ComponentRegistry) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapObjIntOperation
 
handleInjection(ComponentRegistry) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapObjLongOperation
 
handleInjection(ComponentRegistry) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachIntOperation
 
handleInjection(ComponentRegistry) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachLongOperation
 
handleInjection(ComponentRegistry) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachObjDoubleOperation
 
handleInjection(ComponentRegistry) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachObjIntOperation
 
handleInjection(ComponentRegistry) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachObjLongOperation
 
handleInMemoryExpiration(InternalCacheEntry<K, V>, long) - Method in interface org.infinispan.expiration.ExpirationManager
Deprecated.
since 9.3 this method is not intended for external use
handleInMemoryExpiration(InternalCacheEntry<K, V>, long) - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
handleInStoreExpiration(K) - Method in interface org.infinispan.expiration.ExpirationManager
Deprecated.
since 9.3 this method is not intended for external use
handleInStoreExpiration(K) - Method in class org.infinispan.expiration.impl.ClusterExpirationManager
 
handleInStoreExpiration(K) - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
handleInStoreExpiration(K) - Method in interface org.infinispan.expiration.impl.InternalExpirationManager
This is to be invoked when a store entry expires.
handleInStoreExpiration(MarshalledEntry<K, V>) - Method in interface org.infinispan.expiration.ExpirationManager
Deprecated.
since 9.3 this method is not intended for external use
handleInStoreExpiration(MarshalledEntry<K, V>) - Method in class org.infinispan.expiration.impl.ClusterExpirationManager
 
handleInStoreExpiration(MarshalledEntry<K, V>) - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
handleInStoreExpiration(MarshalledEntry<K, V>) - Method in interface org.infinispan.expiration.impl.InternalExpirationManager
This is to be invoked when a store entry expires and the value and/or metadata is available to be used.
handleJoin(String, Address, CacheJoinInfo, int) - Method in interface org.infinispan.topology.ClusterTopologyManager
Signals that a new member is joining the cache.
handleJoin(String, Address, CacheJoinInfo, int) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
handleLeave(String, Address, int) - Method in interface org.infinispan.topology.ClusterTopologyManager
Signals that a member is leaving the cache.
handleLeave(String, Address, int) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
handleList(List<Double>) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapDoubleOperation
 
handleList(List<Double>) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapObjDoubleOperation
 
handleList(List<Integer>) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapIntOperation
 
handleList(List<Integer>) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapObjIntOperation
 
handleList(List<Long>) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapLongOperation
 
handleList(List<Long>) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapObjLongOperation
 
handleList(List<V>) - Method in class org.infinispan.stream.impl.termop.AbstractForEachOperation
 
handleList(List<V>) - Method in class org.infinispan.stream.impl.termop.object.ForEachBiOperation
 
handleList(List<V>) - Method in class org.infinispan.stream.impl.termop.object.ForEachOperation
 
handleMissingSuccessfulResponse(Response) - Static method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
handleNonTxWriteCommand(InvocationContext, AbstractDataWriteCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
handleObject(Object) - Method in class org.infinispan.container.entries.PrimitiveEntrySizeCalculator
 
handlePrepareCommand(InvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
Deprecated.
 
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
Deprecated.
 
handlePutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
Deprecated.
 
handlePutMapCommandReturn - Variable in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
handlePutMapCommandReturn(InvocationContext, VisitableCommand, Object) - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
handlePutMapCommandReturn(InvocationContext, VisitableCommand, Object) - Method in class org.infinispan.interceptors.impl.DistCacheWriterInterceptor
 
handler - Variable in class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
 
handler - Variable in class org.infinispan.stream.impl.StreamIteratorCloseCommand
 
handleReadCommand(InvocationContext, C) - Method in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor
 
handleReadCommand(InvocationContext, DataCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
handleReadManyCommand(InvocationContext, AbstractTopologyAffectedCommand, Collection<?>) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
handleReadManyCommand(InvocationContext, FlagAffectedCommand, Collection<?>) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
handleReadManyCommand(InvocationContext, FlagAffectedCommand, Collection<?>) - Method in class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
 
handleReadManyCommand(InvocationContext, FlagAffectedCommand, Collection<?>) - Method in class org.infinispan.interceptors.locking.NonTransactionalLockingInterceptor
 
handleReadManyCommand(InvocationContext, FlagAffectedCommand, Collection<?>) - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
 
handleReadManyCommand(InvocationContext, FlagAffectedCommand, Collection<?>) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
 
handleReadWriteKeyFailure(String, K) - Method in interface org.infinispan.xsite.CustomFailurePolicy
 
handleReadWriteKeyValueFailure(String, K) - Method in interface org.infinispan.xsite.CustomFailurePolicy
 
handleReadWriteManyEntriesFailure(String, Map<? extends K, ? extends V>) - Method in interface org.infinispan.xsite.CustomFailurePolicy
 
handleReadWriteManyFailure(String, Collection<? extends K>) - Method in interface org.infinispan.xsite.CustomFailurePolicy
 
handleRebalance(String, CacheTopology, int, Address) - Method in interface org.infinispan.topology.LocalTopologyManager
Performs the state transfer.
handleRebalance(String, CacheTopology, int, Address) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
handleRebalance(String, CacheTopology, int, Address) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
handleRebalancePhaseConfirm(String, Address, int, Throwable, int) - Method in interface org.infinispan.topology.ClusterTopologyManager
Marks the rebalance as complete on the sender.
handleRebalancePhaseConfirm(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.BaseBackupReceiver
 
handleRemotelyRetrievedKeys(InvocationContext, WriteCommand, List<?>) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
handleRemotelyRetrievedKeys(InvocationContext, WriteCommand, List<?>) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
handleRemove(CacheEntryActivatedEvent<?, ?>) - Method in class org.infinispan.interceptors.impl.GroupingInterceptor.KeyListener
 
handleRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
Deprecated.
 
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
Deprecated.
 
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
Deprecated.
 
handleRollbackFailure(String, Transaction) - Method in class org.infinispan.xsite.AbstractCustomFailurePolicy
 
handleRollbackFailure(String, Transaction) - Method in interface org.infinispan.xsite.CustomFailurePolicy
 
handleSegments(boolean, IntSet, IntSet) - Method in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
handleSegments(boolean, IntSet, IntSet) - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
handleShutdownRequest(String) - Method in interface org.infinispan.topology.ClusterTopologyManager
 
handleShutdownRequest(String) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
handleSingleWrite(InvocationContext, DataWriteCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
 
handleSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
Deprecated.
 
handleStableTopologyUpdate(String, CacheTopology, Address, int) - Method in interface org.infinispan.topology.LocalTopologyManager
Update the stable cache topology.
handleStableTopologyUpdate(String, CacheTopology, Address, int) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
handleStableTopologyUpdate(String, CacheTopology, Address, int) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
handleStateTransferControl(XSiteStateTransferControlCommand) - Method in interface org.infinispan.xsite.BackupReceiver
It handles the state transfer control from a remote site.
handleStateTransferControl(XSiteStateTransferControlCommand) - Method in class org.infinispan.xsite.ClusteredCacheBackupReceiver
 
handleStateTransferControl(XSiteStateTransferControlCommand) - Method in class org.infinispan.xsite.LocalCacheBackupReceiver
 
handleStateTransferState(XSiteStatePushCommand) - Method in interface org.infinispan.xsite.BackupReceiver
It handles the state transfer state from a remote site.
handleStateTransferState(XSiteStatePushCommand) - Method in class org.infinispan.xsite.ClusteredCacheBackupReceiver
 
handleStateTransferState(XSiteStatePushCommand) - Method in class org.infinispan.xsite.LocalCacheBackupReceiver
 
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
 
handleStream(BaseCacheStream) - Method in enum org.infinispan.stream.impl.IntermediateType
 
handleStreamForEach(DoubleStream, List<Double>) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapDoubleOperation
 
handleStreamForEach(DoubleStream, List<Double>) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapObjDoubleOperation
 
handleStreamForEach(IntStream, List<Integer>) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapIntOperation
 
handleStreamForEach(IntStream, List<Integer>) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapObjIntOperation
 
handleStreamForEach(LongStream, List<Long>) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapLongOperation
 
handleStreamForEach(LongStream, List<Long>) - Method in class org.infinispan.stream.impl.termop.primitive.ForEachFlatMapObjLongOperation
 
handleStreamForEach(Stream<V>, List<V>) - Method in class org.infinispan.stream.impl.termop.object.ForEachBiOperation
 
handleStreamForEach(Stream<V>, List<V>) - Method in class org.infinispan.stream.impl.termop.object.ForEachOperation
 
handleStreamForEach(S, List<V>) - Method in class org.infinispan.stream.impl.termop.AbstractForEachOperation
 
handleTopology(TopologyChangedEvent<K, V>) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
handleTopologyUpdate(String, CacheTopology, AvailabilityMode, int, Address) - Method in interface org.infinispan.topology.LocalTopologyManager
Updates the current and/or pending consistent hash, without transferring any state.
handleTopologyUpdate(String, CacheTopology, AvailabilityMode, int, Address) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
handleTopologyUpdate(String, CacheTopology, AvailabilityMode, int, Address) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
handleTxFunctionalCommand(InvocationContext, C) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
handleTxWriteManyCommand(InvocationContext, C, Collection<K>, BiFunction<C, List<K>, C>) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
handleTxWriteManyEntriesCommand(InvocationContext, C, Map<K, V>, BiFunction<C, Map<K, V>, C>) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
handleViewChange(TopologyChangedEvent<?, ?>) - Method in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
 
handleViewChange(TopologyChangedEvent<?, ?>) - Method in class org.infinispan.affinity.ListenerRegistration
 
handleViewChange(ViewChangedEvent) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl.ClusterViewListener
 
handleWriteCommand(InvocationContext, DataWriteCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
handleWriteManyCommand(InvocationContext, WriteCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
handleWriteManyCommand(InvocationContext, WriteCommand, Collection<K>, boolean) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
handleWriteManyCommand(InvocationContext, WriteCommand, Collection<K>, boolean) - Method in class org.infinispan.interceptors.locking.NonTransactionalLockingInterceptor
 
handleWriteManyCommand(InvocationContext, WriteCommand, Collection<K>, boolean) - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
 
handleWriteManyCommand(InvocationContext, WriteCommand, Collection<K>, boolean) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
 
handleWriteOnlyKeyFailure(String, K) - Method in interface org.infinispan.xsite.CustomFailurePolicy
 
handleWriteOnlyKeyValueFailure(String, K) - Method in interface org.infinispan.xsite.CustomFailurePolicy
 
handleWriteOnlyManyEntriesFailure(String, Map<? extends K, ? extends V>) - Method in interface org.infinispan.xsite.CustomFailurePolicy
 
handleWriteOnlyManyFailure(String, Collection<? extends K>) - Method in interface org.infinispan.xsite.CustomFailurePolicy
 
hasActiveTransfers() - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
hasAnyFlag(long) - Method in interface org.infinispan.commands.FlagAffectedCommand
Check whether any of the flags in the flagsBitSet parameter is present in the command.
hasAnyFlag(long) - Method in class org.infinispan.commands.remote.BaseClusteredReadCommand
 
hasAnyLockAcquired() - Method in class org.infinispan.transaction.totalorder.TotalOrderManager
 
hasAnyLockAtOrigin(DldGlobalTransaction) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
Deprecated.
 
hasDependent(T) - Method in class org.infinispan.util.DependencyGraph
Check if an element is depended on
hasEnabledBackups() - Method in class org.infinispan.configuration.cache.SitesConfiguration
 
hasFactory(String) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
 
hasFlag(Flag) - Method in interface org.infinispan.commands.FlagAffectedCommand
Deprecated.
Since 9.0, please use FlagAffectedCommand.hasAnyFlag(long) with a FlagBitSets constant instead.
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
Deprecated.
Since 8.2, use HashConfiguration.keyPartitioner() instead.
hash(Hash) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
Deprecated.
HASH - org.infinispan.configuration.parsing.Element
 
HASH - Static variable in class org.infinispan.configuration.cache.HashConfiguration
 
hashCode() - Method in class org.infinispan.atomic.DeltaCompositeKey
Deprecated.
 
hashCode() - Method in class org.infinispan.commands.CancelCommand
 
hashCode() - Method in class org.infinispan.commands.CommandInvocationId
 
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.remote.ClusteredGetAllCommand
 
hashCode() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
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.ClearCommand
 
hashCode() - Method in class org.infinispan.commands.write.ComputeCommand
 
hashCode() - Method in class org.infinispan.commands.write.ComputeIfAbsentCommand
 
hashCode() - Method in class org.infinispan.commands.write.InvalidateCommand
 
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.RemoveExpiredCommand
 
hashCode() - Method in class org.infinispan.commands.write.ReplaceCommand
 
hashCode() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.AuthorizationConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.BackupConfiguration
 
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.ContentTypeConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfiguration
Deprecated.
 
hashCode() - Method in class org.infinispan.configuration.cache.EncodingConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.EvictionConfiguration
Deprecated.
 
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.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.MemoryConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
 
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.SecurityConfiguration
 
hashCode() - Method in class org.infinispan.configuration.cache.SingletonStoreConfiguration
Deprecated.
 
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
Deprecated.
 
hashCode() - Method in class org.infinispan.configuration.cache.SyncConfiguration
Deprecated.
 
hashCode() - Method in class org.infinispan.configuration.cache.TakeOfflineConfiguration
 
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
Deprecated.
 
hashCode() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
hashCode() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
hashCode() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
hashCode() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
hashCode() - Method in class org.infinispan.configuration.global.SerializationConfiguration
 
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.ThreadPoolConfigurationBuilder
 
hashCode() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
hashCode() - Method in class org.infinispan.configuration.internal.PrivateGlobalConfiguration
 
hashCode() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
hashCode() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
hashCode() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
hashCode() - Method in class org.infinispan.container.entries.MortalCacheValue
 
hashCode() - Method in class org.infinispan.container.entries.TransientCacheValue
 
hashCode() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
hashCode() - Method in class org.infinispan.container.versioning.NumericVersion
 
hashCode() - Method in class org.infinispan.container.versioning.SimpleClusteredVersion
 
hashCode() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
hashCode() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
 
hashCode() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
 
hashCode() - Method in class org.infinispan.distribution.ch.impl.HashFunctionPartitioner
 
hashCode() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
hashCode() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory
 
hashCode() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
 
hashCode() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory
 
hashCode() - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory
 
hashCode() - Method in class org.infinispan.distribution.group.impl.PartitionerConsistentHash
 
hashCode() - Method in class org.infinispan.encoding.DataConversion
 
hashCode() - Method in class org.infinispan.functional.MetaParam.MetaEntryVersion
 
hashCode() - Method in class org.infinispan.functional.MetaParam.MetaLoadedFromPersistence
 
hashCode() - Method in class org.infinispan.functional.MetaParam.MetaLong
 
hashCode() - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
 
hashCode() - Method in class org.infinispan.globalstate.ScopedState
 
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.marshall.core.MarshalledEntryImpl
 
hashCode() - Method in class org.infinispan.metadata.EmbeddedMetadata
 
hashCode() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
 
hashCode() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
hashCode() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
hashCode() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.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.remoting.LocalInvocation
 
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
Deprecated.
 
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.security.CachePermission
 
hashCode() - Method in class org.infinispan.security.impl.CachePrincipalPair
 
hashCode() - Method in class org.infinispan.security.impl.CacheRoleImpl
 
hashCode() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
hashCode() - Method in class org.infinispan.topology.CacheJoinInfo
 
hashCode() - Method in class org.infinispan.topology.CacheTopology
 
hashCode() - Method in class org.infinispan.topology.PersistentUUID
 
hashCode() - Method in class org.infinispan.transaction.impl.AbstractEnlistmentAdapter
Invoked by TransactionManagers, make sure it's an efficient implementation.
hashCode() - Method in class org.infinispan.transaction.impl.LocalTransaction
 
hashCode() - Method in class org.infinispan.transaction.impl.RemoteTransaction
 
hashCode() - Method in class org.infinispan.transaction.impl.TotalOrderRemoteTransactionState
 
hashCode() - Method in class org.infinispan.transaction.tm.DummyNoXaXid
Deprecated.
Implementing an efficient hashCode is critical for performance:
hashCode() - Method in class org.infinispan.transaction.tm.DummyTransaction
Deprecated.
Must be defined for increased performance
hashCode() - Method in class org.infinispan.transaction.tm.DummyXid
Deprecated.
 
hashCode() - Method in class org.infinispan.transaction.totalorder.TotalOrderLatchImpl
 
hashCode() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
Deprecated.
 
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
Deprecated.
 
hashCode() - Method in class org.infinispan.util.ByteString
 
hashCode() - Method in class org.infinispan.util.KeyValuePair
 
hashCode() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferCollector
 
HashConfiguration - Class in org.infinispan.configuration.cache
Allows fine-tuning of rehashing characteristics.
HashConfigurationBuilder - Class in org.infinispan.configuration.cache
Allows fine-tuning of rehashing characteristics.
hashFunction - Variable in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
hashFunction - Variable in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
HashFunctionPartitioner - Class in org.infinispan.distribution.ch.impl
Key partitioner that computes a key's segment based on a hash function.
HashFunctionPartitioner() - Constructor for class org.infinispan.distribution.ch.impl.HashFunctionPartitioner
 
hashNumVirtualNodesDeprecated() - Method in class org.infinispan.util.logging.Log_$logger
 
hashNumVirtualNodesDeprecated() - Method in interface org.infinispan.util.logging.Log
 
hashNumVirtualNodesDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
hashToSegment(T) - Method in class org.infinispan.util.StripedHashFunction
It calculates the segment in which the object belongs.
hasInUseBackup(String) - Method in class org.infinispan.configuration.cache.SitesConfiguration
 
hasKeys() - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
hasLifespan() - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
hasLocalBias(Object) - Method in interface org.infinispan.scattered.BiasManager
Check if we can read local data and update last-read timestamp for this key.
hasLocalBias(Object) - Method in class org.infinispan.scattered.impl.BiasManagerImpl
 
hasLockedKey(Object) - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
hasLockedKey(Object) - Method in class org.infinispan.context.impl.ClearInvocationContext
 
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
Deprecated.
 
hasMaxIdle() - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
hasModification(Class<?>) - Method in class org.infinispan.transaction.impl.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.distribution.util.ReadOnlySegmentAwareIterator
 
hasNext() - Method in class org.infinispan.interceptors.base.CommandInterceptor
Deprecated.
Note: Unlike CommandInterceptor.getNext(), this method does not ignore interceptors that do not extend CommandInterceptor
hasNext() - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
 
hasNext() - Method in class org.infinispan.util.CloseableSuppliedIterator
 
hasNext() - Method in class org.infinispan.util.DataContainerRemoveIterator
 
hasNext() - Method in class org.infinispan.util.LazyConcatIterator
 
hasPendingBackupAcks(long) - Method in class org.infinispan.util.concurrent.CommandAckCollector
 
hasSameFlags(FlagAffectedCommand) - Method in class org.infinispan.commands.AbstractFlagAffectedCommand
 
hasSharedCacheLoaderOrWriter(Configuration) - Static method in class org.infinispan.configuration.cache.Configurations
 
hasSkipLoadFlag(FlagAffectedCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
hasSkipLocking() - Method in class org.infinispan.commands.control.LockControlCommand
 
hasSkipLocking() - Method in class org.infinispan.commands.functional.AbstractWriteManyCommand
 
hasSkipLocking() - Method in class org.infinispan.commands.tx.PrepareCommand
 
hasSkipLocking() - Method in class org.infinispan.commands.write.AbstractDataWriteCommand
 
hasSkipLocking() - Method in class org.infinispan.commands.write.InvalidateCommand
 
hasSkipLocking() - Method in class org.infinispan.commands.write.PutMapCommand
 
hasSkipLocking() - Method in interface org.infinispan.util.concurrent.locks.RemoteLockCommand
It checks if this command should acquire locks.
hasSkipLocking(FlagAffectedCommand) - Method in class org.infinispan.interceptors.base.CommandInterceptor
Deprecated.
 
hasTimedOut() - Method in interface org.infinispan.util.concurrent.locks.PendingLockPromise
 
hasTopologyInfo() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
hasZeroLockAcquisition() - Method in class org.infinispan.commands.control.LockControlCommand
 
hasZeroLockAcquisition() - Method in class org.infinispan.commands.functional.AbstractWriteManyCommand
 
hasZeroLockAcquisition() - Method in class org.infinispan.commands.tx.PrepareCommand
 
hasZeroLockAcquisition() - Method in class org.infinispan.commands.write.AbstractDataWriteCommand
 
hasZeroLockAcquisition() - Method in class org.infinispan.commands.write.InvalidateCommand
 
hasZeroLockAcquisition() - Method in class org.infinispan.commands.write.PutMapCommand
 
hasZeroLockAcquisition() - Method in interface org.infinispan.util.concurrent.locks.RemoteLockCommand
 
Health - Interface in org.infinispan.health
An entry point for checking health status.
HealthImpl - Class in org.infinispan.health.impl
 
HealthImpl(EmbeddedCacheManager) - Constructor for class org.infinispan.health.impl.HealthImpl
 
HealthJMXExposer - Interface in org.infinispan.health.jmx
A Contract for exposing Health API over the JMX.
HealthJMXExposerImpl - Class in org.infinispan.health.impl.jmx
A JMX exposer (or adapter) for Health API.
HealthJMXExposerImpl(Health) - Constructor for class org.infinispan.health.impl.jmx.HealthJMXExposerImpl
 
HealthStatus - Enum in org.infinispan.health
General Health status.
HEALTHY - org.infinispan.health.HealthStatus
Given entity is healthy.
HeartBeatCommand - Class in org.infinispan.topology
A hear-beat command used to ping members in ClusterTopologyManagerImpl.confirmMembersAvailable().
HeartBeatCommand() - Constructor for class org.infinispan.topology.HeartBeatCommand
 
HIT - Static variable in class org.infinispan.functional.impl.StatsEnvelope
 
hookBehavior() - Method in class org.infinispan.configuration.global.ShutdownConfiguration
 
hookBehavior(ShutdownHookBehavior) - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
 
HostInfo - Interface in org.infinispan.health
Information about the host.
HostInfoImpl - Class in org.infinispan.health.impl
 
HostInfoImpl() - Constructor for class org.infinispan.health.impl.HostInfoImpl
 

I

icf - Variable in class org.infinispan.commands.remote.BaseRpcInvokingCommand
Deprecated.
 
icf - Variable in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
icf - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
id - Variable in class org.infinispan.stream.impl.StreamIteratorCloseCommand
 
id - Variable in class org.infinispan.stream.impl.StreamIteratorNextCommand
 
id - Variable in class org.infinispan.stream.impl.StreamResponseCommand
 
id - Variable in class org.infinispan.transaction.xa.GlobalTransaction
 
id() - Method in enum org.infinispan.functional.Param.ExecutionMode
 
id() - Method in interface org.infinispan.functional.Param
A parameter's identifier.
id() - Method in enum org.infinispan.functional.Param.LockingMode
 
id() - Method in enum org.infinispan.functional.Param.PersistenceMode
 
id() - Method in enum org.infinispan.functional.Param.ReplicationMode
 
id() - Method in enum org.infinispan.functional.Param.StatisticsMode
 
ID - org.infinispan.configuration.parsing.Attribute
 
ID - Static variable in enum org.infinispan.functional.Param.ExecutionMode
 
ID - Static variable in enum org.infinispan.functional.Param.LockingMode
 
ID - Static variable in enum org.infinispan.functional.Param.PersistenceMode
 
ID - Static variable in enum org.infinispan.functional.Param.ReplicationMode
 
ID - Static variable in enum org.infinispan.functional.Param.StatisticsMode
 
identifier - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
identity() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
identity() - Static method in class org.infinispan.stream.StreamMarshalling
Same as Function.identity() except that this instance is also able to be marshalled by Infinispan.
IDENTITY_KEY - Static variable in class org.infinispan.encoding.DataConversion
 
IDENTITY_ROLE_MAPPER - org.infinispan.configuration.parsing.Element
 
IDENTITY_VALUE - Static variable in class org.infinispan.encoding.DataConversion
 
IdentityRoleMapper - Class in org.infinispan.security.impl
IdentityRoleMapper.
IdentityRoleMapper() - Constructor for class org.infinispan.security.impl.IdentityRoleMapper
 
Ids - Interface in org.infinispan.marshall.core
Indexes for object types.
IGNORE - org.infinispan.configuration.cache.BackupFailurePolicy
 
IGNORE_MODIFICATIONS - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
IGNORE_RETURN_VALUES - org.infinispan.context.Flag
Signals that a write operation's return value will be ignored, so reading the existing value from a store or from a remote node is not necessary.
IGNORE_RETURN_VALUES - Static variable in class org.infinispan.context.impl.FlagBitSets
 
ignoreCommandOnStatus(ComponentStatus) - Method in interface org.infinispan.commands.VisitableCommand
Deprecated.
Since 9.0, no longer used.
ignoredAttribute(String, String, String, int) - Method in class org.infinispan.util.logging.Log_$logger
 
ignoredAttribute(String, String, String, int) - Method in interface org.infinispan.util.logging.Log
 
ignoredAttribute$str() - Method in class org.infinispan.util.logging.Log_$logger
 
ignoredReplicationQueueAttribute(String, int) - Method in class org.infinispan.util.logging.Log_$logger
 
ignoredReplicationQueueAttribute(String, int) - Method in interface org.infinispan.util.logging.Log
 
ignoredReplicationQueueAttribute$str() - Method in class org.infinispan.util.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
 
ignoreLeavers() - Static method in class org.infinispan.remoting.transport.impl.MapResponseCollector
 
ignoreLeavers() - Static method in class org.infinispan.remoting.transport.impl.SingletonMapResponseCollector
 
ignoreLeavers() - Static method in class org.infinispan.remoting.transport.impl.VoidResponseCollector
 
ignoreLeavers(boolean) - Static method in class org.infinispan.remoting.transport.impl.MapResponseCollector
 
ignoreLeavers(boolean, int) - Static method in class org.infinispan.remoting.transport.impl.MapResponseCollector
 
ignoreLeavers(int) - Static method in class org.infinispan.remoting.transport.impl.MapResponseCollector
 
ignoreMaxSegments - Variable in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
ignoreModifications - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
Deprecated.
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() - 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 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(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.
ignoreXmlAttribute(Object) - Method in class org.infinispan.util.logging.Log_$logger
 
ignoreXmlAttribute(Object) - Method in interface org.infinispan.util.logging.Log
 
ignoreXmlAttribute$str() - Method in class org.infinispan.util.logging.Log_$logger
 
ignoreXmlElement(Object) - Method in class org.infinispan.util.logging.Log_$logger
 
ignoreXmlElement(Object) - Method in interface org.infinispan.util.logging.Log
 
ignoreXmlElement$str() - Method in class org.infinispan.util.logging.Log_$logger
 
ignoringCacheTopology(Collection<Address>, CacheTopology) - Method in class org.infinispan.util.logging.Log_$logger
 
ignoringCacheTopology(Collection<Address>, CacheTopology) - Method in interface org.infinispan.util.logging.Log
 
ignoringCacheTopology$str() - Method in class org.infinispan.util.logging.Log_$logger
 
ignoringInvalidateVersionsFromOldTopology(int, int) - Method in class org.infinispan.util.logging.Log_$logger
 
ignoringInvalidateVersionsFromOldTopology(int, int) - Method in interface org.infinispan.util.logging.Log
 
ignoringInvalidateVersionsFromOldTopology$str() - Method in class org.infinispan.util.logging.Log_$logger
 
ignoringUnsolicitedState(Address, int, String) - Method in class org.infinispan.util.logging.Log_$logger
 
ignoringUnsolicitedState(Address, int, String) - Method in interface org.infinispan.util.logging.Log
 
ignoringUnsolicitedState$str() - Method in class org.infinispan.util.logging.Log_$logger
 
illegalCacheName(String) - Method in class org.infinispan.util.logging.Log_$logger
 
illegalCacheName(String) - Method in interface org.infinispan.util.logging.Log
 
illegalCacheName$str() - Method in class org.infinispan.util.logging.Log_$logger
 
IllegalLifecycleStateException - Exception in org.infinispan
This exception is thrown when the cache or cache manager does not have the right lifecycle state for operations to be called on it.
IllegalLifecycleStateException() - Constructor for exception org.infinispan.IllegalLifecycleStateException
 
IllegalLifecycleStateException(String) - Constructor for exception org.infinispan.IllegalLifecycleStateException
 
IllegalLifecycleStateException(String, Throwable) - Constructor for exception org.infinispan.IllegalLifecycleStateException
 
IllegalLifecycleStateException(Throwable) - Constructor for exception org.infinispan.IllegalLifecycleStateException
 
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 - org.infinispan.globalstate.ConfigurationStorage
An immutable configuration storage provider.
IMMUTABLE_CONFIGURATION_STORAGE - org.infinispan.configuration.parsing.Element
 
immutableConfiguration() - Method in class org.infinispan.util.logging.Log_$logger
 
immutableConfiguration() - Method in interface org.infinispan.util.logging.Log
 
immutableConfiguration$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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.
immutableInternalCacheEntry(InternalCacheEntry<K, V>) - Static method in class org.infinispan.util.CoreImmutables
Wraps a InternalCacheEntry} with an immutable InternalCacheEntry}.
ImmutableLocalConfigurationStorage - Class in org.infinispan.globalstate.impl
An immutable implementation of LocalConfigurationStorage which does not allow cache creation/removal.
ImmutableLocalConfigurationStorage() - Constructor for class org.infinispan.globalstate.impl.ImmutableLocalConfigurationStorage
 
ImmutableMarshalledValueByteStream - Class in org.infinispan.io
A byte stream that is immutable.
ImmutableMarshalledValueByteStream(byte[]) - Constructor for class org.infinispan.io.ImmutableMarshalledValueByteStream
 
implies(Permission) - Method in class org.infinispan.security.CachePermission
 
implies(Permission) - Method in class org.infinispan.security.CachePermissionCollection
 
implies(AuthorizationPermission) - Method in enum org.infinispan.security.AuthorizationPermission
 
IN_PROGRESS - org.infinispan.topology.RebalancingStatus
 
IN_USE_BACKUP_SITES - Static variable in class org.infinispan.configuration.cache.SitesConfiguration
 
InboundInvocationHandler - Interface in org.infinispan.remoting.inboundhandler
Interface to invoke when the Transport receives a command from other node or site.
InboundInvocationHandlerFactory - Class in org.infinispan.factories
Factory class that creates instances of PerCacheInboundInvocationHandler.
InboundInvocationHandlerFactory() - Constructor for class org.infinispan.factories.InboundInvocationHandlerFactory
 
inboundSegments - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
InboundTransferTask - Class in org.infinispan.statetransfer
Inbound state transfer task.
InboundTransferTask(IntSet, Address, int, RpcManager, CommandsFactory, long, String, boolean) - Constructor for class org.infinispan.statetransfer.InboundTransferTask
 
include(TopologyAwareAddress, TopologyAwareAddress) - Method in enum org.infinispan.manager.ClusterExecutionPolicy
 
includeCurrentState() - Method in annotation type org.infinispan.notifications.Listener
If set to true then the entire existing state within the cluster is evaluated.
includeLoader - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
incompatibleClusterConfiguration(String, Configuration, Configuration) - Method in class org.infinispan.util.logging.Log_$logger
 
incompatibleClusterConfiguration(String, Configuration, Configuration) - Method in interface org.infinispan.util.logging.Log
 
incompatibleClusterConfiguration$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.impl.OwnershipStatistics
 
incPrimaryOwned(Address) - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
 
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.
incrementVersion(int) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
incrementVersion(int) - Method in interface org.infinispan.scattered.ScatteredVersionManager
Generates a new version for an entry in given segment.
index() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
Returns the indexing mode of this cache.
index() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
index(int) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
Specifies a position in the interceptor chain to place the new interceptor.
index(Index) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
Indicates indexing mode
Index - Enum in org.infinispan.configuration.cache
Used to configure indexing of entries in the cache for index-assisted searching.
INDEX - org.infinispan.configuration.parsing.Attribute
 
INDEX - Static variable in class org.infinispan.configuration.cache.IndexingConfiguration
 
INDEX - Static variable in class org.infinispan.configuration.cache.InterceptorConfiguration
 
INDEXED_ENTITIES - org.infinispan.configuration.parsing.Element
 
INDEXED_ENTITIES - Static variable in class org.infinispan.configuration.cache.IndexingConfiguration
 
INDEXED_ENTITY - org.infinispan.configuration.parsing.Element
 
indexedEntities() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
 
IndexedFilter<K,​V,​C> - Interface in org.infinispan.notifications.cachelistener.filter
A marker interface for filters that can be handled efficiently by a FilterIndexingServiceProvider.
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
 
INDEXING - org.infinispan.configuration.parsing.Element
 
IndexingConfiguration - Class in org.infinispan.configuration.cache
Configures indexing of entries in the cache for searching.
IndexingConfigurationBuilder - Class in org.infinispan.configuration.cache
Configures indexing of entries in the cache for searching.
indexLocalOnly() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
Deprecated.
indexLocalOnly(boolean) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
indexShareable() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
Check if the indexes can be shared.
InDoubtTxInfoImpl - Class in org.infinispan.transaction.xa.recovery
 
InDoubtTxInfoImpl(Xid, long) - Constructor for class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
InDoubtTxInfoImpl(Xid, long, IntSet) - Constructor for class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
InDoubtTxInfoImpl(Xid, Long, Integer) - 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.
InfinispanLock - Class in org.infinispan.util.concurrent.locks.impl
A special lock for Infinispan cache.
InfinispanLock(Executor, TimeService) - Constructor for class org.infinispan.util.concurrent.locks.impl.InfinispanLock
Creates a new instance.
InfinispanLock(Executor, TimeService, Runnable) - Constructor for class org.infinispan.util.concurrent.locks.impl.InfinispanLock
Creates a new instance.
info(EventLogCategory, String) - Method in interface org.infinispan.util.logging.events.EventLogger
Logs a message to the event log using the EventLogLevel.INFO severity
INFO - org.infinispan.security.AuditResponse
 
INFO - org.infinispan.util.logging.events.EventLogLevel
 
init() - Method in class org.infinispan.container.impl.EntryFactoryImpl
 
init() - Method in class org.infinispan.interceptors.impl.BaseRpcInterceptor
 
init(boolean, boolean, boolean, boolean) - Method in class org.infinispan.transaction.xa.TransactionFactory
 
init(String, GlobalConfiguration, Configuration, GlobalSecurityManager, EmbeddedCacheManager) - Method in class org.infinispan.security.impl.AuthorizationManagerImpl
 
init(Cache) - Method in class org.infinispan.xsite.AbstractCustomFailurePolicy
 
init(Cache<Object, Object>) - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
init(Cache<K, V>) - Method in interface org.infinispan.xsite.CustomFailurePolicy
Invoked during the initialization phase.
init(CancellationService) - Method in class org.infinispan.commands.CancelCommand
 
init(Configuration) - Method in class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
Deprecated.
init(Configuration) - Method in class org.infinispan.transaction.lookup.WildflyTransactionManagerLookup
Deprecated.
Use WildflyTransactionManagerLookup.init(GlobalConfiguration) instead since Configuration has no access to classloader any more.
init(HashConfiguration) - Method in class org.infinispan.distribution.ch.impl.HashFunctionPartitioner
 
init(HashConfiguration) - Method in interface org.infinispan.distribution.ch.KeyPartitioner
Initialization.
init(GlobalConfiguration) - Method in class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
 
init(GlobalConfiguration) - Method in class org.infinispan.transaction.lookup.WildflyTransactionManagerLookup
 
init(DataContainer, OrderedUpdatesManager, StateTransferLock, DistributionManager, BiasManager) - Method in class org.infinispan.commands.write.InvalidateVersionsCommand
 
init(InvocationContextFactory, CommandsFactory, InternalEntryFactory, AsyncInterceptorChain, TransactionTable) - Method in class org.infinispan.commands.remote.ClusteredGetAllCommand
 
init(InvocationContextFactory, AsyncInterceptorChain, ComponentRegistry) - Method in class org.infinispan.commands.triangle.MultiEntriesFunctionalBackupWriteCommand
 
init(InvocationContextFactory, AsyncInterceptorChain, ComponentRegistry) - Method in class org.infinispan.commands.triangle.MultiKeyFunctionalBackupWriteCommand
 
init(InvocationContextFactory, AsyncInterceptorChain, ComponentRegistry) - Method in class org.infinispan.commands.triangle.SingleKeyFunctionalBackupWriteCommand
 
init(InvocationContextFactory, AsyncInterceptorChain, CacheNotifier) - Method in class org.infinispan.commands.triangle.PutMapBackupWriteCommand
 
init(InvocationContextFactory, AsyncInterceptorChain, CacheNotifier, ComponentRegistry, VersionGenerator) - Method in class org.infinispan.commands.triangle.SingleKeyBackupWriteCommand
 
init(DistributionManager, CacheNotifier, DataContainer) - Method in class org.infinispan.commands.write.InvalidateL1Command
 
init(ComponentRegistry) - Method in class org.infinispan.commands.functional.AbstractWriteKeyCommand
 
init(ComponentRegistry) - Method in class org.infinispan.commands.functional.AbstractWriteManyCommand
 
init(ComponentRegistry) - Method in class org.infinispan.commands.functional.ReadOnlyKeyCommand
 
init(ComponentRegistry) - Method in class org.infinispan.commands.functional.ReadOnlyManyCommand
 
init(ComponentRegistry) - Method in class org.infinispan.commands.functional.ReadWriteKeyCommand
 
init(ComponentRegistry) - Method in class org.infinispan.commands.functional.ReadWriteKeyValueCommand
 
init(ComponentRegistry) - Method in class org.infinispan.commands.functional.ReadWriteManyCommand
 
init(ComponentRegistry) - Method in class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
init(ComponentRegistry) - Method in class org.infinispan.commands.functional.TxReadOnlyKeyCommand
 
init(ComponentRegistry) - Method in class org.infinispan.commands.functional.TxReadOnlyManyCommand
 
init(ComponentRegistry) - Method in class org.infinispan.commands.functional.WriteOnlyKeyCommand
 
init(ComponentRegistry) - Method in class org.infinispan.commands.functional.WriteOnlyKeyValueCommand
 
init(ComponentRegistry) - Method in class org.infinispan.commands.functional.WriteOnlyManyCommand
 
init(ComponentRegistry) - Method in class org.infinispan.commands.functional.WriteOnlyManyEntriesCommand
 
init(AsyncInterceptorChain, InvocationContextFactory) - Method in class org.infinispan.commands.remote.BaseRpcInvokingCommand
Deprecated.
 
init(AsyncInterceptorChain, InvocationContextFactory, TransactionTable) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
init(EmbeddedCacheManager) - Method in class org.infinispan.commands.CreateCacheCommand
 
init(EmbeddedCacheManager, GlobalConfiguration) - Method in class org.infinispan.stats.impl.ClusterContainerStatsImpl
 
init(EmbeddedCacheManager, GlobalConfiguration, InternalCacheRegistry) - Method in class org.infinispan.security.impl.GlobalSecurityManagerImpl
 
init(CacheNotifier) - Method in class org.infinispan.commands.write.InvalidateCommand
 
init(CacheNotifier) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
init(CacheNotifier) - Method in class org.infinispan.commands.write.RemoveCommand
 
init(CacheNotifier) - Method in class org.infinispan.commands.write.ReplaceCommand
 
init(CacheNotifier<Object, Object>) - Method in class org.infinispan.commands.write.PutMapCommand
 
init(CacheNotifier<Object, Object>, DataContainer<?, ?>) - Method in class org.infinispan.commands.write.ClearCommand
 
init(CacheNotifier, IncrementableEntryVersion, TimeService) - Method in class org.infinispan.commands.write.RemoveExpiredCommand
 
init(CacheNotifier, ComponentRegistry) - Method in class org.infinispan.commands.write.ComputeCommand
 
init(CacheNotifier, ComponentRegistry) - Method in class org.infinispan.commands.write.ComputeIfAbsentCommand
 
init(InitializationContext) - Method in class org.infinispan.persistence.async.AsyncCacheWriter
 
init(InitializationContext) - Method in class org.infinispan.persistence.cluster.ClusterLoader
 
init(InitializationContext) - Method in class org.infinispan.persistence.file.SingleFileStore
 
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.ComposedSegmentedLoadWriteStore
 
init(InitializationContext) - Method in class org.infinispan.persistence.support.DelegatingCacheLoader
 
init(InitializationContext) - Method in class org.infinispan.persistence.support.DelegatingCacheWriter
 
init(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.BaseLockingAction
 
init(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.LockAction
 
init(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.PendingTxAction
 
init(RpcManager, CommandsFactory, ComponentRef<TransactionTable>, TransactionCoordinator, TransactionFactory) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
init(Transport, Configuration, KeyPartitioner) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
 
init(BiasManager) - Method in class org.infinispan.commands.remote.RenewBiasCommand
 
init(BiasManager, CommandsFactory, RpcManager) - Method in class org.infinispan.commands.remote.RevokeBiasCommand
 
init(StateConsumer, StateReceiver) - Method in class org.infinispan.statetransfer.StateResponseCommand
 
init(StateProvider, BiasManager) - Method in class org.infinispan.statetransfer.StateRequestCommand
 
init(TransactionTable, LockManager, RecoveryManager, StateTransferManager) - Method in class org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
 
init(RecoveryManager) - Method in class org.infinispan.commands.remote.recovery.RecoveryCommand
 
init(BackupSender) - Method in class org.infinispan.xsite.XSiteAdminCommand
 
INIT - org.infinispan.remoting.inboundhandler.action.BaseLockingAction.InternalState
 
initChannel() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
initChunkSizeFromMetadata() - Method in class org.infinispan.io.GridFile
 
INITIAL_CLUSTER_SIZE - org.infinispan.configuration.parsing.Attribute
 
INITIAL_CLUSTER_SIZE - Static variable in class org.infinispan.configuration.global.TransportConfiguration
 
INITIAL_CLUSTER_TIMEOUT - org.infinispan.configuration.parsing.Attribute
 
INITIAL_CLUSTER_TIMEOUT - Static variable in class org.infinispan.configuration.global.TransportConfiguration
 
INITIAL_CONNECTION_ATTEMPTS - Static variable in class org.infinispan.topology.ClusterTopologyManagerImpl
 
INITIAL_REBALANCE_ID - Static variable in class org.infinispan.topology.ClusterCacheStatus
 
INITIAL_TOPOLOGY_ID - Static variable in class org.infinispan.topology.ClusterCacheStatus
 
initialClusterSize() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
initialClusterSize(int) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
Sets the number of nodes that need to join before the cache container can start.
initialClusterTimeout() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
initialClusterTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
Sets the timeout for the initial cluster to form.
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, KeyPartitioner, StreamingMarshaller, TimeService, ByteBufferFactory, MarshalledEntryFactory, ExecutorService) - Constructor for class org.infinispan.persistence.InitializationContextImpl
 
initialize(Iterable<ModuleMetadataFileFinder>, ClassLoader) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
Initializes this repository.
initialize(InvocationContextFactory, CommandsFactory, InternalEntryFactory, AsyncInterceptorChain) - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
initialize(EmbeddedCacheManager) - Method in class org.infinispan.globalstate.impl.ImmutableLocalConfigurationStorage
 
initialize(EmbeddedCacheManager) - Method in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
 
initialize(EmbeddedCacheManager) - Method in interface org.infinispan.globalstate.LocalConfigurationStorage
Initialization entry point for the LocalConfigurationStorage
initialize(CacheNotifier, RecoveryManager) - Method in class org.infinispan.commands.tx.PrepareCommand
 
initialize(XSiteStateConsumer) - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
 
initialize(XSiteStateProvider, XSiteStateConsumer, XSiteStateTransferManager) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
 
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) with necessary named-cache-specific components.
INITIALIZING - org.infinispan.lifecycle.ComponentStatus
The start() method has been called but not yet completed.
INITIALIZING - org.infinispan.topology.ClusterTopologyManager.ClusterManagerStatus
 
initialPriority() - Method in class org.infinispan.factories.threads.DefaultThreadFactory
 
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
 
initMBeanServer(GlobalConfiguration) - Method in class org.infinispan.jmx.AbstractJmxRegistration
 
initTopologyId() - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
inject(Executor, TimeService) - Method in class org.infinispan.util.concurrent.locks.impl.PerKeyLockContainer
 
inject(Executor, TimeService) - Method in class org.infinispan.util.concurrent.locks.impl.StripedLockContainer
 
inject(Cache<K, V>) - Method in class org.infinispan.stream.impl.LocalStreamManagerImpl
Injects the cache - unfortunately this cannot be in start.
inject(Configuration, CacheNotifier, InternalDataContainer, KeyValueMetadataSizeCalculator, DistributionManager) - Method in class org.infinispan.interceptors.impl.TransactionalExceptionEvictionInterceptor
 
inject(GlobalConfiguration, EmbeddedCacheManager, LocalTopologyManager) - Method in class org.infinispan.globalstate.impl.GlobalConfigurationManagerImpl
 
inject(InternalDataContainer) - Method in class org.infinispan.commands.remote.expiration.UpdateLastAccessCommand
 
inject(InternalDataContainer, TimeService) - Method in class org.infinispan.commands.remote.expiration.RetrieveLastAccessCommand
 
inject(ComponentRegistry) - Method in interface org.infinispan.commands.functional.functions.InjectableComponent
 
inject(ComponentRegistry) - Method in class org.infinispan.commands.functional.functions.MergeFunction
 
inject(BiasManager) - Method in class org.infinispan.interceptors.impl.BiasedEntryWrappingInterceptor
 
inject(ClusterStreamManager) - Method in class org.infinispan.stream.impl.StreamResponseCommand
 
inject(IteratorHandler) - Method in class org.infinispan.stream.impl.StreamIteratorCloseCommand
 
inject(LocalStreamManager) - Method in class org.infinispan.stream.impl.StreamIteratorNextCommand
 
inject(LocalStreamManager) - Method in class org.infinispan.stream.impl.StreamRequestCommand
 
inject(CommandAckCollector, BiasManager) - Method in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor
 
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.
InjectableComponent - Interface in org.infinispan.commands.functional.functions
 
injectCache(Cache<K, V>) - Method in interface org.infinispan.stream.CacheAware
Method that is invoked when a cache is to be injected.
injectDependencies() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
injectDependencies() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
Deprecated.
Injects dependencies into this component.
injectDependencies(Cache<?, ?>, Configuration) - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
injectDependencies(GlobalConfiguration, EncoderRegistry, Configuration) - Method in class org.infinispan.encoding.DataConversion
 
injectDependencies(ComponentRegistry) - Method in class org.infinispan.cache.impl.EncoderEntryMapper
 
injectDependencies(ComponentRegistry) - Method in class org.infinispan.cache.impl.EncoderKeyMapper
 
injectDependencies(ComponentRegistry) - Method in class org.infinispan.cache.impl.EncoderValueMapper
 
injectDependencies(ComponentRegistry) - Method in class org.infinispan.compat.BiFunctionMapper
 
injectDependencies(ComponentRegistry) - Method in class org.infinispan.compat.FunctionMapper
 
injectDependencies(ComponentRegistry) - Method in class org.infinispan.filter.CompositeKeyFilter
 
injectDependencies(ComponentRegistry) - Method in class org.infinispan.filter.CompositeKeyValueFilter
 
injectDependencies(ComponentRegistry) - Method in class org.infinispan.filter.KeyFilterAsKeyValueFilter
 
injectDependencies(ComponentRegistry) - Method in class org.infinispan.filter.KeyValueFilterAsKeyFilter
 
injectDependencies(ComponentRegistry) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventConverterAsConverter
 
injectDependencies(ComponentRegistry) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterAsKeyValueFilter
 
injectDependencies(ComponentRegistry) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverterAsKeyValueFilterConverter
 
injectDependencies(ComponentRegistry) - Method in class org.infinispan.notifications.cachelistener.filter.CompositeCacheEventFilter
 
injectDependencies(ComponentRegistry) - Method in class org.infinispan.notifications.cachelistener.filter.KeyFilterAsCacheEventFilter
 
injectDependencies(ComponentRegistry) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterAsCacheEventFilter
 
injectDependencies(ComponentRegistry) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter
 
injectFactoryForComponent(Class<?>, Class<?>) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
Deprecated.
For testing purposes only.
InjectFieldMetadata(String, String, String, String, boolean) - Constructor for class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
 
inputKeys() - Method in interface org.infinispan.distexec.FailoverContext
Returns a list of input keys for this task.
INSTANCE - Static variable in class org.infinispan.context.impl.ImmutableContext
 
INSTANCE - Static variable in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
INSTANCE - Static variable in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor.LostDataVisitor
 
INSTANCE - Static variable in class org.infinispan.remoting.responses.CacheNotFoundResponse
 
INSTANCE - Static variable in class org.infinispan.remoting.responses.UnsureResponse
 
INSTANCE - Static variable in class org.infinispan.remoting.transport.impl.PassthroughSingleResponseCollector
 
INSTANCE - Static variable in class org.infinispan.remoting.transport.LocalModeAddress
 
INSTANCE - Static variable in exception org.infinispan.statetransfer.AllOwnersLostException
 
INSTANCE - Static variable in exception org.infinispan.statetransfer.OutdatedTopologyException
A cached instance of OutdatedTopologyException.
INSTANCE - Static variable in class org.infinispan.topology.HeartBeatCommand
 
INSTANCE - Static variable in class org.infinispan.transaction.lookup.GenericTransactionManagerLookup
 
INSTANCE - Static variable in class org.infinispan.util.logging.events.Messages_$bundle
 
INSTANTIATED - org.infinispan.lifecycle.ComponentStatus
Object has been instantiated, but start() has not been called.
INT - org.infinispan.stream.impl.IntermediateType
 
intCacheStream() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
intCacheStream() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
intCacheStream() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
intCacheStream() - Method in class org.infinispan.stream.impl.tx.TxDistributedCacheStream
 
intCacheStream() - Method in class org.infinispan.stream.impl.tx.TxDistributedDoubleCacheStream
 
intCacheStream() - Method in class org.infinispan.stream.impl.tx.TxDistributedLongCacheStream
 
IntCacheStream - Interface in org.infinispan
A IntStream that has additional methods to allow for Serializable instances.
interceptListenerInvocation(CacheEntryListenerInvocation<K, V>) - Method in interface org.infinispan.notifications.cachelistener.filter.FilterIndexingServiceProvider
Starts handling an invocation that uses an IndexedFilter.
interceptor() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
Deprecated.
Since 9.0, please use InterceptorConfiguration.asyncInterceptor() instead.
interceptor(AsyncInterceptor) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
An instance of the new custom interceptor to add to the configuration.
interceptor(CommandInterceptor) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
Deprecated.
INTERCEPTOR - org.infinispan.configuration.parsing.Element
 
INTERCEPTOR - Static variable in class org.infinispan.configuration.cache.InterceptorConfiguration
 
INTERCEPTOR_CLASS - Static variable in class org.infinispan.configuration.cache.InterceptorConfiguration
 
interceptorChain - Variable in class org.infinispan.commands.remote.BaseRpcInvokingCommand
Deprecated.
 
interceptorChain - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
InterceptorChain - Class in org.infinispan.interceptors
Deprecated.
Since 9.0, use AsyncInterceptorChain instead. Some methods will ignore the interceptors that do not extend CommandInterceptor.
InterceptorChain() - Constructor for class org.infinispan.interceptors.InterceptorChain
Deprecated.
 
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
 
interceptorClass() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
Deprecated.
interceptorClass(Class<? extends AsyncInterceptor>) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
Class of the new custom interceptor to add to the configuration.
interceptorClassAndInstanceDefined(String, String) - Method in class org.infinispan.util.logging.Log_$logger
 
interceptorClassAndInstanceDefined(String, String) - Method in interface org.infinispan.util.logging.Log
 
interceptorClassAndInstanceDefined$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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
 
interceptorStackNotSupported() - Method in class org.infinispan.util.logging.Log_$logger
 
interceptorStackNotSupported() - Method in interface org.infinispan.util.logging.Log
 
interceptorStackNotSupported$str() - Method in class org.infinispan.util.logging.Log_$logger
 
IntermediateCacheStream<Original,​R> - Class in org.infinispan.stream.impl
An intermediate cache stream used when an intermediate operation that requires both a remote and local portion
IntermediateCacheStream(BaseCacheStream, IntermediateType, LocalCacheStream<R>, IntermediateCacheStreamSupplier) - Constructor for class org.infinispan.stream.impl.IntermediateCacheStream
 
IntermediateCacheStream(DistributedCacheStream<Original, R>) - Constructor for class org.infinispan.stream.impl.IntermediateCacheStream
 
IntermediateDoubleCacheStream - Class in org.infinispan.stream.impl
An intermediate double cache stream used when an intermediate operation that requires both a remote and local portion
IntermediateDoubleCacheStream(BaseCacheStream, IntermediateType, LocalDoubleCacheStream, IntermediateCacheStreamSupplier) - Constructor for class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
IntermediateDoubleCacheStream(DistributedDoubleCacheStream) - Constructor for class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
IntermediateIntCacheStream - Class in org.infinispan.stream.impl
An intermediate int cache stream used when an intermediate operation that requires both a remote and local portion
IntermediateIntCacheStream(BaseCacheStream, IntermediateType, LocalIntCacheStream, IntermediateCacheStreamSupplier) - Constructor for class org.infinispan.stream.impl.IntermediateIntCacheStream
 
IntermediateIntCacheStream(DistributedIntCacheStream) - Constructor for class org.infinispan.stream.impl.IntermediateIntCacheStream
 
IntermediateLongCacheStream - Class in org.infinispan.stream.impl
An intermediate long cache stream used when an intermediate operation that requires both a remote and local portion
IntermediateLongCacheStream(BaseCacheStream, IntermediateType, LocalLongCacheStream, IntermediateCacheStreamSupplier) - Constructor for class org.infinispan.stream.impl.IntermediateLongCacheStream
 
IntermediateLongCacheStream(DistributedLongCacheStream) - Constructor for class org.infinispan.stream.impl.IntermediateLongCacheStream
 
IntermediateOperation<InputType,​InputStream extends BaseStream<InputType,​InputStream>,​OutputType,​OutputStream extends BaseStream<OutputType,​OutputStream>> - Interface in org.infinispan.stream.impl.intops
Intermediate operation that can be applied to a stream to change its processing.
IntermediateOperationExternalizer - Class in org.infinispan.stream.impl.intops
Externalizer to be used for serializing the various intermediate operations
IntermediateOperationExternalizer() - Constructor for class org.infinispan.stream.impl.intops.IntermediateOperationExternalizer
 
intermediateOperations - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
intermediateOperations - Variable in class org.infinispan.stream.impl.local.AbstractLocalCacheStream
 
intermediateOperations - Variable in class org.infinispan.stream.impl.termop.BaseTerminalOperation
 
IntermediateType - Enum in org.infinispan.stream.impl
The various intermediate types.
InternalCacheEntry<K,​V> - 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
 
internalCacheHasFlag(String, InternalCacheRegistry.Flag) - Method in class org.infinispan.registry.impl.InternalCacheRegistryImpl
 
internalCacheHasFlag(String, InternalCacheRegistry.Flag) - Method in interface org.infinispan.registry.InternalCacheRegistry
Returns whether a particular internal cache has a specific flag
InternalCacheRegistry - Interface in org.infinispan.registry
InternalCacheRegistry.
InternalCacheRegistry.Flag - Enum in org.infinispan.registry
 
InternalCacheRegistryImpl - Class in org.infinispan.registry.impl
InternalCacheRegistryImpl.
InternalCacheRegistryImpl() - Constructor for class org.infinispan.registry.impl.InternalCacheRegistryImpl
 
InternalCacheValue<V> - Interface in org.infinispan.container.entries
A representation of an InternalCacheEntry that does not have a reference to the key.
InternalConflictManager<K,​V> - Interface in org.infinispan.conflict.impl
 
InternalDataContainer<K,​V> - Interface in org.infinispan.container.impl
Interface describing methods of a data container where operations can be indexed by the segment of the key stored in the map.
InternalDataContainerAdapter<K,​V> - Class in org.infinispan.container.impl
Wrapper around a DataContainer to provide operations for use with a InternalDataContainer.
InternalDataContainerAdapter(DataContainer<K, V>) - Constructor for class org.infinispan.container.impl.InternalDataContainerAdapter
 
InternalEntryFactory - Interface in org.infinispan.container.impl
A factory for InternalCacheEntry and InternalCacheValue instances.
InternalEntryFactoryImpl - Class in org.infinispan.container.impl
An implementation that generates non-versioned entries
InternalEntryFactoryImpl() - Constructor for class org.infinispan.container.impl.InternalEntryFactoryImpl
 
InternalExpirationManager<K,​V> - Interface in org.infinispan.expiration.impl
Interface describing the internal operations for the the ExpirationManager.
internalExternalizerIdLimitExceeded(AdvancedExternalizer<?>, int, int) - Method in class org.infinispan.util.logging.Log_$logger
 
internalExternalizerIdLimitExceeded(AdvancedExternalizer<?>, int, int) - Method in interface org.infinispan.util.logging.Log
 
internalExternalizerIdLimitExceeded$str() - Method in class org.infinispan.util.logging.Log_$logger
 
internalGetCache(String, String) - Method in class org.infinispan.manager.DefaultCacheManager
 
internalMetadata(InternalCacheEntry) - Static method in class org.infinispan.persistence.PersistenceUtil
 
internalMetadata(InternalCacheValue) - Static method in class org.infinispan.persistence.PersistenceUtil
 
InternalMetadata - Interface in org.infinispan.metadata
 
InternalMetadataImpl - Class in org.infinispan.metadata.impl
 
InternalMetadataImpl() - Constructor for class org.infinispan.metadata.impl.InternalMetadataImpl
 
InternalMetadataImpl(InternalCacheEntry) - Constructor for class org.infinispan.metadata.impl.InternalMetadataImpl
 
InternalMetadataImpl(Metadata, long, long) - Constructor for class org.infinispan.metadata.impl.InternalMetadataImpl
 
InternalMetadataImpl.Externalizer - Class in org.infinispan.metadata.impl
 
interruptedAcquiringLock(long, InterruptedException) - Method in class org.infinispan.util.logging.Log_$logger
 
interruptedAcquiringLock(long, InterruptedException) - Method in interface org.infinispan.util.logging.Log
 
interruptedAcquiringLock$str() - Method in class org.infinispan.util.logging.Log_$logger
 
interruptedWaitingAsyncStorePush(InterruptedException) - Method in class org.infinispan.util.logging.Log_$logger
 
interruptedWaitingAsyncStorePush(InterruptedException) - Method in interface org.infinispan.util.logging.Log
 
interruptedWaitingAsyncStorePush$str() - Method in class org.infinispan.util.logging.Log_$logger
 
interruptedWaitingForCoordinator(InterruptedException) - Method in class org.infinispan.util.logging.Log_$logger
 
interruptedWaitingForCoordinator(InterruptedException) - Method in interface org.infinispan.util.logging.Log
 
interruptedWaitingForCoordinator$str() - Method in class org.infinispan.util.logging.Log_$logger
 
INTERVAL - org.infinispan.configuration.parsing.Attribute
 
IntSetExternalizer - Class in org.infinispan.util
Externalizer to be used for IntSet implementations
IntSetExternalizer() - Constructor for class org.infinispan.util.IntSetExternalizer
 
IntSummaryStatisticsExternalizer - Class in org.infinispan.marshall.exts
Externalizer used for IntSummaryStatistics.
IntSummaryStatisticsExternalizer() - Constructor for class org.infinispan.marshall.exts.IntSummaryStatisticsExternalizer
 
inUseBackupSites() - Method in class org.infinispan.configuration.cache.SitesConfiguration
 
invalidate(Object[]) - Method in interface org.infinispan.persistence.manager.OrderedUpdatesManager
 
invalidate(Object[]) - Method in class org.infinispan.persistence.manager.OrderedUpdatesManagerImpl
 
InvalidateCommand - Class in org.infinispan.commands.write
Removes an entry from memory.
InvalidateCommand() - Constructor for class org.infinispan.commands.write.InvalidateCommand
 
InvalidateCommand(CacheNotifier, long, Collection<Object>, CommandInvocationId) - Constructor for class org.infinispan.commands.write.InvalidateCommand
 
InvalidateCommand(CacheNotifier, long, CommandInvocationId, 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(DataContainer, DistributionManager, CacheNotifier, long, Collection<Object>, CommandInvocationId) - Constructor for class org.infinispan.commands.write.InvalidateL1Command
 
InvalidateL1Command(DataContainer, DistributionManager, CacheNotifier, long, CommandInvocationId, Object...) - Constructor for class org.infinispan.commands.write.InvalidateL1Command
 
InvalidateL1Command(Address, DataContainer, DistributionManager, CacheNotifier, long, Collection<Object>, CommandInvocationId) - Constructor for class org.infinispan.commands.write.InvalidateL1Command
 
InvalidateVersionsCommand - Class in org.infinispan.commands.write
Must be VisitableCommand as we want to catch it in persistence handling etc.
InvalidateVersionsCommand() - Constructor for class org.infinispan.commands.write.InvalidateVersionsCommand
 
InvalidateVersionsCommand(ByteString) - Constructor for class org.infinispan.commands.write.InvalidateVersionsCommand
 
InvalidateVersionsCommand(ByteString, int, Object[], int[], long[], boolean) - Constructor for class org.infinispan.commands.write.InvalidateVersionsCommand
 
INVALIDATION - org.infinispan.configuration.parsing.ParsedCacheMode
 
INVALIDATION_ASYNC - org.infinispan.configuration.cache.CacheMode
Data invalidated asynchronously.
INVALIDATION_BATCH_SIZE - org.infinispan.configuration.parsing.Attribute
 
INVALIDATION_BATCH_SIZE - Static variable in class org.infinispan.configuration.cache.ClusteringConfiguration
 
INVALIDATION_CACHE - org.infinispan.configuration.parsing.Element
 
INVALIDATION_CACHE_CONFIGURATION - org.infinispan.configuration.parsing.Element
 
INVALIDATION_CLEANUP_TASK_FREQUENCY - org.infinispan.configuration.parsing.Attribute
 
INVALIDATION_SYNC - org.infinispan.configuration.cache.CacheMode
Data invalidated synchronously.
INVALIDATION_THRESHOLD - Static variable in class org.infinispan.configuration.cache.L1Configuration
 
invalidationBatchSize() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
For scattered cache, the threshold after which batched invalidations are sent
invalidationBatchSize(int) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
For scattered cache, the threshold after which batched invalidations are sent
invalidationBatchSizeAppliesOnNonScattered() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidationBatchSizeAppliesOnNonScattered() - Method in interface org.infinispan.util.logging.Log
 
invalidationBatchSizeAppliesOnNonScattered$str() - Method in class org.infinispan.util.logging.Log_$logger
 
InvalidationInterceptor - Class in org.infinispan.interceptors.impl
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.impl.InvalidationInterceptor
 
InvalidationLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.InvalidationLogic
 
invalidations - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
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.
invalidBinaryFormat(Object) - Method in class org.infinispan.util.logging.Log_$logger
 
invalidBinaryFormat(Object) - Method in interface org.infinispan.util.logging.Log
 
invalidBinaryFormat$str() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidCacheModeForTotalOrder(String) - Method in class org.infinispan.util.logging.Log_$logger
 
invalidCacheModeForTotalOrder(String) - Method in interface org.infinispan.util.logging.Log
 
invalidCacheModeForTotalOrder$str() - Method in class org.infinispan.util.logging.Log_$logger
 
InvalidCacheUsageException - Exception in org.infinispan
Thrown when client makes cache usage errors.
InvalidCacheUsageException(String) - Constructor for exception org.infinispan.InvalidCacheUsageException
 
InvalidCacheUsageException(String, Throwable) - Constructor for exception org.infinispan.InvalidCacheUsageException
 
InvalidCacheUsageException(Throwable) - Constructor for exception org.infinispan.InvalidCacheUsageException
 
invalidCompletedTxTimeout(long) - Method in class org.infinispan.util.logging.Log_$logger
 
invalidCompletedTxTimeout(long) - Method in interface org.infinispan.util.logging.Log
 
invalidCompletedTxTimeout$str() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidConfigurationIndexingWithInvalidation() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidConfigurationIndexingWithInvalidation() - Method in interface org.infinispan.util.logging.Log
 
invalidConfigurationIndexingWithInvalidation$str() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidConfigurationIndexingWithoutModule() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidConfigurationIndexingWithoutModule() - Method in interface org.infinispan.util.logging.Log
 
invalidConfigurationIndexingWithoutModule$str() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidEncodingClass(Class<?>, Class<?>) - Method in class org.infinispan.util.logging.Log_$logger
 
invalidEncodingClass(Class<?>, Class<?>) - Method in interface org.infinispan.util.logging.Log
 
invalidEncodingClass$str() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidEvictionSize() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidEvictionSize() - Method in interface org.infinispan.util.logging.Log
 
invalidEvictionSize$str() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidLockingModeForTotalOrder(LockingMode) - Method in class org.infinispan.util.logging.Log_$logger
 
invalidLockingModeForTotalOrder(LockingMode) - Method in interface org.infinispan.util.logging.Log
 
invalidLockingModeForTotalOrder$str() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidMessageType(int, Address) - Method in class org.infinispan.util.logging.Log_$logger
 
invalidMessageType(int, Address) - Method in interface org.infinispan.util.logging.Log
 
invalidMessageType$str() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidPermission(Permission) - Method in class org.infinispan.util.logging.Log_$logger
 
invalidPermission(Permission) - Method in interface org.infinispan.util.logging.Log
 
invalidPermission$str() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidPersistentState(String) - Method in class org.infinispan.util.logging.Log_$logger
 
invalidPersistentState(String) - Method in interface org.infinispan.util.logging.Log
 
invalidPersistentState$str() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidPrincipalRoleMapper() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidPrincipalRoleMapper() - Method in interface org.infinispan.util.logging.Log
 
invalidPrincipalRoleMapper$str() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidReaperWakeUpInterval(long) - Method in class org.infinispan.util.logging.Log_$logger
 
invalidReaperWakeUpInterval(long) - Method in interface org.infinispan.util.logging.Log
 
invalidReaperWakeUpInterval$str() - Method in class org.infinispan.util.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.
invalidRemoteTxReturnValue() - Method in class org.infinispan.commands.tx.CommitCommand
 
InvalidResponse - Class in org.infinispan.remoting.responses
An invalid response
InvalidResponse() - Constructor for class org.infinispan.remoting.responses.InvalidResponse
 
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(String) - Constructor for exception org.infinispan.transaction.xa.InvalidTransactionException
 
InvalidTransactionException(String, Throwable) - Constructor for exception org.infinispan.transaction.xa.InvalidTransactionException
 
InvalidTransactionException(Throwable) - Constructor for exception org.infinispan.transaction.xa.InvalidTransactionException
 
invalidTxModeForTotalOrder(TransactionMode) - Method in class org.infinispan.util.logging.Log_$logger
 
invalidTxModeForTotalOrder(TransactionMode) - Method in interface org.infinispan.util.logging.Log
 
invalidTxModeForTotalOrder$str() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidXSiteStateTransferTimeout() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidXSiteStateTransferTimeout() - Method in interface org.infinispan.util.logging.Log
 
invalidXSiteStateTransferTimeout$str() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidXSiteStateTransferWaitTime() - Method in class org.infinispan.util.logging.Log_$logger
 
invalidXSiteStateTransferWaitTime() - Method in interface org.infinispan.util.logging.Log
 
invalidXSiteStateTransferWaitTime$str() - Method in class org.infinispan.util.logging.Log_$logger
 
invocation - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
invocation - Variable in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
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
 
invocationBatchingCannotBeRecoverable() - Method in class org.infinispan.util.logging.Log_$logger
 
invocationBatchingCannotBeRecoverable() - Method in interface org.infinispan.util.logging.Log
 
invocationBatchingCannotBeRecoverable$str() - Method in class org.infinispan.util.logging.Log_$logger
 
InvocationBatchingConfiguration - Class in org.infinispan.configuration.cache
 
InvocationBatchingConfigurationBuilder - Class in org.infinispan.configuration.cache
 
invocationBatchingNeedsTransactionalCache() - Method in class org.infinispan.util.logging.Log_$logger
 
invocationBatchingNeedsTransactionalCache() - Method in interface org.infinispan.util.logging.Log
 
invocationBatchingNeedsTransactionalCache$str() - Method in class org.infinispan.util.logging.Log_$logger
 
invocationBatchingNotEnabled() - Method in class org.infinispan.util.logging.Log_$logger
 
invocationBatchingNotEnabled() - Method in interface org.infinispan.util.logging.Log
 
invocationBatchingNotEnabled$str() - Method in class org.infinispan.util.logging.Log_$logger
 
InvocationCallback - Interface in org.infinispan.interceptors
Base interface for all callbacks used by BaseAsyncInterceptor and InvocationStage methods.
InvocationContext - Interface in org.infinispan.context
A context that contains information pertaining to a given invocation.
InvocationContextContainer - Interface in org.infinispan.context
Deprecated.
Since 9.0, this interface is going to be moved to an internal package.
invocationContextFactory - Variable in class org.infinispan.cache.impl.CacheImpl
 
InvocationContextFactory - Interface in org.infinispan.context
Factory for InvocationContext objects.
InvocationContextInterceptor - Class in org.infinispan.interceptors.impl
 
InvocationContextInterceptor() - Constructor for class org.infinispan.interceptors.impl.InvocationContextInterceptor
 
InvocationExceptionFunction - Interface in org.infinispan.interceptors
InvocationFinallyAction - Interface in org.infinispan.interceptors
InvocationFinallyFunction - Interface in org.infinispan.interceptors
invocationHandler - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
InvocationStage - Class in org.infinispan.interceptors
A partial command invocation, either completed or in progress.
InvocationStage() - Constructor for class org.infinispan.interceptors.InvocationStage
 
InvocationSuccessAction - Interface in org.infinispan.interceptors
InvocationSuccessFunction - Interface in org.infinispan.interceptors
invoke() - Method in class org.infinispan.commands.remote.RenewBiasCommand
 
invoke() - Method in class org.infinispan.commands.remote.RevokeBiasCommand
 
invoke() - Method in interface org.infinispan.commands.ReplicableCommand
Invoke the command synchronously.
invoke(A) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.ListenerInvocationImpl
 
invoke(String, Object[], String[]) - Method in class org.infinispan.jmx.ResourceDMBean
 
invoke(InvocationContext, VisitableCommand) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Walks the command through the interceptor chain.
invoke(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
invoke(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.impl.AsyncInterceptorChainImpl
 
invoke(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.InterceptorChain
Deprecated.
Walks the command through the interceptor chain.
invoke(Event<K, V>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
invoke(Event<K, V>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.ClusteredListenerInvocation
 
invoke(Event<K, V>) - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
invoke(EventWrapper<K, V, CacheEntryEvent<K, V>>, boolean) - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
 
invoke(EventWrapper<K, V, CacheEntryEvent<K, V>>, boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
This is the entry point for local listeners firing events
invoke(EventWrapper<K, V, CacheEntryEvent<K, V>>, boolean) - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
invoke(T) - Method in interface org.infinispan.notifications.impl.ListenerInvocation
Invokes the event
invokeAll(Collection<? extends Callable<T>>) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
invokeAll(Collection<? extends Callable<T>>) - 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.LazyInitializingBlockingTaskAwareExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
invokeAll(BiFunction<Cache<K, V>, ? super CacheEntry<K, V>, R>) - Method in interface org.infinispan.LockedStream
Performs a BiFunction for each element of this stream on the primary owner of each entry returning a value.
invokeAll(BiFunction<Cache<K, V>, ? super CacheEntry<K, V>, R>) - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
invokeAll(BiFunction<Cache<K, V>, ? super CacheEntry<K, V>, R>) - Method in class org.infinispan.stream.impl.TxLockedStreamImpl
 
invokeAll(SerializableBiFunction<Cache<K, V>, ? super CacheEntry<K, V>, R>) - Method in interface org.infinispan.LockedStream
Same as LockedStream.invokeAll(BiFunction) except that the BiFunction must also implement Serializable
invokeAny(Collection<? extends Callable<T>>) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
invokeAny(Collection<? extends Callable<T>>) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - 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.distexec.DefaultExecutorService
Deprecated.
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
invokeAsync() - Method in class org.infinispan.commands.CancelCommand
 
invokeAsync() - Method in class org.infinispan.commands.control.LockControlCommand
 
invokeAsync() - Method in class org.infinispan.commands.CreateCacheCommand
 
invokeAsync() - Method in class org.infinispan.commands.read.DistributedExecuteCommand
Performs invocation of Callable and returns result
invokeAsync() - Method in class org.infinispan.commands.remote.ClusteredGetAllCommand
 
invokeAsync() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
Invokes a logical "get(key)" on a remote cache and returns results.
invokeAsync() - Method in class org.infinispan.commands.remote.expiration.RetrieveLastAccessCommand
 
invokeAsync() - Method in class org.infinispan.commands.remote.expiration.UpdateLastAccessCommand
 
invokeAsync() - Method in class org.infinispan.commands.remote.recovery.CompleteTransactionCommand
 
invokeAsync() - Method in class org.infinispan.commands.remote.recovery.GetInDoubtTxInfoCommand
 
invokeAsync() - Method in class org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
 
invokeAsync() - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
invokeAsync() - Method in class org.infinispan.commands.RemoveCacheCommand
Deprecated.
 
invokeAsync() - Method in interface org.infinispan.commands.ReplicableCommand
Invoke the command asynchronously.
invokeAsync() - Method in class org.infinispan.commands.triangle.BackupWriteCommand
 
invokeAsync() - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
invokeAsync() - Method in class org.infinispan.commands.tx.PrepareCommand
 
invokeAsync() - Method in class org.infinispan.commands.tx.RollbackCommand
 
invokeAsync() - Method in class org.infinispan.commands.write.InvalidateVersionsCommand
 
invokeAsync() - Method in class org.infinispan.manager.impl.ReplicableCommandManagerFunction
 
invokeAsync() - Method in class org.infinispan.manager.impl.ReplicableCommandRunnable
 
invokeAsync() - Method in class org.infinispan.statetransfer.StateRequestCommand
 
invokeAsync() - Method in class org.infinispan.statetransfer.StateResponseCommand
 
invokeAsync() - Method in class org.infinispan.stream.impl.StreamIteratorCloseCommand
 
invokeAsync() - Method in class org.infinispan.stream.impl.StreamIteratorNextCommand
 
invokeAsync() - Method in class org.infinispan.stream.impl.StreamIteratorRequestCommand
 
invokeAsync() - Method in class org.infinispan.stream.impl.StreamRequestCommand
 
invokeAsync() - Method in class org.infinispan.stream.impl.StreamResponseCommand
 
invokeAsync() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
invokeAsync() - Method in class org.infinispan.xsite.SingleXSiteRpcCommand
 
invokeAsync() - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
 
invokeAsync() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
 
invokeAsync() - Method in class org.infinispan.xsite.XSiteAdminCommand
 
invokeAsync(InvocationContext, VisitableCommand) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Walks the command through the interceptor chain.
invokeAsync(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
invokeAsync(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.impl.AsyncInterceptorChainImpl
 
invokeCommand(Collection<Address>, ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
invokeCommand(Collection<Address>, ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
invokeCommand(Collection<Address>, ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in interface org.infinispan.remoting.transport.Transport
Invoke a command on a collection of node and pass the responses to a ResponseCollector.
invokeCommand(Collection<Address>, ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in interface org.infinispan.remoting.rpc.RpcManager
Invoke a command on a collection of node and pass the responses to a ResponseCollector.
invokeCommand(Collection<Address>, ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeCommand(Address, ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
invokeCommand(Address, ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
invokeCommand(Address, ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in interface org.infinispan.remoting.transport.Transport
Invoke a command on a single node and pass the response to a ResponseCollector.
invokeCommand(Address, ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in interface org.infinispan.remoting.rpc.RpcManager
Invoke a command on a single node and pass the response to a ResponseCollector.
invokeCommand(Address, ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeCommandOnAll(Collection<Address>, ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
invokeCommandOnAll(Collection<Address>, ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in interface org.infinispan.remoting.transport.Transport
Invoke a command on all the nodes in the cluster and pass the responses to a ResponseCollector.
invokeCommandOnAll(ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
invokeCommandOnAll(ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
invokeCommandOnAll(ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in interface org.infinispan.remoting.transport.Transport
Invoke a command on all the nodes in the cluster and pass the responses to a ResponseCollector.
invokeCommandOnAll(ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in interface org.infinispan.remoting.rpc.RpcManager
Invoke a command on all the nodes in the cluster and pass the responses to a ResponseCollector.
invokeCommandOnAll(ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeCommands(Collection<Address>, Function<Address, ReplicableCommand>, ResponseCollector<T>, long, DeliverOrder) - Method in interface org.infinispan.remoting.transport.Transport
invokeCommands(Collection<Address>, Function<Address, ReplicableCommand>, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
invokeCommands(Collection<Address>, Function<Address, ReplicableCommand>, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
invokeCommands(Collection<Address>, Function<Address, ReplicableCommand>, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in interface org.infinispan.remoting.transport.Transport
Invoke different commands on a collection of nodes and pass the responses to a ResponseCollector.
invokeCommands(Collection<Address>, Function<Address, ReplicableCommand>, ResponseCollector<T>, RpcOptions) - Method in interface org.infinispan.remoting.rpc.RpcManager
Invoke different commands on a collection of nodes and pass the responses to a ResponseCollector.
invokeCommands(Collection<Address>, Function<Address, ReplicableCommand>, ResponseCollector<T>, RpcOptions) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeCommandStaggered(Collection<Address>, ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
invokeCommandStaggered(Collection<Address>, ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
invokeCommandStaggered(Collection<Address>, ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in interface org.infinispan.remoting.transport.Transport
Invoke a command on a collection of nodes and pass the responses to a ResponseCollector.
invokeCommandStaggered(Collection<Address>, ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in interface org.infinispan.remoting.rpc.RpcManager
Invoke a command on a collection of nodes and pass the responses to a ResponseCollector.
invokeCommandStaggered(Collection<Address>, ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeEach(InvocationContext, Iterator<VisitableCommand>, BaseAsyncInterceptor, Object) - Static method in class org.infinispan.interceptors.impl.MultiSubCommandInvoker
invokeNext(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
Invoke the next interceptor, possibly with a new command.
invokeNextAndExceptionally(InvocationContext, VisitableCommand, InvocationExceptionFunction) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
Invoke the next interceptor, possibly with a new command, and execute an InvocationCallback after all the interceptors have finished with an exception.
invokeNextAndFinally(InvocationContext, VisitableCommand, InvocationFinallyAction) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
Invoke the next interceptor, possibly with a new command, and execute an InvocationCallback after all the interceptors have finished, with or without an exception.
invokeNextAndHandle(InvocationContext, VisitableCommand, InvocationFinallyFunction) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
Invoke the next interceptor, possibly with a new command, and execute an InvocationCallback after all the interceptors have finished, with or without an exception.
invokeNextInterceptor(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.base.CommandInterceptor
Deprecated.
Invokes the next interceptor in the chain.
invokeNextThenAccept(InvocationContext, VisitableCommand, InvocationSuccessAction) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
Invoke the next interceptor, possibly with a new command, and execute an InvocationCallback after all the interceptors have finished successfully.
invokeNextThenApply(InvocationContext, VisitableCommand, InvocationSuccessFunction) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
Invoke the next interceptor, possibly with a new command, and execute an InvocationCallback after all the interceptors have finished successfully.
invokeNoChecks(EventWrapper<K, V, CacheEntryEvent<K, V>>, boolean, boolean, boolean) - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
 
invokeNoChecks(EventWrapper<K, V, CacheEntryEvent<K, V>>, boolean, boolean, boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
This is the entry point for remote listener events being fired
invokeNoChecks(EventWrapper<K, V, CacheEntryEvent<K, V>>, boolean, boolean, boolean) - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
invoker - Variable in class org.infinispan.cache.impl.CacheImpl
 
invoker - Variable in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) - Method in interface org.infinispan.remoting.transport.Transport
invokeRemotely(Collection<Address>, ReplicableCommand, RpcOptions) - Method in interface org.infinispan.remoting.rpc.RpcManager
invokeRemotely(Collection<Address>, ReplicableCommand, RpcOptions) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotely(Map<Address, ReplicableCommand>, ResponseMode, long, boolean, ResponseFilter, boolean, boolean) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
invokeRemotely(Map<Address, ReplicableCommand>, ResponseMode, long, boolean, ResponseFilter, boolean, boolean) - Method in interface org.infinispan.remoting.transport.Transport
invokeRemotely(Map<Address, ReplicableCommand>, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
invokeRemotely(Map<Address, ReplicableCommand>, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
Deprecated.
invokeRemotely(Map<Address, ReplicableCommand>, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) - Method in interface org.infinispan.remoting.transport.Transport
invokeRemotely(Map<Address, ReplicableCommand>, RpcOptions) - Method in interface org.infinispan.remoting.rpc.RpcManager
invokeRemotely(Map<Address, ReplicableCommand>, RpcOptions) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemotely(InvocationContext, DataWriteCommand, Address) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
invokeRemotelyAsync(Collection<Address>, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
invokeRemotelyAsync(Collection<Address>, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
invokeRemotelyAsync(Collection<Address>, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) - Method in interface org.infinispan.remoting.transport.Transport
 
invokeRemotelyAsync(Collection<Address>, ReplicableCommand, RpcOptions) - Method in interface org.infinispan.remoting.rpc.RpcManager
Invokes a command on remote nodes.
invokeRemotelyAsync(Collection<Address>, ReplicableCommand, RpcOptions) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
invokeRemoveExpiredCommand(InvocationContext, RemoveExpiredCommand, DistributionInfo) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
invokeRemoveExpiredCommand(InvocationContext, RemoveExpiredCommand, DistributionInfo) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
 
invokeXSite(Collection<XSiteBackup>, XSiteReplicateCommand) - Method in interface org.infinispan.remoting.rpc.RpcManager
Invokes the XSiteReplicateCommand to one or more remote sites.
invokeXSite(Collection<XSiteBackup>, XSiteReplicateCommand) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
is1PcForAutoCommitTransaction(LocalTransaction) - Method in class org.infinispan.transaction.impl.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 interface org.infinispan.remoting.rpc.ResponseFilter
Determines whether a response from a given sender should be added to the response list of the request
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.impl.DistributionManagerImpl
 
isAllCompleted() - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
isAllowed(Class<?>) - Static method in class org.infinispan.marshall.core.ExternallyMarshallable
 
isAllowed(Object) - Static method in class org.infinispan.marshall.core.ExternallyMarshallable
 
isAsyncBackup() - Method in class org.infinispan.configuration.cache.BackupConfiguration
 
isAsynchronous() - Method in enum org.infinispan.remoting.rpc.ResponseMode
 
isAvailable() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
isAvailable() - Method in interface org.infinispan.notifications.cachelistener.event.PersistenceAvailabilityChangedEvent
 
isAvailable() - Method in class org.infinispan.persistence.async.AsyncCacheWriter
 
isAvailable() - Method in class org.infinispan.persistence.file.SingleFileStore
 
isAvailable() - Method in interface org.infinispan.persistence.manager.PersistenceManager
 
isAvailable() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
isAvailable() - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
isAvailable() - Method in interface org.infinispan.persistence.spi.CacheLoader
 
isAvailable() - Method in interface org.infinispan.persistence.spi.CacheWriter
 
isAvailable() - Method in interface org.infinispan.persistence.spi.ExternalStore
 
isAvailable() - Method in interface org.infinispan.util.concurrent.locks.LockPromise
It tests if the lock is available.
isBackupFor(String, String) - Method in class org.infinispan.configuration.cache.BackupForConfiguration
 
isBatchingEnabled() - Method in enum org.infinispan.configuration.parsing.Parser.TransactionMode
 
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.
isCacheRebalancingEnabled(String) - Method in interface org.infinispan.topology.LocalTopologyManager
Checks whether rebalancing is enabled for the specified cache.
isCacheRebalancingEnabled(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
isCacheRebalancingEnabled(String) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
isCancelled() - Method in class org.infinispan.statetransfer.InboundTransferTask
 
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.ClearCacheEntry
 
isChanged() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
isChanged() - Method in class org.infinispan.container.entries.NullCacheEntry
 
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
 
isClustered() - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
 
isClustered() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
isClustered() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
isClustered() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
isClustered(GlobalConfiguration) - Static method in class org.infinispan.configuration.cache.Configurations
 
isCommandRetried() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
isCommandRetried() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryCreatedEvent
This will be true if the write command that caused this had to be retried again due to a topology change.
isCommandRetried() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryModifiedEvent
This will be true if the write command that caused this had to be retried again due to a topology change.
isCommandRetried() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryRemovedEvent
This will be true if the write command that caused this had to be retried again due to a topology change.
isCommandRetried() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
isCommandSentBeforeFirstTopology(int) - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
 
isCommit() - Method in enum org.infinispan.interceptors.locking.ClusteringDependentLogic.Commit
 
isCommitOrRollbackSent() - Method in class org.infinispan.transaction.impl.LocalTransaction
 
isCommitReceived() - Method in class org.infinispan.transaction.impl.TotalOrderRemoteTransactionState
check if the transaction is marked for commit (by the Commit Command)
isCommitted() - Method in interface org.infinispan.container.entries.MVCCEntry
 
isCommitted() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
isComplete() - Method in interface org.infinispan.stream.impl.IteratorResponse
Whether the iterator is the end or if more requests are needed
isComplete() - Method in class org.infinispan.stream.impl.IteratorResponses
 
isComplete(Object) - Method in interface org.infinispan.stream.impl.ClusterStreamManager
Tests whether this operation is still pending or not.
isComplete(Object) - Method in class org.infinispan.stream.impl.ClusterStreamManagerImpl
 
isComplete(Object) - Method in class org.infinispan.stream.impl.tx.TxClusterStreamManager
 
isCompletedSuccessfully() - Method in class org.infinispan.statetransfer.InboundTransferTask
 
isCompletionFailed() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareLocalTransaction
Returns true if this transaction failed during 2nd phase of 2PC(prepare or commit).
isComputeIfPresent() - Method in class org.infinispan.commands.write.ComputeCommand
 
isConditional() - Method in class org.infinispan.commands.functional.AbstractWriteManyCommand
 
isConditional() - Method in class org.infinispan.commands.functional.ReadWriteKeyCommand
 
isConditional() - Method in class org.infinispan.commands.functional.ReadWriteKeyValueCommand
 
isConditional() - Method in class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
isConditional() - Method in class org.infinispan.commands.functional.WriteOnlyKeyCommand
 
isConditional() - Method in class org.infinispan.commands.functional.WriteOnlyKeyValueCommand
 
isConditional() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
Deprecated.
 
isConditional() - Method in class org.infinispan.commands.write.ClearCommand
 
isConditional() - Method in class org.infinispan.commands.write.ComputeCommand
 
isConditional() - Method in class org.infinispan.commands.write.ComputeIfAbsentCommand
 
isConditional() - Method in class org.infinispan.commands.write.InvalidateCommand
 
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.RemoveExpiredCommand
 
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.
isConditional(WriteCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
isConflictResolutionInProgress() - Method in interface org.infinispan.conflict.ConflictManager
 
isConflictResolutionInProgress() - Method in class org.infinispan.conflict.impl.DefaultConflictManager
 
isConnected() - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
isConversionSupported(MediaType) - Method in class org.infinispan.encoding.DataConversion
 
isConversionSupported(MediaType, MediaType) - Method in interface org.infinispan.marshall.core.EncoderRegistry
 
isConversionSupported(MediaType, MediaType) - Method in class org.infinispan.marshall.core.EncoderRegistryImpl
 
isCoordinator() - Method in class org.infinispan.manager.DefaultCacheManager
isCoordinator() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
isCoordinator() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
isCoordinator() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
isCoordinator() - Method in class org.infinispan.remoting.transport.jgroups.ClusterView
 
isCoordinator() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
isCoordinator() - Method in interface org.infinispan.remoting.transport.Transport
 
isCreate() - Method in class org.infinispan.notifications.cachelistener.filter.EventType
 
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.ClearCacheEntry
 
isCreated() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
isCreated() - Method in class org.infinispan.container.entries.NullCacheEntry
 
isCreated() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
isCreated() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
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.impl.EventImpl
 
isCurrentState() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryEvent
 
isCurrentState() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
isDefaultRunning() - Method in class org.infinispan.manager.DefaultCacheManager
 
isDefaultRunning() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Tests whether the default cache is running.
isDefaultRunning() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
isDelete() - Method in class org.infinispan.functional.impl.StatsEnvelope
 
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.topology.ClusterCacheStatus
 
isDone() - Method in class org.infinispan.interceptors.impl.SimpleAsyncInvocationStage
 
isDone() - Method in class org.infinispan.interceptors.InvocationStage
 
isDone() - Method in class org.infinispan.interceptors.SyncInvocationStage
 
isEmbeddedMode(GlobalConfiguration) - Static method in class org.infinispan.configuration.cache.Configurations
 
isEmpty() - Method in class org.infinispan.atomic.impl.AtomicMapProxyImpl
 
isEmpty() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
isEmpty() - Method in class org.infinispan.cache.impl.CacheImpl
 
isEmpty() - Method in class org.infinispan.cache.impl.DecoratedCache
 
isEmpty() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySetBase
 
isEmpty() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
isEmpty() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.KeySet
 
isEmpty() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.Values
 
isEmpty() - Method in class org.infinispan.commands.read.AbstractCloseableIteratorCollection
 
isEmpty() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
isEmpty() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
Checks if the provided set is empty.
isEmpty() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
Checks if the provided map is empty.
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.security.impl.SecureCacheImpl
 
isEmpty() - Method in class org.infinispan.statetransfer.CommitManager
 
isEmpty() - Method in class org.infinispan.util.CollectionMapper
 
isEmpty() - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
 
isEmpty() - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
Deprecated.
 
isEnabled() - Method in class org.infinispan.configuration.cache.CompatibilityModeConfigurationBuilder
 
isEnabled() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
 
isEnabled() - Method in enum org.infinispan.configuration.cache.Index
Is indexing enabled?
isEnabled() - Method in enum org.infinispan.eviction.EvictionStrategy
Whether or not the cache will do something due to the strategy
isEnabled() - Method in class org.infinispan.eviction.impl.PassivationManagerImpl
 
isEnabled() - Method in class org.infinispan.eviction.impl.PassivationManagerStub
 
isEnabled() - Method in interface org.infinispan.eviction.PassivationManager
 
isEnabled() - Method in interface org.infinispan.expiration.ExpirationManager
 
isEnabled() - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
isEnabled() - Method in interface org.infinispan.persistence.manager.PersistenceManager
 
isEnabled() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
isEnabled() - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
isEnabled() - Method in class org.infinispan.xsite.OfflineStatus
 
isEncoded() - Method in interface org.infinispan.functional.FunctionalMap
Tells if the underlying cache is using encoding or not
isEncodingChanged() - Method in class org.infinispan.configuration.cache.ContentTypeConfiguration
 
isEnlisted() - Method in class org.infinispan.transaction.impl.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.ClearInvocationContext
 
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
Deprecated.
 
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.ClearCacheEntry
 
isEvicted() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
isEvicted() - Method in class org.infinispan.container.entries.NullCacheEntry
 
isEvicted() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
isEvictionEnabled() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
Returns whether remove eviction is in use
isExceptionBased() - Method in enum org.infinispan.eviction.EvictionStrategy
The cache will throw exceptions to prevent memory growth
isExceptionBasedEviction(Configuration) - Static method in class org.infinispan.configuration.cache.Configurations
 
isExceptionThrown() - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
isExpired() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
isExpired() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
isExpired() - Method in interface org.infinispan.container.entries.InternalCacheEntry
isExpired() - Method in interface org.infinispan.container.entries.InternalCacheValue
isExpired() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
isExpired() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
 
isExpired() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
isExpired() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
 
isExpired() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
isExpired() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue
 
isExpired() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
isExpired() - Method in class org.infinispan.container.entries.MortalCacheValue
 
isExpired() - Method in interface org.infinispan.container.entries.MVCCEntry
Returns whether this entry was marked as being expired or not
isExpired() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
isExpired() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
isExpired() - Method in class org.infinispan.container.entries.TransientCacheValue
 
isExpired() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
isExpired() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
isExpired() - Method in class org.infinispan.notifications.cachelistener.filter.EventType
 
isExpired(long) - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
isExpired(long) - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
isExpired(long) - Method in interface org.infinispan.container.entries.InternalCacheEntry
 
isExpired(long) - Method in interface org.infinispan.container.entries.InternalCacheValue
 
isExpired(long) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
isExpired(long) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
 
isExpired(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
isExpired(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
 
isExpired(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
isExpired(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue
 
isExpired(long) - Method in class org.infinispan.container.entries.MortalCacheEntry
 
isExpired(long) - Method in class org.infinispan.container.entries.MortalCacheValue
 
isExpired(long) - Method in class org.infinispan.container.entries.RemoteMetadata
 
isExpired(long) - Method in class org.infinispan.container.entries.TransientCacheEntry
 
isExpired(long) - Method in class org.infinispan.container.entries.TransientCacheValue
 
isExpired(long) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
isExpired(long) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
isExpired(long) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
Returns whether entry is expired or not.
isExpired(long) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
Returns whether entry is expired.
isExpired(long) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
 
isExpired(long) - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
 
isExpired(long) - Method in interface org.infinispan.metadata.InternalMetadata
 
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
 
isFetchEnabled - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
isFile() - Method in class org.infinispan.io.GridFile
 
isFile() - Method in class org.infinispan.io.GridFile.Metadata
 
isFilterOnStorageFormat() - Method in class org.infinispan.notifications.cachelistener.ListenerHolder
 
isFinished() - Method in class org.infinispan.transaction.impl.TotalOrderRemoteTransactionState
 
isForwarded() - Method in class org.infinispan.commands.functional.AbstractWriteManyCommand
 
isForwarded() - Method in class org.infinispan.commands.functional.ReadWriteManyCommand
 
isForwarded() - Method in class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
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.impl.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() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
isGlobalScope() - Method in class org.infinispan.factories.components.ComponentMetadata
 
isGroupOwner() - Method in class org.infinispan.commands.remote.GetKeysInGroupCommand
 
isHidden() - Method in class org.infinispan.io.GridFile
 
isHit() - Method in class org.infinispan.functional.impl.StatsEnvelope
 
isImplicitTransaction() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
isImplicitTransaction() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
isImplicitTransaction() - Method in interface org.infinispan.context.impl.TxInvocationContext
 
isImplicitTransaction() - Method in class org.infinispan.transaction.impl.LocalTransaction
 
isIncludeCurrentState() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
isInDoubt() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
A transaction is in doubt if it is prepared and and it is orphan.
isInternalCache(String) - Method in class org.infinispan.registry.impl.InternalCacheRegistryImpl
 
isInternalCache(String) - Method in interface org.infinispan.registry.InternalCacheRegistry
Returns whether the cache is internal, i.e.
isInTxScope() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
isInTxScope() - Method in class org.infinispan.context.impl.ClearInvocationContext
 
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
Deprecated.
 
isInvalidation() - Method in enum org.infinispan.configuration.cache.CacheMode
Returns true if the mode is invalidation, either sync or async.
isInvalidationMode - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
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.impl.DistributionManagerImpl
 
isJoinComplete() - Method in interface org.infinispan.statetransfer.StateTransferManager
 
isJoinComplete() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
isKeyEquals(Object) - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
Deprecated.
 
isKeyGeneratorThreadActive() - Method in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
 
isKeyGeneratorThreadAlive() - Method in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
 
isKeyLocalToNode(Address, Object) - Method in interface org.infinispan.distribution.ch.ConsistentHash
isKeyLocalToNode(Address, Object) - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
isKeyLocalToNode(Address, Object) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
isKeyLocalToNode(Address, Object) - Method in class org.infinispan.distribution.group.impl.PartitionerConsistentHash
 
isL1Enabled - Variable in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
isL1Entry() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
isL1Entry() - Method in interface org.infinispan.container.entries.InternalCacheEntry
 
isL1Entry() - Method in class org.infinispan.container.entries.L1InternalCacheEntry
 
isL1Entry() - Method in class org.infinispan.container.entries.metadata.L1MetadataInternalCacheEntry
 
isLastChunk() - Method in class org.infinispan.statetransfer.StateChunk
 
isLazy() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
 
isLoaded() - Method in interface org.infinispan.container.entries.CacheEntry
Deprecated.
since 8.1
isLoaded() - Method in interface org.infinispan.container.entries.MVCCEntry
 
isLoaded() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
isLocal() - Method in enum org.infinispan.distribution.DataLocality
 
isLocal() - Method in enum org.infinispan.interceptors.locking.ClusteringDependentLogic.Commit
 
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.impl.BaseRpcInterceptor
 
isLocalOnly() - Method in enum org.infinispan.configuration.cache.Index
Deprecated.
isLocatedLocally(String) - Method in class org.infinispan.distribution.impl.DistributionManagerImpl
 
isLocked() - Method in class org.infinispan.util.concurrent.locks.impl.InfinispanLock
It checks if the lock is acquired.
isLocked(Object) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
 
isLocked(Object) - Method in interface org.infinispan.util.concurrent.locks.impl.LockContainer
 
isLocked(Object) - Method in class org.infinispan.util.concurrent.locks.impl.PerKeyLockContainer
 
isLocked(Object) - Method in class org.infinispan.util.concurrent.locks.impl.StripedLockContainer
 
isLocked(Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Tests if the key is locked.
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.impl.AbstractCacheTransaction
 
isMarkedForRollback() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
isMarshallable(Object) - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
isMarshallableCandidate(Object) - Method in class org.infinispan.marshall.core.JBossMarshaller
 
IsMarshallableInterceptor - Class in org.infinispan.interceptors.impl
Interceptor to verify whether parameters passed into cache are marshallables or not.
IsMarshallableInterceptor() - Constructor for class org.infinispan.interceptors.impl.IsMarshallableInterceptor
 
isMaxIdle() - Method in class org.infinispan.commands.write.RemoveExpiredCommand
Whether this remove expired was fired because of max idle
isMediaTypeChanged() - Method in class org.infinispan.configuration.cache.ContentTypeConfiguration
 
isMergeView() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
isMergeView() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
 
isMinorityPartition(List<Address>, List<Address>) - Method in class org.infinispan.partitionhandling.impl.PreferConsistencyStrategy
 
isMiss() - Method in class org.infinispan.functional.impl.StatsEnvelope
 
isModified() - Method in class org.infinispan.notifications.cachelistener.filter.EventType
 
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
isNext(int, long, int) - Method in class org.infinispan.distribution.TriangleOrderManager
 
isNoNamespaceAttribute(XMLStreamReader, int) - Static method in class org.infinispan.configuration.parsing.ParseUtils
 
isNonExistent() - Method in class org.infinispan.commands.write.RemoveCommand
 
isNotificationAllowed(FlagAffectedCommand, List<CacheEntryListenerInvocation<K, V>>) - 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.ClearCacheEntry
 
isNull() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
isNull() - Method in class org.infinispan.container.entries.NullCacheEntry
 
isNull() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
isOffline() - Method in class org.infinispan.xsite.OfflineStatus
 
isOffline() - Method in class org.infinispan.xsite.status.AbstractMixedSiteStatus
 
isOffline() - Method in class org.infinispan.xsite.status.AbstractSiteStatusBuilder
 
isOffline() - Method in class org.infinispan.xsite.status.ContainerSiteStatusBuilder
 
isOffline() - Method in class org.infinispan.xsite.status.OfflineSiteStatus
 
isOffline() - Method in class org.infinispan.xsite.status.OnlineSiteStatus
 
isOffline() - Method in interface org.infinispan.xsite.status.SiteStatus
 
ISOLATION - org.infinispan.configuration.parsing.Attribute
 
ISOLATION_LEVEL - Static variable in class org.infinispan.configuration.cache.LockingConfiguration
 
isolationLevel() - Method in class org.infinispan.configuration.cache.LockingConfiguration
Cache isolation level.
isolationLevel() - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
 
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
 
isOnline() - Method in class org.infinispan.xsite.status.AbstractMixedSiteStatus
 
isOnline() - Method in class org.infinispan.xsite.status.AbstractSiteStatusBuilder
 
isOnline() - Method in class org.infinispan.xsite.status.ContainerSiteStatusBuilder
 
isOnline() - Method in class org.infinispan.xsite.status.OfflineSiteStatus
 
isOnline() - Method in class org.infinispan.xsite.status.OnlineSiteStatus
 
isOnline() - Method in interface org.infinispan.xsite.status.SiteStatus
 
isOnlyPrimary() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
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
 
isOperationAllowed(boolean, long) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
isOriginatorMissing(GlobalTransaction) - Method in class org.infinispan.transaction.impl.ClusteredTransactionOriginatorChecker
 
isOriginatorMissing(GlobalTransaction) - Method in interface org.infinispan.transaction.impl.TransactionOriginatorChecker
 
isOriginatorMissing(GlobalTransaction, Collection<Address>) - Method in class org.infinispan.transaction.impl.ClusteredTransactionOriginatorChecker
 
isOriginatorMissing(GlobalTransaction, Collection<Address>) - Method in interface org.infinispan.transaction.impl.TransactionOriginatorChecker
 
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
Deprecated.
 
isOriginLocal() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
isOriginLocal() - Method in class org.infinispan.notifications.cachelistener.event.impl.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.
isOwner(Object) - Method in interface org.infinispan.distribution.group.impl.GroupManager
Deprecated.
Since 9.0, please use DistributionManager.getCacheTopology() instead.
isOwner(Object) - Method in class org.infinispan.distribution.group.impl.GroupManagerImpl
 
isParallel() - Method in class org.infinispan.stream.impl.AbstractCacheStream
 
isParallel() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
isParallel() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
isParallel() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
isParallel() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
isParallel() - Method in class org.infinispan.stream.impl.local.AbstractLocalCacheStream
 
isParallel() - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
isParallel() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
isParameterNameSet(int) - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMethodMetadata
 
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 class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
isPre() - Method in interface org.infinispan.notifications.cachelistener.event.Event
 
isPre() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
isPreEvent() - Method in class org.infinispan.notifications.cachelistener.filter.EventType
 
isPreloaded() - Method in interface org.infinispan.persistence.manager.PersistenceManager
 
isPreloaded() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
isPreloaded() - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
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.impl.LocalTransaction
 
isPrimary() - Method in class org.infinispan.distribution.DistributionInfo
 
isPrimaryOwner() - Method in enum org.infinispan.configuration.cache.Index
 
isPrimaryOwner(Object) - Method in interface org.infinispan.distribution.group.impl.GroupManager
Deprecated.
Since 9.0, please use DistributionManager.getCacheTopology() instead.
isPrimaryOwner(Object) - Method in class org.infinispan.distribution.group.impl.GroupManagerImpl
 
isPrimaryOwner(ConsistentHash, Object) - Method in class org.infinispan.stream.impl.AbstractCacheStream
 
isPrivateCache(String) - Method in class org.infinispan.registry.impl.InternalCacheRegistryImpl
 
isPrivateCache(String) - Method in interface org.infinispan.registry.InternalCacheRegistry
Returns whether the cache is private, i.e.
isPrivileged() - Static method in class org.infinispan.security.Security
 
isProperWriter(InvocationContext, FlagAffectedCommand, Object) - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
isProperWriter(InvocationContext, FlagAffectedCommand, Object) - Method in class org.infinispan.interceptors.impl.DistCacheWriterInterceptor
 
isPutIfAbsent() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
isRead() - Method in interface org.infinispan.container.entries.MVCCEntry
Check is this entry as loaded from the cache (as opposed to generated by the application using write-only command), mostly for purposes of the write skew check.
isRead() - Method in class org.infinispan.container.entries.RepeatableReadEntry
 
isRead() - Method in interface org.infinispan.functional.impl.EntryViews.AccessLoggingReadWriteView
 
isReadOnly() - Method in class org.infinispan.transaction.impl.LocalTransaction
 
isReadOwner() - Method in class org.infinispan.distribution.DistributionInfo
 
isReadOwner(Object) - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
isReady() - Method in class org.infinispan.remoting.inboundhandler.action.CompositeAction
 
isReady() - Method in class org.infinispan.remoting.inboundhandler.action.DefaultReadyAction
 
isReady() - Method in interface org.infinispan.remoting.inboundhandler.action.ReadyAction
 
isReady() - Method in class org.infinispan.remoting.inboundhandler.DefaultTopologyRunnable
 
isReady() - Method in interface org.infinispan.util.concurrent.BlockingRunnable
 
isReady() - Method in interface org.infinispan.util.concurrent.locks.PendingLockPromise
 
isRebalance() - Method in enum org.infinispan.topology.CacheTopology.Phase
 
isRebalanceEnabled() - Method in class org.infinispan.topology.ClusterCacheStatus
 
isRebalanceInProgress() - Method in class org.infinispan.topology.ClusterCacheStatus
 
isRebalancingEnabled() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
isRebalancingEnabled() - Method in class org.infinispan.cache.impl.CacheImpl
 
isRebalancingEnabled() - Method in interface org.infinispan.topology.ClusterTopologyManager
 
isRebalancingEnabled() - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
isRebalancingEnabled() - Method in interface org.infinispan.topology.LocalTopologyManager
Checks whether rebalancing is enabled for the entire cluster.
isRebalancingEnabled() - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
isRebalancingEnabled() - Method in class org.infinispan.topology.ManagerStatusResponse
 
isRebalancingEnabled() - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
isRebalancingEnabled(String) - Method in interface org.infinispan.topology.ClusterTopologyManager
Returns whether rebalancing is enabled or disabled for this container.
isRebalancingEnabled(String) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
isRecoveryEnabled() - Method in enum org.infinispan.configuration.cache.TransactionMode
 
isRecoveryEnabled() - Method in enum org.infinispan.configuration.parsing.Parser.TransactionMode
 
isRegistered(Class<? extends Encoder>) - Method in interface org.infinispan.marshall.core.EncoderRegistry
 
isRegistered(Class<? extends Encoder>) - Method in class org.infinispan.marshall.core.EncoderRegistryImpl
 
isRehashInProgress() - Method in interface org.infinispan.distribution.DistributionManager
Tests whether a rehash is in progress
isRehashInProgress() - Method in class org.infinispan.distribution.impl.DistributionManagerImpl
Tests whether a rehash is in progress
isRemote() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
isRemovalBased() - Method in enum org.infinispan.eviction.EvictionStrategy
The cache will remove other entries to make room to limit memory growth
isRemove() - Method in class org.infinispan.notifications.cachelistener.filter.EventType
 
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.ClearCacheEntry
 
isRemoved() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
isRemoved() - Method in class org.infinispan.container.entries.NullCacheEntry
 
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 - Variable in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
isReplicated() - Method in enum org.infinispan.configuration.cache.CacheMode
 
isReplicated() - Method in interface org.infinispan.distribution.ch.ConsistentHash
 
isReplicated() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
isReplicated() - Method in class org.infinispan.distribution.group.impl.PartitionerConsistentHash
 
isRetriedCommand() - Method in class org.infinispan.commands.tx.PrepareCommand
 
isRetry() - Method in class org.infinispan.notifications.cachelistener.filter.EventType
 
isReturnEntries() - Method in class org.infinispan.commands.read.GetAllCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.CancelCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.CreateCacheCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.functional.ReadOnlyManyCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.functional.ReadWriteManyCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.functional.WriteOnlyManyCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.functional.WriteOnlyManyEntriesCommand
 
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.GetAllCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.remote.ClusteredGetAllCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.remote.expiration.RetrieveLastAccessCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.remote.expiration.UpdateLastAccessCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.remote.GetKeysInGroupCommand
 
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.RenewBiasCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.remote.RevokeBiasCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.RemoveCacheCommand
Deprecated.
 
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.triangle.BackupWriteCommand
 
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.BackupAckCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.write.BackupMultiKeyAckCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.write.ClearCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.write.ComputeCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.write.ComputeIfAbsentCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.write.ExceptionAckCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.write.InvalidateCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.write.InvalidateVersionsCommand
 
isReturnValueExpected() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
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.manager.impl.ReplicableCommandManagerFunction
 
isReturnValueExpected() - Method in class org.infinispan.manager.impl.ReplicableCommandRunnable
 
isReturnValueExpected() - Method in class org.infinispan.statetransfer.StateRequestCommand
 
isReturnValueExpected() - Method in class org.infinispan.statetransfer.StateResponseCommand
 
isReturnValueExpected() - Method in class org.infinispan.stream.impl.StreamIteratorCloseCommand
 
isReturnValueExpected() - Method in class org.infinispan.stream.impl.StreamIteratorNextCommand
 
isReturnValueExpected() - Method in class org.infinispan.stream.impl.StreamIteratorRequestCommand
 
isReturnValueExpected() - Method in class org.infinispan.stream.impl.StreamRequestCommand
 
isReturnValueExpected() - Method in class org.infinispan.stream.impl.StreamResponseCommand
 
isReturnValueExpected() - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
isReturnValueExpected() - Method in class org.infinispan.topology.HeartBeatCommand
 
isReturnValueExpected() - Method in class org.infinispan.xsite.SingleXSiteRpcCommand
 
isReturnValueExpected() - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
 
isReturnValueExpected() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
 
isReturnValueExpected() - Method in class org.infinispan.xsite.XSiteAdminCommand
 
isRollbackReceived() - Method in class org.infinispan.transaction.impl.TotalOrderRemoteTransactionState
check if the transaction is marked for rollback (by the Rollback Command)
isRunning() - Method in interface org.infinispan.factories.impl.ComponentRef
 
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.
isRunning(String) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
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
 
isScattered() - Method in enum org.infinispan.configuration.cache.CacheMode
 
isSegmentLocalToNode(Address, int) - Method in interface org.infinispan.distribution.ch.ConsistentHash
Check if a segment is local to a given member.
isSegmentLocalToNode(Address, int) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
 
isSegmentLocalToNode(Address, int) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
isSegmentLocalToNode(Address, int) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
 
isSegmentLocalToNode(Address, int) - Method in class org.infinispan.distribution.group.impl.PartitionerConsistentHash
 
isSegmentReadOwner(int) - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
isSegmentWriteOwner(int) - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
isServerMode() - Method in class org.infinispan.configuration.internal.PrivateGlobalConfiguration
 
isShutdown - Variable in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
isShutdown() - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
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
 
isSkip(Params) - Static method in enum org.infinispan.functional.Param.StatisticsMode
 
isStarted() - Method in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
 
isStarted() - Method in interface org.infinispan.affinity.KeyAffinityService
Checks weather or not the service is started.
isStateTransferInProgress() - Method in interface org.infinispan.conflict.ConflictManager
 
isStateTransferInProgress() - Method in class org.infinispan.conflict.impl.DefaultConflictManager
 
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.impl.TxInterceptor
 
isStatisticsEnabled() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
 
isStatisticsEnabled() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
isStatisticsEnabled() - Method in class org.infinispan.stats.impl.AbstractClusterStats
 
isStatisticsEnabled() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
isStatusOk() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferCollector
 
isStopped() - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader.TaskContext
Deprecated.
Verifies if the the TaskContext is marked as stopped.
isStopped() - Method in class org.infinispan.persistence.TaskContextImpl
 
isStopped() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
 
isStopped() - Method in class org.infinispan.remoting.transport.jgroups.ClusterView
 
isStopping() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
isStorageFormatFilterable() - Method in class org.infinispan.encoding.DataConversion
 
isStoreEnabled(FlagAffectedCommand) - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
isStoreEnabled(FlagAffectedCommand) - Method in class org.infinispan.interceptors.impl.PassivationWriterInterceptor
 
isStoreMetadata(Metadata, InternalCacheEntry) - Static method in class org.infinispan.container.impl.InternalEntryFactoryImpl
Indicates whether the entire metadata object needs to be stored or not.
isSuccessful() - Method in class org.infinispan.commands.functional.AbstractWriteKeyCommand
 
isSuccessful() - Method in class org.infinispan.commands.functional.AbstractWriteManyCommand
 
isSuccessful() - Method in class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
isSuccessful() - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
isSuccessful() - Method in interface org.infinispan.commands.ReplicableCommand
If true, a return value will be marshalled as a SuccessfulResponse, otherwise it will be marshalled as a UnsuccessfulResponse.
isSuccessful() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
Deprecated.
 
isSuccessful() - Method in class org.infinispan.commands.write.ClearCommand
 
isSuccessful() - Method in class org.infinispan.commands.write.ComputeCommand
 
isSuccessful() - Method in class org.infinispan.commands.write.ComputeIfAbsentCommand
 
isSuccessful() - Method in class org.infinispan.commands.write.InvalidateCommand
 
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
 
isSuccessfullyDone(Object) - Static method in class org.infinispan.interceptors.BaseAsyncInterceptor
 
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.WrappedByteArrayOrPrimitiveMapper
 
isSurvivesRestarts() - Method in class org.infinispan.factories.components.ComponentMetadata
 
isSuspectExceptionInChain(Throwable) - Static method in exception org.infinispan.remoting.transport.jgroups.SuspectException
 
isSuspendTxAfterInvocation() - Method in class org.infinispan.batch.BatchContainer
 
isSync() - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
 
isSync() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
isSync() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
isSync() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
isSync() - Method in class org.infinispan.xsite.XSiteBackup
 
isSynchronous() - Method in enum org.infinispan.configuration.cache.CacheMode
 
isSynchronous() - Method in enum org.infinispan.configuration.parsing.Parser.Mode
 
isSynchronous() - Method in enum org.infinispan.remoting.rpc.ResponseMode
 
isSynchronous(FlagAffectedCommand) - Method in class org.infinispan.interceptors.impl.BaseRpcInterceptor
 
isTemplate() - Method in class org.infinispan.configuration.cache.Configuration
 
isTerminated() - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
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
 
isTotalOrder - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
isTotalOrder() - Method in class org.infinispan.topology.CacheJoinInfo
 
isTotalOrder() - Method in class org.infinispan.topology.ClusterCacheStatus
 
isTotalOrder() - Method in enum org.infinispan.transaction.TransactionProtocol
 
isTotalOrderCache(String) - Method in interface org.infinispan.topology.LocalTopologyManager
Checks if the cache defined by cacheName is using total order.
isTotalOrderCache(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
isTotalOrderCache(String) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
isTraceEnabled() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
 
isTraceEnabled() - Method in class org.infinispan.remoting.inboundhandler.NonTotalOrderPerCacheInboundInvocationHandler
 
isTraceEnabled() - Method in class org.infinispan.remoting.inboundhandler.NonTotalOrderTxPerCacheInboundInvocationHandler
 
isTraceEnabled() - Method in class org.infinispan.remoting.inboundhandler.TotalOrderTxPerCacheInboundInvocationHandler
 
isTraceEnabled() - Method in class org.infinispan.remoting.inboundhandler.TrianglePerCacheInboundInvocationHandler
 
isTracking(Flag) - Method in class org.infinispan.statetransfer.CommitManager
 
isTransactional - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
isTransactional() - Method in enum org.infinispan.transaction.TransactionMode
 
isTransactionCompleted(GlobalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
 
isTransactionPartiallyCommitted(GlobalTransaction) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
isTransactionPartiallyCommitted(GlobalTransaction) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
It checks if the transaction resources (for example locks) can be released.
isTransactionPartiallyCommitted(GlobalTransaction) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
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.impl.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
 
isTxVersioned(Configuration) - Static method in class org.infinispan.configuration.cache.Configurations
 
isUncertain() - Method in enum org.infinispan.distribution.DataLocality
 
isUnlock() - Method in class org.infinispan.commands.control.LockControlCommand
 
isUseSetter() - Method in class org.infinispan.factories.components.JmxAttributeMetadata
 
isUseXaXid() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Deprecated.
 
isValid() - Method in interface org.infinispan.container.entries.CacheEntry
Deprecated.
since 9.2
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
 
isVersionActual(int, EntryVersion) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
isVersionActual(int, EntryVersion) - Method in interface org.infinispan.scattered.ScatteredVersionManager
 
isViewIdAtLeast(int) - Method in class org.infinispan.remoting.transport.jgroups.ClusterView
 
isWired() - Method in interface org.infinispan.factories.impl.ComponentRef
 
isWritable() - Method in class org.infinispan.factories.components.JmxAttributeMetadata
 
isWrite() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
isWriteBackup() - Method in class org.infinispan.distribution.DistributionInfo
 
isWriteOnly() - Method in class org.infinispan.commands.functional.WriteOnlyKeyCommand
 
isWriteOnly() - Method in class org.infinispan.commands.functional.WriteOnlyKeyValueCommand
 
isWriteOnly() - Method in class org.infinispan.commands.functional.WriteOnlyManyCommand
 
isWriteOnly() - Method in class org.infinispan.commands.functional.WriteOnlyManyEntriesCommand
 
isWriteOnly() - Method in interface org.infinispan.commands.write.WriteCommand
Indicates whether the command is write-only, meaning that it makes no attempt to read the previously associated value with key for which the command is directed.
isWriteOwner() - Method in class org.infinispan.distribution.DistributionInfo
 
isWriteOwner(Object) - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
isXAEnabled() - Method in enum org.infinispan.configuration.cache.TransactionMode
 
isXAEnabled() - Method in enum org.infinispan.configuration.parsing.Parser.TransactionMode
 
iter - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator
 
iterator() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntrySet
 
iterator() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySet
 
iterator() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.KeySet
 
iterator() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.Values
 
iterator() - Method in interface org.infinispan.CacheStream
iterator() - Method in class org.infinispan.commands.read.AbstractCloseableIteratorCollection
 
iterator() - Method in interface org.infinispan.container.DataContainer
iterator() - Method in class org.infinispan.container.impl.AbstractDelegatingDataContainer
 
iterator() - Method in class org.infinispan.container.impl.AbstractInternalDataContainer.Values
Deprecated.
 
iterator() - Method in class org.infinispan.container.impl.DefaultDataContainer
 
iterator() - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
iterator() - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
iterator() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
 
iterator() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareEntryCollection
 
iterator() - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingEntrySet
 
iterator() - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingKeySet
 
iterator() - Method in interface org.infinispan.LockedStream
This method is not supported when using a LockedStream
iterator() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
iterator() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
iterator() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
iterator() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
iterator() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
iterator() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
iterator() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
iterator() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
iterator() - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
iterator() - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
iterator() - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
iterator() - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
iterator() - Method in class org.infinispan.stream.impl.local.ValueCacheCollection
 
iterator() - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
iterator() - Method in class org.infinispan.stream.impl.PriorityMergingProcessor
 
iterator() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
iterator() - Method in class org.infinispan.util.AbstractDelegatingCloseableIteratorCollection
 
iterator() - Method in class org.infinispan.util.AbstractDelegatingCloseableIteratorSet
 
iterator() - Method in class org.infinispan.util.CacheCollectionMapper
Deprecated.
 
iterator() - Method in class org.infinispan.util.CacheSetMapper
 
iterator() - Method in class org.infinispan.util.CollectionMapper
 
iterator() - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
 
iterator() - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
Deprecated.
 
iterator() - Method in class org.infinispan.util.WriteableCacheCollectionMapper
 
iterator(IntSet) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
iterator(IntSet) - Method in class org.infinispan.container.impl.DefaultDataContainer
 
iterator(IntSet) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
iterator(IntSet) - Method in interface org.infinispan.container.impl.InternalDataContainer
Same as DataContainer.iterator() except that only entries that map to the provided segments are returned via the iterator.
iterator(IntSet) - Method in class org.infinispan.container.impl.InternalDataContainerAdapter
 
iterator(IntSet) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
iterator(Publisher<E>, int) - Static method in class org.infinispan.util.Closeables
Converts a Publisher to a CloseableIterator by utilizing items fetched into an array and refetched as they are consumed from the iterator.
IteratorAsSpliterator<T> - Class in org.infinispan.stream.impl.spliterators
A Spliterator using the provided iterator for supplying values.
IteratorAsSpliterator.Builder<T> - Class in org.infinispan.stream.impl.spliterators
 
IteratorHandler - Class in org.infinispan.stream.impl
Handler for storing iterators between invocations so that remote node can request data in chunks.
IteratorHandler() - Constructor for class org.infinispan.stream.impl.IteratorHandler
 
IteratorHandler.OnCloseIterator<E> - Interface in org.infinispan.stream.impl
A CloseableIterator that also allows callers to attach Runnable instances to it, so that when this iterator is closed, those Runnables are also invoked.
iteratorIncludingExpired() - Method in interface org.infinispan.container.DataContainer
Same as DataContainer.iterator() except that is also returns expired entries.
iteratorIncludingExpired() - Method in class org.infinispan.container.impl.AbstractDelegatingDataContainer
 
iteratorIncludingExpired() - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
iteratorIncludingExpired() - Method in class org.infinispan.container.impl.DefaultDataContainer
 
iteratorIncludingExpired() - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
iteratorIncludingExpired() - Method in class org.infinispan.container.impl.L1SegmentedDataContainer
 
iteratorIncludingExpired() - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
iteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
iteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
iteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.DefaultDataContainer
 
iteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
iteratorIncludingExpired(IntSet) - Method in interface org.infinispan.container.impl.InternalDataContainer
Same as DataContainer.iteratorIncludingExpired() except that only entries that map to the provided segments are returned via the iterator.
iteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.InternalDataContainerAdapter
 
iteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.L1SegmentedDataContainer
 
iteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
iteratorOperation - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
IteratorResponse<V> - Interface in org.infinispan.stream.impl
Iterator response returned when an iterator batch is sent back which contains the iterator, if any segments were suspected and if the iterator has returned all values (complete).
IteratorResponses - Class in org.infinispan.stream.impl
Response object used when an iterator is the response value and it is unknown if the iterator has enough entries for the given batch size.
IteratorResponses.IteratorResponsesExternalizer - Class in org.infinispan.stream.impl
This externalizer is a special breed that converts a given response into others, based on whether or not an iterator has completed or not.
IteratorResponsesExternalizer() - Constructor for class org.infinispan.stream.impl.IteratorResponses.IteratorResponsesExternalizer
 
iteratorsRunning - Variable in class org.infinispan.stream.impl.ClusterStreamManagerImpl
 

J

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(GlobalMarshaller, GlobalConfiguration) - Constructor for class org.infinispan.marshall.core.JBossMarshaller
 
JBossMBeanServerLookup - Class in org.infinispan.jmx
Deprecated.
since 9.4, use JBossMBeanServerLookup instead
JBossMBeanServerLookup() - Constructor for class org.infinispan.jmx.JBossMBeanServerLookup
Deprecated.
 
JBossStandaloneJTAManagerLookup - Class in org.infinispan.transaction.lookup
JTA standalone TM lookup (JBoss AS 7 and earlier, and WildFly 8, 9, and 10).
JBossStandaloneJTAManagerLookup() - Constructor for class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
 
JGROUPS - org.infinispan.configuration.parsing.Element
 
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
 
JGroupsAddressCache - Class in org.infinispan.remoting.transport.jgroups
Cache JGroupsAddress instances
JGroupsAddressCache() - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsAddressCache
 
JGroupsBackupResponse - Class in org.infinispan.remoting.transport.jgroups
 
JGroupsBackupResponse(Map<XSiteBackup, Future<ValidResponse>>, 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.
jgroupsConfigurationNotFound(String) - Method in class org.infinispan.util.logging.Log_$logger
 
jgroupsConfigurationNotFound(String) - Method in interface org.infinispan.util.logging.Log
 
jgroupsConfigurationNotFound$str() - Method in class org.infinispan.util.logging.Log_$logger
 
JGroupsTopologyAwareAddress - Class in org.infinispan.remoting.transport.jgroups
An encapsulation of a JGroups ExtendedUUID with a site id, a rack id, and a machine id.
JGroupsTopologyAwareAddress(ExtendedUUID) - 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() - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
JGroupsTransport(JChannel) - 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.
JMX - org.infinispan.configuration.parsing.Element
 
JMX_DOMAIN - org.infinispan.configuration.parsing.Attribute
 
JMX_DOMAIN - Static variable in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
JMX_STATISTICS - org.infinispan.configuration.parsing.Element
 
JmxAttributeMetadata - Class in org.infinispan.factories.components
Persistable and cacheable metadata for JMX attributes
JmxAttributeMetadata(Field) - Constructor for class org.infinispan.factories.components.JmxAttributeMetadata
 
JmxAttributeMetadata(Method) - Constructor for class org.infinispan.factories.components.JmxAttributeMetadata
 
jmxDomain(String) - Method in 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
 
jmxMBeanAlreadyRegistered(String, String) - Method in class org.infinispan.util.logging.Log_$logger
 
jmxMBeanAlreadyRegistered(String, String) - Method in interface org.infinispan.util.logging.Log
 
jmxMBeanAlreadyRegistered$str() - Method in class org.infinispan.util.logging.Log_$logger
 
JmxOperationMetadata - Class in org.infinispan.factories.components
Persistable and cacheable metadata for JMX operations
JmxOperationMetadata(Method) - Constructor for class org.infinispan.factories.components.JmxOperationMetadata
 
JmxOperationParameter - Class in org.infinispan.factories.components
JmxOperationParameter stores metadata information about MBean operation parameters which is then used at runtime to build the relevant MBeanParameterInfo
JmxOperationParameter(String, String, String) - Constructor for class org.infinispan.factories.components.JmxOperationParameter
 
jmxStatistics() - Method in class org.infinispan.configuration.cache.Configuration
 
jmxStatistics() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
jmxStatistics() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
JMXStatisticsConfiguration - Class in org.infinispan.configuration.cache
Determines whether statistics are gather and reported.
JMXStatisticsConfigurationBuilder - Class in org.infinispan.configuration.cache
Determines whether statistics are gather and reported.
JmxStatisticsExposer - Interface in org.infinispan.jmx
Interface containing common cache management operations
JmxStatsCommandInterceptor - Class in org.infinispan.interceptors.impl
Base class for all the interceptors exposing management statistics.
JmxStatsCommandInterceptor() - Constructor for class org.infinispan.interceptors.impl.JmxStatsCommandInterceptor
 
JNDI_NAME - org.infinispan.configuration.parsing.Attribute
 
join(String, CacheJoinInfo, CacheTopologyHandler, PartitionHandlingManager) - Method in interface org.infinispan.topology.LocalTopologyManager
Forwards the join request to the coordinator.
join(String, CacheJoinInfo, CacheTopologyHandler, PartitionHandlingManager) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
join(String, CacheJoinInfo, CacheTopologyHandler, PartitionHandlingManager) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
JOIN - org.infinispan.topology.CacheTopologyControlCommand.Type
 

K

KEEP_ALIVE_TIME - org.infinispan.configuration.parsing.Attribute
 
keepingDegradedModeAfterMergeDataLost(Collection<Address>, Collection<Address>, Collection<Address>) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
keepingDegradedModeAfterMergeDataLost(Collection<Address>, Collection<Address>, Collection<Address>) - Method in interface org.infinispan.util.logging.events.Messages
 
keepingDegradedModeAfterMergeDataLost$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
keepingDegradedModeAfterMergeMinorityPartition(Collection<Address>, Collection<Address>, Collection<Address>) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
keepingDegradedModeAfterMergeMinorityPartition(Collection<Address>, Collection<Address>, Collection<Address>) - Method in interface org.infinispan.util.logging.events.Messages
 
keepingDegradedModeAfterMergeMinorityPartition$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
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.ReadCommittedEntry
 
key - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl.KeyAndVersion
 
key() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
 
key() - Method in interface org.infinispan.functional.EntryView.ReadEntryView
Key of the read-only entry view.
key() - Method in interface org.infinispan.functional.EntryView.WriteEntryView
Key of the write-only entry view.
key() - Method in class org.infinispan.xsite.statetransfer.XSiteState
 
KEY_DATA_TYPE - org.infinispan.configuration.parsing.Element
 
KEY_EQUIVALENCE - org.infinispan.configuration.parsing.Attribute
 
KEY_PARTITIONER - org.infinispan.configuration.parsing.Attribute
 
KEY_PARTITIONER - Static variable in class org.infinispan.configuration.cache.HashConfiguration
 
KEY_TRANSFER - org.infinispan.scattered.ScatteredVersionManager.SegmentState
 
Key2StringMapper - Interface in org.infinispan.persistence.keymappers
Defines the logic of mapping a key object to a String.
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.impl
Implementation of KeyAffinityService.
KeyAffinityServiceImpl<K> - Class in org.infinispan.affinity
Deprecated.
Extend from KeyAffinityServiceImpl instead. This class will be removed in the future.
KeyAffinityServiceImpl(Executor, Cache<? extends K, ?>, KeyGenerator<? extends K>, int, Collection<Address>, boolean) - Constructor for class org.infinispan.affinity.impl.KeyAffinityServiceImpl
 
KeyAffinityServiceImpl(Executor, Cache<? extends K, ?>, KeyGenerator<? extends K>, int, Collection<Address>, boolean) - Constructor for class org.infinispan.affinity.KeyAffinityServiceImpl
Deprecated.
 
keyAllowed(Object) - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
 
KeyAndVersion(Object, EntryVersion) - Constructor for class org.infinispan.scattered.impl.ScatteredStateConsumerImpl.KeyAndVersion
 
KeyAwareLockListener - Interface in org.infinispan.util.concurrent.locks
A listener for KeyAwareLockPromise.
KeyAwareLockPromise - Interface in org.infinispan.util.concurrent.locks
An extension of LockPromise that contains a key associated to the lock.
keyDataConversion - Variable in class org.infinispan.commands.functional.ReadOnlyKeyCommand
 
keyDataConversion - Variable in class org.infinispan.commands.functional.ReadOnlyManyCommand
 
keyDataConversion() - Method in interface org.infinispan.commands.functional.Mutation
 
keyDataType() - Method in class org.infinispan.configuration.cache.EncodingConfiguration
 
keyEquivalence() - Method in class org.infinispan.configuration.cache.DataContainerConfiguration
Deprecated.
Equivalence is no longer used. This will be removed in the future. Only returns AnyEquivalence
keyEquivalence(Equivalence<K>) - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
Deprecated.
Equivalence is to be removed (byte[] are directly supported)
KeyFilter<K> - Interface in org.infinispan.filter
Deprecated.
since 9.3 This will be replaced by Predicate in the future
KeyFilterAsCacheEventFilter<K> - Class in org.infinispan.notifications.cachelistener.filter
CacheEventFilter that implements it's filtering solely on the use of the provided KeyFilter
KeyFilterAsCacheEventFilter(KeyFilter<? super K>) - Constructor for class org.infinispan.notifications.cachelistener.filter.KeyFilterAsCacheEventFilter
 
KeyFilterAsCacheEventFilter.Externalizer - Class in org.infinispan.notifications.cachelistener.filter
 
KeyFilterAsKeyValueFilter<K,​V> - Class in org.infinispan.filter
KeyValueFilter that implements it's filtering solely on the use of the provided KeyFilter
KeyFilterAsKeyValueFilter(KeyFilter<? super K>) - Constructor for class org.infinispan.filter.KeyFilterAsKeyValueFilter
 
KeyFilterAsKeyValueFilter.Externalizer - Class in org.infinispan.filter
 
keyFilterMapper - Variable in class org.infinispan.util.CacheCollectionMapper
Deprecated.
 
keyFilterMapper - Variable in class org.infinispan.util.WriteableCacheCollectionMapper
 
keyFromStorage(Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
KeyGenerator<K> - Interface in org.infinispan.affinity
Used for generating keys; used by KeyAffinityService to generate the affinity keys.
keyInvalidationListener - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
KeyListener(Object, GroupManager, InternalEntryFactory) - Constructor for class org.infinispan.interceptors.impl.GroupingInterceptor.KeyListener
 
keyMigrationFailed(String, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
keyMigrationFailed(String, Throwable) - Method in interface org.infinispan.util.logging.Log
 
keyMigrationFailed$str() - Method in class org.infinispan.util.logging.Log_$logger
 
keyPartitioner - Variable in class org.infinispan.cache.impl.CacheImpl
 
keyPartitioner - Variable in class org.infinispan.container.impl.AbstractInternalDataContainer
 
keyPartitioner - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
keyPartitioner - Variable in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
keyPartitioner - Variable in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
keyPartitioner - Variable in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
keyPartitioner - Variable in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
keyPartitioner - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
keyPartitioner - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
keyPartitioner - Variable in class org.infinispan.statetransfer.StateProviderImpl
 
keyPartitioner - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
keyPartitioner() - Method in class org.infinispan.configuration.cache.HashConfiguration
 
keyPartitioner(KeyPartitioner) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
Key partitioner, controlling the mapping of keys to hash segments.
KeyPartitioner - Interface in org.infinispan.distribution.ch
Map keys to segments.
KeyPartitionerFactory - Class in org.infinispan.distribution.ch.impl
Key partitioner factory that uses the hash function defined in the configuration.
KeyPartitionerFactory() - Constructor for class org.infinispan.distribution.ch.impl.KeyPartitionerFactory
 
keyRead(Object) - Method in class org.infinispan.transaction.impl.LocalTransaction
 
keyRead(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
Deprecated.
since 9.1 Use MVCCEntry.isRead() instead
keys - Variable in class org.infinispan.commands.functional.ReadOnlyManyCommand
 
keys - Variable in class org.infinispan.commands.write.InvalidateCommand
 
keys() - Method in interface org.infinispan.functional.FunctionalMap.ReadOnlyMap
Provides a Traversable that allows clients to navigate all cached keys.
keys() - Method in class org.infinispan.functional.impl.ReadOnlyMapImpl
 
keys(C) - Method in interface org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadManyCommandHelper
 
keys(ReadOnlyManyCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadOnlyManyHelper
 
keySet - Variable in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingKeySet
 
keySet() - Method in class org.infinispan.atomic.impl.AtomicMapProxyImpl
 
keySet() - Method in class org.infinispan.atomic.impl.FineGrainedAtomicMapProxyImpl
 
keySet() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
keySet() - Method in class org.infinispan.cache.impl.CacheImpl
 
keySet() - Method in class org.infinispan.cache.impl.DecoratedCache
 
keySet() - Method in class org.infinispan.cache.impl.EncoderCache
 
keySet() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
keySet() - Method in interface org.infinispan.Cache
Returns a set view of the keys contained in this cache and cache loader across the entire cluster.
keySet() - Method in interface org.infinispan.container.DataContainer
Deprecated.
Please use iterator method if bulk operations are required.
keySet() - Method in class org.infinispan.container.impl.AbstractDelegatingDataContainer
 
keySet() - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
keySet() - Method in class org.infinispan.container.impl.DefaultDataContainer
 
keySet() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
keySet() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
 
keySet() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
KeySet() - Constructor for class org.infinispan.cache.impl.SimpleCacheImpl.KeySet
 
KeySetCommand<K,​V> - Class in org.infinispan.commands.read
Command implementation for Map.keySet() functionality.
KeySetCommand(Cache<K, V>, InternalDataContainer<K, V>, KeyPartitioner, long) - Constructor for class org.infinispan.commands.read.KeySetCommand
 
keysToExecutionNodes(DistributedTaskExecutionPolicy, K...) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
keysToFilter - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
keysToFilter - Variable in class org.infinispan.stream.impl.local.AbstractLocalCacheStream
 
KeyStreamSupplier<K,​V> - Class in org.infinispan.stream.impl.local
Stream supplier that is to be used when the underlying stream is composed by key instances.
KeyStreamSupplier(Cache<K, V>, ToIntFunction<Object>, Supplier<Stream<K>>) - Constructor for class org.infinispan.stream.impl.local.KeyStreamSupplier
 
keyToEntryFunction() - Static method in class org.infinispan.stream.StreamMarshalling
Provides a function that given a key will return the CacheEntry that maps to this key.
keyToStorage(Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
KeyTrackingTerminalOperation<Original,​K,​R> - Interface in org.infinispan.stream.impl
A terminal operation for a CacheStream that allows tracking keys during a rehash event.
KeyTrackingTerminalOperation.IntermediateCollector<C> - Interface in org.infinispan.stream.impl
Collector used to collect items from intermediate responses of operations
KeyValueFilter<K,​V> - Interface in org.infinispan.filter
A filter for keys with their values.
KeyValueFilterAsCacheEventFilter<K,​V> - Class in org.infinispan.notifications.cachelistener.filter
CacheEventFilter that implements it's filtering solely on the use of the provided KeyValueFilter
KeyValueFilterAsCacheEventFilter(KeyValueFilter<? super K, ? super V>) - Constructor for class org.infinispan.notifications.cachelistener.filter.KeyValueFilterAsCacheEventFilter
 
KeyValueFilterAsCacheEventFilter.Externalizer - Class in org.infinispan.notifications.cachelistener.filter
 
KeyValueFilterAsKeyFilter<K> - Class in org.infinispan.filter
This is a KeyFilter that utilizes the given KeyValueFilter to determine if to filter the key.
KeyValueFilterAsKeyFilter(KeyValueFilter<? super K, ?>) - Constructor for class org.infinispan.filter.KeyValueFilterAsKeyFilter
 
KeyValueFilterAsKeyFilter.Externalizer - Class in org.infinispan.filter
 
KeyValueFilterConverter<K,​V,​C> - Interface in org.infinispan.filter
This interface is an optimization that can be used when a filter and converter are most efficiently used as the same object composing the filtering and conversion in the same method invocation.
KeyValueFilterConverterAsCacheEventFilterConverter<K,​V,​C> - Class in org.infinispan.notifications.cachelistener.filter
CacheEventFilterConverter that uses an underlying KeyValueFilterConverter to do the conversion and filtering.
KeyValueFilterConverterAsCacheEventFilterConverter(KeyValueFilterConverter<K, V, C>) - Constructor for class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter
 
KeyValueFilterConverterAsCacheEventFilterConverter.Externalizer - Class in org.infinispan.notifications.cachelistener.filter
 
KeyValueFilterConverterFactory<K,​V,​C> - Interface in org.infinispan.filter
Factory for KeyValueFilterConverter instances
KeyValueMetadataSizeCalculator<K,​V> - Interface in org.infinispan.container.impl
Size calculator that takes into account not only key and value but also metadata.
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
 
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.
L1 - org.infinispan.configuration.parsing.Element
 
L1_LIFESPAN - org.infinispan.configuration.parsing.Attribute
 
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.
L1InternalCacheEntry - Class in org.infinispan.container.entries
A InternalCacheEntry implementation to store a L1 entry.
L1InternalCacheEntry(Object, Object, long, long) - Constructor for class org.infinispan.container.entries.L1InternalCacheEntry
 
l1InvalidLifespan() - Method in class org.infinispan.util.logging.Log_$logger
 
l1InvalidLifespan() - Method in interface org.infinispan.util.logging.Log
 
l1InvalidLifespan$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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 - Variable in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
L1Manager - Interface in org.infinispan.distribution
Manages the L1 Cache, in particular recording anyone who is going to cache an a command that a node responds to so that a unicast invalidation can be sent later if needed.
L1ManagerImpl - Class in org.infinispan.distribution.impl
 
L1ManagerImpl() - Constructor for class org.infinispan.distribution.impl.L1ManagerImpl
 
L1Metadata - Class in org.infinispan.metadata.impl
Metadata implementation that must be passed to the DataContainer.put(Object, Object, org.infinispan.metadata.Metadata) when the entry to store is a L1 entry.
L1Metadata(Metadata) - Constructor for class org.infinispan.metadata.impl.L1Metadata
 
L1MetadataInternalCacheEntry - Class in org.infinispan.container.entries.metadata
A InternalCacheEntry implementation to store a L1 entry.
L1MetadataInternalCacheEntry(Object, Object, Metadata, long) - Constructor for class org.infinispan.container.entries.metadata.L1MetadataInternalCacheEntry
 
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
 
l1OnlyForDistributedCache(String) - Method in class org.infinispan.util.logging.Log_$logger
 
l1OnlyForDistributedCache(String) - Method in interface org.infinispan.util.logging.Log
 
l1OnlyForDistributedCache$str() - Method in class org.infinispan.util.logging.Log_$logger
 
L1SegmentedDataContainer<K,​V> - Class in org.infinispan.container.impl
Segmented data container that also allows for non owned segments to be written to a temporary map (L1).
L1SegmentedDataContainer(Supplier<ConcurrentMap<K, InternalCacheEntry<K, V>>>, int) - Constructor for class org.infinispan.container.impl.L1SegmentedDataContainer
 
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(InternalDataContainer, long, StateTransferLock, ClusteringDependentLogic) - Constructor for class org.infinispan.interceptors.distribution.L1WriteSynchronizer
 
LambdaWithMetasExternalizer() - Constructor for class org.infinispan.marshall.core.MarshallableFunctionExternalizers.LambdaWithMetasExternalizer
 
last() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
LAST - org.infinispan.configuration.cache.InterceptorConfiguration.Position
Specifies that the new interceptor is placed last in the chain.
lastAddress - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
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.ReadCommittedEntry
 
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 class org.infinispan.container.entries.RemoteMetadata
 
lastUsed() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
 
lastUsed() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
 
lastUsed() - Method in interface org.infinispan.metadata.InternalMetadata
 
LazyConcatIterator<E> - Class in org.infinispan.util
Iterator implementation that will return all entries from the first iterator.
LazyConcatIterator(CloseableIterator<E>, Supplier<? extends CloseableIterator<E>>) - Constructor for class org.infinispan.util.LazyConcatIterator
 
LazyInitializingBlockingTaskAwareExecutorService - Class in org.infinispan.executors
A delegating executor that lazily constructs and initializes the underlying executor.
LazyInitializingBlockingTaskAwareExecutorService(ThreadPoolExecutorFactory<ExecutorService>, ThreadFactory, TimeService, String) - 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(ThreadPoolExecutorFactory<ExecutorService>, ThreadFactory) - Constructor for class org.infinispan.executors.LazyInitializingExecutorService
 
LazyInitializingScheduledExecutorService - Class in org.infinispan.executors
A delegating scheduled executor that lazily constructs and initializes the underlying scheduled executor, since unused JDK executors are expensive.
LazyInitializingScheduledExecutorService(ThreadPoolExecutorFactory<ScheduledExecutorService>, ThreadFactory) - Constructor for class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
leave(String) - Method in interface org.infinispan.topology.LocalTopologyManager
Forwards the leave request to the coordinator.
leave(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
leave(String) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
LEAVE - org.infinispan.topology.CacheTopologyControlCommand.Type
 
length() - Method in class org.infinispan.io.GridFile
 
Lifecycle - Interface in org.infinispan.lifecycle
Deprecated.
use Lifecycle instead
LIFECYCLE - org.infinispan.security.AuthorizationPermission
Allows control of a cache's lifecycle (i.e.
LIFECYCLE - org.infinispan.util.logging.events.EventLogCategory
 
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() - 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() - Method in class org.infinispan.configuration.cache.L1Configuration
Maximum lifespan of an entry placed in the L1 cache.
lifespan() - Method in class org.infinispan.container.entries.RemoteMetadata
 
lifespan() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
 
lifespan() - Method in class org.infinispan.metadata.EmbeddedMetadata
 
lifespan() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
 
lifespan() - Method in class org.infinispan.metadata.impl.L1Metadata
 
lifespan() - Method in interface org.infinispan.metadata.Metadata
Returns the lifespan of the cache entry with which this metadata object is associated, 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) - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
Maximum lifespan of an entry placed in the L1 cache.
lifespan(long) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata.Builder
 
lifespan(long) - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
lifespan(long) - Method in interface org.infinispan.metadata.Metadata.Builder
Set lifespan time assuming that the time unit is 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(long, TimeUnit) - 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.functional.impl.MetaParamsInternalMetadata.Builder
 
lifespan(long, TimeUnit) - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
lifespan(long, TimeUnit) - Method in interface org.infinispan.metadata.Metadata.Builder
Set lifespan time with a given time unit.
LIFESPAN - org.infinispan.configuration.parsing.Attribute
 
LIFESPAN - Static variable in class org.infinispan.configuration.cache.ExpirationConfiguration
 
LIFESPAN - Static variable in class org.infinispan.configuration.cache.L1Configuration
 
LifespanExternalizer() - Constructor for class org.infinispan.marshall.exts.MetaParamExternalizers.LifespanExternalizer
 
lifespanUnit - Variable in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
limit(long) - Method in interface org.infinispan.CacheStream
limit(long) - Method in interface org.infinispan.DoubleCacheStream
limit(long) - Method in interface org.infinispan.IntCacheStream
limit(long) - Method in interface org.infinispan.LongCacheStream
limit(long) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
limit(long) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
limit(long) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
limit(long) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
limit(long) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
limit(long) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
limit(long) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
limit(long) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
limit(long) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
limit(long) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
limit(long) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
limit(long) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
limit(long) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
LimitDoubleOperation - Class in org.infinispan.stream.impl.intops.primitive.d
Performs limit operation on a DoubleStream
LimitDoubleOperation(long) - Constructor for class org.infinispan.stream.impl.intops.primitive.d.LimitDoubleOperation
 
LimitedExecutor - Class in org.infinispan.executors
Executes tasks in the given executor, but never has more than maxConcurrentTasks tasks running at the same time.
LimitedExecutor(String, Executor, int) - Constructor for class org.infinispan.executors.LimitedExecutor
 
LimitIntOperation - Class in org.infinispan.stream.impl.intops.primitive.i
Performs limit operation on a IntStream
LimitIntOperation(long) - Constructor for class org.infinispan.stream.impl.intops.primitive.i.LimitIntOperation
 
LimitLongOperation - Class in org.infinispan.stream.impl.intops.primitive.l
Performs limit operation on a LongStream
LimitLongOperation(long) - Constructor for class org.infinispan.stream.impl.intops.primitive.l.LimitLongOperation
 
LimitOperation<S> - Class in org.infinispan.stream.impl.intops.object
Performs limit operation on a regular Stream
LimitOperation(long) - Constructor for class org.infinispan.stream.impl.intops.object.LimitOperation
 
LIRS - org.infinispan.eviction.EvictionStrategy
Deprecated.
list() - Method in class org.infinispan.io.GridFile
 
list(FilenameFilter) - Method in class org.infinispan.io.GridFile
 
list(String) - Method in class org.infinispan.security.impl.ClusterRoleMapper
 
LIST - org.infinispan.persistence.modifications.Modification.Type
 
listAll() - Method in class org.infinispan.security.impl.ClusterRoleMapper
 
LISTEN - org.infinispan.security.AuthorizationPermission
Allows attaching listeners to a cache
Listenable - Interface in org.infinispan.notifications
Interface that denotes that the implementation can have listeners attached to it.
listener - Variable in class org.infinispan.stream.impl.PartitionAwareClusterStreamManager
 
Listener - Annotation Type in org.infinispan.notifications
Class-level annotation used to annotate an object as being a valid cache listener.
LISTENER_EXECUTOR - org.infinispan.configuration.parsing.Attribute
 
Listener.Observation - Enum in org.infinispan.notifications
Enumeration that defines when a listener event can be observed.
ListenerHolder - Class in org.infinispan.notifications.cachelistener
 
ListenerHolder(Object, DataConversion, DataConversion, boolean) - Constructor for class org.infinispan.notifications.cachelistener.ListenerHolder
 
ListenerInvocation<T> - Interface in org.infinispan.notifications.impl
Defines simple listener invocation.
ListenerInvocationImpl(Object, Method, boolean, ClassLoader, Subject) - Constructor for class org.infinispan.notifications.impl.AbstractListenerImpl.ListenerInvocationImpl
 
ListenerRegistration - Class in org.infinispan.affinity
Used for registering various cache notifications.
ListenerRegistration(KeyAffinityServiceImpl<?>) - Constructor for class org.infinispan.affinity.ListenerRegistration
 
listeners - Variable in class org.infinispan.container.impl.AbstractInternalDataContainer
 
listeners - Variable in class org.infinispan.container.impl.InternalDataContainerAdapter
 
listeners() - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
Allows to read-write listeners to be registered.
listeners() - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Allows to write-only listeners to be registered.
listeners() - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
 
listeners() - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
Listeners - Class in org.infinispan.functional
Holder class for functional listener definitions.
Listeners.ReadWriteListeners<K,​V> - Interface in org.infinispan.functional
Read-write listeners enable users to register listeners for cache entry created, modified and removed events, and also register listeners for any cache entry write events.
Listeners.ReadWriteListeners.ReadWriteListener<K,​V> - Interface in org.infinispan.functional
Read-write listener
Listeners.WriteListeners<K,​V> - Interface in org.infinispan.functional
Write listeners enable user to register listeners for any cache entry write events that happen in either a read-write or write-only functional map.
Listeners.WriteListeners.WriteListener<K,​V> - Interface in org.infinispan.functional
Write-only listener.
listenersMap - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl
 
listenerThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
listenerThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
listenerThreadPool() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
Configuration for the listener thread pool
listFiles() - Method in class org.infinispan.io.GridFile
 
listFiles(FileFilter) - Method in class org.infinispan.io.GridFile
 
listFiles(FilenameFilter) - Method in class org.infinispan.io.GridFile
 
load(int, Object) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
Fetches an entry from the storage given a segment to optimize this lookup based on.
load(int, Object) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
load(Object) - Method in class org.infinispan.persistence.async.AsyncCacheLoader
 
load(Object) - Method in class org.infinispan.persistence.cluster.ClusterLoader
 
load(Object) - Method in class org.infinispan.persistence.file.SingleFileStore
 
load(Object) - Method in interface org.infinispan.persistence.spi.CacheLoader
Fetches an entry from the storage.
load(Object) - Method in class org.infinispan.persistence.support.AbstractSegmentedAdvancedLoadWriteStore
 
load(Object) - Method in class org.infinispan.persistence.support.DelegatingCacheLoader
 
LOAD_PERSIST - org.infinispan.functional.Param.PersistenceMode
 
loadAll() - Method in class org.infinispan.globalstate.impl.ImmutableLocalConfigurationStorage
 
loadAll() - Method in class org.infinispan.globalstate.impl.OverlayLocalConfigurationStorage
 
loadAll() - Method in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
 
loadAll() - Method in interface org.infinispan.globalstate.LocalConfigurationStorage
Loads all persisted cache configurations
loadAndCheckExpiration(PersistenceManager, Object, int, InvocationContext) - Static method in class org.infinispan.persistence.internal.PersistenceUtil
 
loadAndCheckExpiration(PersistenceManager, Object, InvocationContext, TimeService) - Static method in class org.infinispan.persistence.PersistenceUtil
Deprecated.
since 9.4 This method references PersistenceManager, which isn't a public class
loadAndComputeInDataContainer(DataContainer<K, V>, int, PersistenceManager, K, InvocationContext, TimeService, DataContainer.ComputeAction<K, V>) - Static method in class org.infinispan.persistence.internal.PersistenceUtil
 
loadAndComputeInDataContainer(DataContainer<K, V>, int, PersistenceManager, K, InvocationContext, TimeService, DataContainer.ComputeAction<K, V>) - Static method in class org.infinispan.persistence.PersistenceUtil
Deprecated.
since 9.4 This method references PersistenceManager, which isn't a public class
loadAndStoreInDataContainer(DataContainer<K, V>, int, PersistenceManager, K, InvocationContext, TimeService, AtomicReference<Boolean>) - Static method in class org.infinispan.persistence.internal.PersistenceUtil
 
loadAndStoreInDataContainer(DataContainer<K, V>, int, PersistenceManager, K, InvocationContext, TimeService, AtomicReference<Boolean>) - Static method in class org.infinispan.persistence.PersistenceUtil
Deprecated.
since 9.4 This method references PersistenceManager, which isn't a public class
loadAndStoreInDataContainer(DataContainer<K, V>, PersistenceManager, K, InvocationContext, TimeService, AtomicReference<Boolean>) - Static method in class org.infinispan.persistence.internal.PersistenceUtil
 
loadAndStoreInDataContainer(DataContainer<K, V>, PersistenceManager, K, InvocationContext, TimeService, AtomicReference<Boolean>) - Static method in class org.infinispan.persistence.PersistenceUtil
Deprecated.
since 9.4 This method references PersistenceManager, which isn't a public class
LOADED - org.infinispan.container.entries.ReadCommittedEntry.Flags
 
LOADED - Static variable in class org.infinispan.functional.MetaParam.MetaLoadedFromPersistence
 
LOADER - org.infinispan.configuration.parsing.Element
 
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.util.logging.Log_$logger
 
loaderConfigurationDoesNotSpecifyLoaderClass(String) - Method in interface org.infinispan.util.logging.Log
 
loaderConfigurationDoesNotSpecifyLoaderClass$str() - Method in class org.infinispan.util.logging.Log_$logger
 
loadFromAllStores(Object, boolean, boolean) - Method in interface org.infinispan.persistence.manager.PersistenceManager
Loads an entry from the persistence store for the given key.
loadFromAllStores(Object, boolean, boolean) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
loadFromAllStores(Object, boolean, boolean) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
loadFromAllStores(Object, int, boolean, boolean) - Method in interface org.infinispan.persistence.manager.PersistenceManager
Same as PersistenceManager.loadFromAllStores(Object, boolean, boolean) except that the segment of the key is also provided to avoid having to calculate the segment.
loadFromAllStores(Object, int, boolean, boolean) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
loadFromAllStores(Object, int, boolean, boolean) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
loadIfNeeded(InvocationContext, Object, FlagAffectedCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
Loads from the cache loader the entry for the given key.
loadModuleCommandHandlers(ClassLoader) - Method in class org.infinispan.util.ModuleProperties
 
loadType() - Method in class org.infinispan.commands.functional.ReadOnlyKeyCommand
 
loadType() - Method in class org.infinispan.commands.functional.ReadOnlyManyCommand
 
loadType() - Method in class org.infinispan.commands.functional.ReadWriteKeyCommand
 
loadType() - Method in class org.infinispan.commands.functional.ReadWriteKeyValueCommand
 
loadType() - Method in class org.infinispan.commands.functional.ReadWriteManyCommand
 
loadType() - Method in class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
loadType() - Method in class org.infinispan.commands.functional.WriteOnlyKeyCommand
 
loadType() - Method in class org.infinispan.commands.functional.WriteOnlyKeyValueCommand
 
loadType() - Method in class org.infinispan.commands.functional.WriteOnlyManyCommand
 
loadType() - Method in class org.infinispan.commands.functional.WriteOnlyManyEntriesCommand
 
loadType() - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
loadType() - Method in class org.infinispan.commands.read.EntrySetCommand
 
loadType() - Method in class org.infinispan.commands.read.GetAllCommand
 
loadType() - Method in class org.infinispan.commands.read.GetCacheEntryCommand
 
loadType() - Method in class org.infinispan.commands.read.GetKeyValueCommand
 
loadType() - Method in class org.infinispan.commands.read.KeySetCommand
 
loadType() - Method in class org.infinispan.commands.read.SizeCommand
 
loadType() - Method in class org.infinispan.commands.remote.GetKeysInGroupCommand
 
loadType() - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
loadType() - Method in interface org.infinispan.commands.VisitableCommand
 
loadType() - Method in class org.infinispan.commands.write.ApplyDeltaCommand
Deprecated.
 
loadType() - Method in class org.infinispan.commands.write.ClearCommand
 
loadType() - Method in class org.infinispan.commands.write.ComputeCommand
 
loadType() - Method in class org.infinispan.commands.write.ComputeIfAbsentCommand
 
loadType() - Method in class org.infinispan.commands.write.EvictCommand
 
loadType() - Method in class org.infinispan.commands.write.InvalidateCommand
 
loadType() - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
loadType() - Method in class org.infinispan.commands.write.PutMapCommand
 
loadType() - Method in class org.infinispan.commands.write.RemoveCommand
 
loadType() - Method in class org.infinispan.commands.write.ReplaceCommand
 
LOCAL - org.infinispan.configuration.cache.CacheMode
Data is not replicated.
LOCAL - org.infinispan.configuration.cache.Index
Deprecated.
since 9.1
LOCAL - org.infinispan.configuration.parsing.ParsedCacheMode
 
LOCAL - org.infinispan.distribution.DataLocality
 
LOCAL - org.infinispan.functional.Param.ExecutionMode
Command is executed only locally, it is not sent to remote nodes.
LOCAL - Static variable in interface org.infinispan.transaction.impl.TransactionOriginatorChecker
A Local mode implementation.
LOCAL_CACHE - org.infinispan.configuration.parsing.Element
 
LOCAL_CACHE_CONFIGURATION - org.infinispan.configuration.parsing.Element
 
LOCAL_SITE - org.infinispan.functional.Param.ExecutionMode
Command is executed only in the current site (same as Param.ExecutionMode.ALL, but it is not sent for backup to other sites)
LOCAL_UNCERTAIN - org.infinispan.distribution.DataLocality
 
localAddress - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
localAddress - Variable in class org.infinispan.stream.impl.ClusterStreamManagerImpl
 
localAndPhysicalAddress(String, Address, List<Address>) - Method in class org.infinispan.util.logging.Log_$logger
 
localAndPhysicalAddress(String, Address, List<Address>) - Method in interface org.infinispan.util.logging.Log
 
localAndPhysicalAddress$str() - Method in class org.infinispan.util.logging.Log_$logger
 
LocalCacheBackupReceiver - Class in org.infinispan.xsite
BackupReceiver implementation for local caches.
LocalCacheBackupReceiver(Cache<Object, Object>) - Constructor for class org.infinispan.xsite.LocalCacheBackupReceiver
 
LocalCacheStream<R> - Class in org.infinispan.stream.impl.local
CacheStream that is to be used locally.
LocalCacheStream(AbstractLocalCacheStream.StreamSupplier<R, Stream<R>>, boolean, ComponentRegistry) - Constructor for class org.infinispan.stream.impl.local.LocalCacheStream
 
LocalCacheStream(AbstractLocalCacheStream<?, ?, ?>) - Constructor for class org.infinispan.stream.impl.local.LocalCacheStream
 
LocalClassLoaderCacheStoreFactory - Class in org.infinispan.persistence.factory
Default implementation, which uses Local class loader.
LocalClassLoaderCacheStoreFactory() - Constructor for class org.infinispan.persistence.factory.LocalClassLoaderCacheStoreFactory
 
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.
LocalConfigurationStorage - Interface in org.infinispan.globalstate
The LocalConfigurationStorage is responsible for applying on each node the configuration changes initiated through the GlobalConfigurationManager and persist them if requested via CacheContainerAdmin.AdminFlag.PERMANENT.
LocalDoubleCacheStream - Class in org.infinispan.stream.impl.local
DoubleStream that wraps a given stream to allow for additional functionality such as injection of values into various operations
LocalDoubleCacheStream(AbstractLocalCacheStream.StreamSupplier<Double, DoubleStream>, boolean, ComponentRegistry) - Constructor for class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
localExecutionFailed(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
localExecutionFailed(Throwable) - Method in interface org.infinispan.util.logging.Log
 
localExecutionFailed$str() - Method in class org.infinispan.util.logging.Log_$logger
 
localExecutorService - Variable in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
localIndexingWithSharedCacheLoaderRequiresPreload() - Method in class org.infinispan.util.logging.Log_$logger
 
localIndexingWithSharedCacheLoaderRequiresPreload() - Method in interface org.infinispan.util.logging.Log
 
localIndexingWithSharedCacheLoaderRequiresPreload$str() - Method in class org.infinispan.util.logging.Log_$logger
 
LocalIntCacheStream - Class in org.infinispan.stream.impl.local
IntStream that wraps a given stream to allow for additional functionality such as injection of values into various operations
LocalIntCacheStream(AbstractLocalCacheStream.StreamSupplier<Integer, IntStream>, boolean, ComponentRegistry) - Constructor for class org.infinispan.stream.impl.local.LocalIntCacheStream
 
LocalInvocation - Class in org.infinispan.remoting
Simulates a remote invocation on the local node.
LocalizedCacheTopology - Class in org.infinispan.distribution
Extends CacheTopology with information about keys owned by the local node.
LocalizedCacheTopology(CacheMode, CacheTopology, KeyPartitioner, Address, boolean) - Constructor for class org.infinispan.distribution.LocalizedCacheTopology
 
localLastAccess(Object, Object, int) - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
LocalLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
 
LocalLongCacheStream - Class in org.infinispan.stream.impl.local
LongStream that wraps a given stream to allow for additional functionality such as injection of values into various operations
LocalLongCacheStream(AbstractLocalCacheStream.StreamSupplier<Long, LongStream>, boolean, ComponentRegistry) - Constructor for class org.infinispan.stream.impl.local.LocalLongCacheStream
 
LocalModeAddress - Class in org.infinispan.remoting.transport
Represents the local node's address.
localNodeIsOwner(Object) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
Deprecated.
Since 9.0, please use getCacheTopology().isWriteOwner(key) instead.
localNodeIsPrimaryOwner(Object) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
Deprecated.
Since 9.0, please use getCacheTopology().getDistribution(key).isPrimary() instead.
LocalOnlyCacheLoader - Interface in org.infinispan.persistence.spi
Marker interface for cache loaders that should only load values on the originating nodes.
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.
LocalStreamManager<Original,​K> - Interface in org.infinispan.stream.impl
Stream manager that is invoked on a local node.
LocalStreamManagerImpl<Original,​K,​V> - Class in org.infinispan.stream.impl
Local stream manager implementation that handles injection of the stream supplier, invoking the operation and subsequently notifying the operation if a rehash has changed one of its segments.
LocalStreamManagerImpl() - Constructor for class org.infinispan.stream.impl.LocalStreamManagerImpl
 
localTopologyManager - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
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.impl
Object that holds transaction's state on the node where it originated; as opposed to RemoteTransaction.
LocalTransaction(Transaction, GlobalTransaction, boolean, int, long) - Constructor for class org.infinispan.transaction.impl.LocalTransaction
 
localTransactionPrepared(LocalTransaction) - Method in class org.infinispan.transaction.impl.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(LocalTransaction) - 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, long) - Constructor for class org.infinispan.transaction.xa.LocalXaTransaction
 
locate(Object) - Method in interface org.infinispan.distribution.DistributionManager
Deprecated.
Since 9.0, please use getCacheTopology().getDistributionInfo(key) instead.
locate(Object) - Method in class org.infinispan.distribution.impl.DistributionManagerImpl
 
locateAll(Collection<Object>) - Method in interface org.infinispan.distribution.DistributionManager
Deprecated.
Since 9.0, no direct replacement.
locateAll(Collection<Object>) - Method in class org.infinispan.distribution.impl.DistributionManagerImpl
 
locateAllOwners(Collection<Object>) - Method in interface org.infinispan.distribution.ch.ConsistentHash
Deprecated.
locateAllOwners(Collection<Object>) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
locateAllOwners(Collection<Object>) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
 
locateKey(String) - Method in class org.infinispan.distribution.impl.DistributionManagerImpl
 
locateOwners(Object) - Method in interface org.infinispan.distribution.ch.ConsistentHash
Deprecated.
Since 9.0, please use LocalizedCacheTopology.getDistribution(Object) instead.
locateOwnersForSegment(int) - Method in interface org.infinispan.distribution.ch.ConsistentHash
 
locateOwnersForSegment(int) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
 
locateOwnersForSegment(int) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
locateOwnersForSegment(int) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
 
locateOwnersForSegment(int) - Method in class org.infinispan.distribution.group.impl.PartitionerConsistentHash
 
locatePrimaryOwner(Object) - Method in interface org.infinispan.distribution.ch.ConsistentHash
Deprecated.
Since 9.0, please use LocalizedCacheTopology.getDistribution(Object) instead.
locatePrimaryOwnerForSegment(int) - Method in interface org.infinispan.distribution.ch.ConsistentHash
 
locatePrimaryOwnerForSegment(int) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
 
locatePrimaryOwnerForSegment(int) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
locatePrimaryOwnerForSegment(int) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
 
locatePrimaryOwnerForSegment(int) - Method in class org.infinispan.distribution.group.impl.PartitionerConsistentHash
 
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 - org.infinispan.configuration.parsing.Attribute
 
LOCATION - Static variable in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
 
lock() - Method in interface org.infinispan.util.concurrent.locks.LockPromise
It locks the key (or keys) associated to this promise.
lock(Object, Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
 
lock(Object, Object, long, TimeUnit) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Attempts to lock the key if the lock isn't already held by the lockOwner.
lock(Collection<? extends K>) - Method in interface org.infinispan.AdvancedCache
Locks collections of keys eagerly across cache nodes in a cluster.
lock(Collection<? extends K>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
lock(Collection<? extends K>) - Method in class org.infinispan.cache.impl.CacheImpl
 
lock(Collection<? extends K>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
lock(Collection<? extends K>) - Method in class org.infinispan.cache.impl.EncoderCache
 
lock(Collection<? extends K>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
lock(Collection<? extends K>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
lock(K...) - Method in interface org.infinispan.AdvancedCache
Locks a given key or keys eagerly across cache nodes in a cluster.
lock(K...) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
lock(K...) - Method in class org.infinispan.cache.impl.CacheImpl
 
lock(K...) - Method in class org.infinispan.cache.impl.DecoratedCache
 
lock(K...) - Method in class org.infinispan.cache.impl.EncoderCache
 
lock(K...) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
lock(K...) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
LOCK - org.infinispan.functional.Param.LockingMode
 
LOCK_ACQUISITION_TIMEOUT - Static variable in class org.infinispan.configuration.cache.LockingConfiguration
 
LOCK_TIMEOUT - org.infinispan.configuration.parsing.Attribute
 
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
LockAction - Class in org.infinispan.remoting.inboundhandler.action
An Action implementation that acquire the locks.
LockAction(LockManager, DistributionManager) - Constructor for class org.infinispan.remoting.inboundhandler.action.LockAction
 
lockAll() - Method in class org.infinispan.container.offheap.StripedLock
Locks all write locks.
lockAll(Collection<?>, Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
 
lockAll(Collection<?>, Object, long, TimeUnit) - Method in interface org.infinispan.util.concurrent.locks.LockManager
lockAndRecord(InvocationContext, Object, long) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
lockAs(Object) - Method in interface org.infinispan.AdvancedCache
Whenever this cache acquires a lock it will do so using the given Object as the owner of said lock.
lockAs(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
lockAs(Object) - Method in class org.infinispan.cache.impl.CacheImpl
 
lockAs(Object) - Method in class org.infinispan.cache.impl.DecoratedCache
 
lockAs(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
lockAs(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
LockContainer - Interface in org.infinispan.util.concurrent.locks.impl
A container for locks
LockContainerFactory - Class in org.infinispan.factories
Factory class that creates instances of LockContainer.
LockContainerFactory() - Constructor for class org.infinispan.factories.LockContainerFactory
 
LockControlCommand - Class in org.infinispan.commands.control
LockControlCommand is a command that enables distributed locking across infinispan nodes.
LockControlCommand(Object, ByteString, long, GlobalTransaction) - Constructor for class org.infinispan.commands.control.LockControlCommand
 
LockControlCommand(Collection<?>, ByteString, long, GlobalTransaction) - Constructor for class org.infinispan.commands.control.LockControlCommand
 
LockControlCommand(ByteString) - Constructor for class org.infinispan.commands.control.LockControlCommand
 
lockedStream() - Method in interface org.infinispan.AdvancedCache
Returns a sequential stream using this Cache as the source.
lockedStream() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
lockedStream() - Method in class org.infinispan.cache.impl.CacheImpl
 
lockedStream() - Method in class org.infinispan.cache.impl.DecoratedCache
 
lockedStream() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
lockedStream() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
LockedStream<K,​V> - Interface in org.infinispan
Stream that allows for operation upon data solely with side effects by using LockedStream.forEach(BiConsumer) where the BiConsumer is invoked while guaranteeing that the entry being passed is properly locked for the entire duration of the invocation.
LockedStreamImpl<K,​V> - Class in org.infinispan.stream.impl
Lock Stream implementation that locks a key using the LockManager before and after executing the various code.
LockedStreamImpl(CacheStream<CacheEntry<K, V>>, long, TimeUnit) - Constructor for class org.infinispan.stream.impl.LockedStreamImpl
 
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
 
LOCKING - org.infinispan.configuration.parsing.Attribute
 
LOCKING - org.infinispan.configuration.parsing.Element
 
LOCKING_MODE - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
 
LOCKING_MODE_ID - Static variable in class org.infinispan.functional.ParamIds
 
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.
LockListener - Interface in org.infinispan.util.concurrent.locks
The listener for LockPromise.
lockManager - Variable in class org.infinispan.interceptors.impl.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
 
lockOperationsNotSupported() - Method in class org.infinispan.util.logging.Log_$logger
 
lockOperationsNotSupported() - Method in interface org.infinispan.util.logging.Log
 
lockOperationsNotSupported$str() - Method in class org.infinispan.util.logging.Log_$logger
 
LockPromise - Interface in org.infinispan.util.concurrent.locks
A promise returned by InfinispanLock.
locksAcquired(Collection<Address>) - Method in class org.infinispan.transaction.impl.LocalTransaction
 
locksAtOrigin - Variable in class org.infinispan.transaction.xa.DldGlobalTransaction
Deprecated.
 
LockState - Enum in org.infinispan.util.concurrent.locks
The InfinispanLock possible states.
log - Static variable in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
 
log - Static variable in class org.infinispan.factories.AbstractComponentFactory
 
log - Static variable in class org.infinispan.globalstate.impl.ImmutableLocalConfigurationStorage
 
log - Static variable in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
 
log - Static variable in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
log - Static variable in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
 
log - Static variable in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
log - Variable in class org.infinispan.security.impl.AuditMessages_$logger
 
log - Static variable in class org.infinispan.stream.impl.ClusterStreamManagerImpl
 
log(EventLogLevel, EventLogCategory, String) - Method in interface org.infinispan.util.logging.events.EventLogger
Logs a message to the event log with the specified level
log(EventLogLevel, EventLogCategory, String) - Method in class org.infinispan.util.logging.events.impl.BasicEventLogger
 
log(EventLogLevel, EventLogCategory, String) - Method in class org.infinispan.util.logging.events.impl.DecoratedEventLogger
 
Log - Interface in org.infinispan.util.logging
Infinispan's log abstraction layer on top of JBoss Logging.
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
 
LOG_ROOT - Static variable in class org.infinispan.util.logging.LogFactory
 
LogFactory - Class in org.infinispan.util.logging
Factory that creates Log instances.
LogFactory() - Constructor for class org.infinispan.util.logging.LogFactory
 
LoggingAuditLogger - Class in org.infinispan.security.impl
LoggingAuditLogger.
LoggingAuditLogger() - Constructor for class org.infinispan.security.impl.LoggingAuditLogger
 
logRetry(int, TopologyAffectedCommand) - Method in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor
 
logRoutingTableInformation() - Method in class org.infinispan.topology.CacheTopology
 
LONG - org.infinispan.stream.impl.IntermediateType
 
longCacheStream() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
longCacheStream() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
longCacheStream() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
longCacheStream() - Method in class org.infinispan.stream.impl.tx.TxDistributedCacheStream
 
longCacheStream() - Method in class org.infinispan.stream.impl.tx.TxDistributedDoubleCacheStream
 
longCacheStream() - Method in class org.infinispan.stream.impl.tx.TxDistributedIntCacheStream
 
LongCacheStream - Interface in org.infinispan
A LongStream that has additional methods to allow for Serializable instances.
LongSummaryStatisticsExternalizer - Class in org.infinispan.marshall.exts
Externalizer used for LongSummaryStatistics.
LongSummaryStatisticsExternalizer() - Constructor for class org.infinispan.marshall.exts.LongSummaryStatisticsExternalizer
 
lookedUpEntries - Variable in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
lookedUpEntriesCount() - Method in interface org.infinispan.context.EntryLookup
 
lookedUpEntriesCount() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
lookedUpEntriesCount() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
Deprecated.
 
lookedUpEntriesTopology() - Method in class org.infinispan.transaction.impl.RemoteTransaction
 
lookupCacheEntry(InvocationContext, Object) - Method in class org.infinispan.commands.functional.ReadOnlyManyCommand
 
lookupComponent(String, String, boolean) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
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.AbstractTxInvocationContext
 
lookupEntry(Object) - Method in class org.infinispan.context.impl.ClearInvocationContext
 
lookupEntry(Object) - Method in class org.infinispan.context.impl.ImmutableContext
 
lookupEntry(Object) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
lookupEntry(Object) - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
Deprecated.
 
lookupEntry(Object) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
lookupEntry(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
lookupLocalComponent(String, String, boolean) - Method in class org.infinispan.factories.ComponentRegistry
 
lostDataBecauseOfAbruptLeavers(Collection<Address>) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
lostDataBecauseOfAbruptLeavers(Collection<Address>) - Method in interface org.infinispan.util.logging.events.Messages
 
lostDataBecauseOfAbruptLeavers$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
lostDataBecauseOfGracefulLeaver(Address) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
lostDataBecauseOfGracefulLeaver(Address) - Method in interface org.infinispan.util.logging.events.Messages
 
lostDataBecauseOfGracefulLeaver$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
LostDataCheck - Interface in org.infinispan.partitionhandling.impl
 
LostDataVisitor() - Constructor for class org.infinispan.interceptors.impl.BaseStateTransferInterceptor.LostDataVisitor
 
lostSegment(boolean) - Method in interface org.infinispan.stream.impl.SegmentAwareOperation
This method will be invoked when the operation is known to be performing on a given set of segments and this node no longer owns 1 or many of them.
lostSegment(boolean) - Method in class org.infinispan.stream.impl.termop.AbstractForEachOperation
 
lostSegment(boolean) - Method in class org.infinispan.stream.impl.termop.primitive.AbstractForEachDoubleOperation
 
lostSegment(boolean) - Method in class org.infinispan.stream.impl.termop.primitive.AbstractForEachIntOperation
 
lostSegment(boolean) - Method in class org.infinispan.stream.impl.termop.primitive.AbstractForEachLongOperation
 
lostSegment(boolean) - Method in class org.infinispan.stream.impl.termop.SegmentRetryingOperation
 
lostSegment(boolean) - Method in class org.infinispan.stream.impl.termop.SingleRunOperation
 
LRU - org.infinispan.eviction.EvictionStrategy
Deprecated.
lruLock - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
lsm - Variable in class org.infinispan.stream.impl.StreamIteratorNextCommand
 

M

MACHINE - org.infinispan.distribution.topologyaware.TopologyLevel
 
MACHINE_ID - org.infinispan.configuration.parsing.Attribute
 
MACHINE_ID - Static variable in class org.infinispan.configuration.global.TransportConfiguration
 
machineId() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
machineId(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
The id of the machine where this node runs.
main(String[]) - Static method in class org.infinispan.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.
MAKE_READY - org.infinispan.remoting.inboundhandler.action.BaseLockingAction.InternalState
 
makeSegmentedSingletonTopology(KeyPartitioner, int, Address) - Static method in class org.infinispan.distribution.LocalizedCacheTopology
Creates a new local topology that has a single address but multiple segments.
makeSingletonTopology(CacheMode, KeyPartitioner, int, Address) - Static method in class org.infinispan.distribution.impl.DistributionManagerImpl
 
makeSingletonTopology(CacheMode, Address) - Static method in class org.infinispan.distribution.LocalizedCacheTopology
 
makeStage(Object) - Static method in class org.infinispan.interceptors.BaseAsyncInterceptor
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<Field>, List<Method>, List<Method>, List<Method>, List<Method>, boolean, boolean, List<Field>, List<Method>, List<Method>, MBean) - Constructor for class org.infinispan.factories.components.ManageableComponentMetadata
 
ManageableExecutorService<T extends ExecutorService> - Class in org.infinispan.executors
 
ManageableExecutorService() - Constructor for class org.infinispan.executors.ManageableExecutorService
 
MANAGED - org.infinispan.globalstate.ConfigurationStorage
A configuration storage provider which stores configurations in a managed environment (e.g.
MANAGED_CONFIGURATION_STORAGE - org.infinispan.configuration.parsing.Element
 
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.
ManagedOperation - Annotation Type in org.infinispan.jmx.annotations
Indicates that a method in an MBean class defines an MBean operation.
managerConfigurationStorageUnavailable() - Method in class org.infinispan.util.logging.Log_$logger
 
managerConfigurationStorageUnavailable() - Method in interface org.infinispan.util.logging.Log
 
managerConfigurationStorageUnavailable$str() - Method in class org.infinispan.util.logging.Log_$logger
 
ManagerStatusResponse - Class in org.infinispan.topology
 
ManagerStatusResponse(Map<String, CacheStatusResponse>, boolean) - Constructor for class org.infinispan.topology.ManagerStatusResponse
 
ManagerStatusResponse.Externalizer - Class in org.infinispan.topology
 
MANUAL - org.infinispan.eviction.EvictionStrategy
Strategy where the cache does nothing but the user is assumed to manually invoke evict method
manyWriteOnRemotePrimary(Address, WriteCommand, CommandAckCollector.MultiTargetCollector) - Method in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor
 
manyWriteOnRemotePrimary(Address, WriteCommand, CommandAckCollector.MultiTargetCollector) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
manyWriteResponse(InvocationContext, WriteCommand, Object) - Method in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor
 
manyWriteResponse(InvocationContext, WriteCommand, Object) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
map - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
 
map - Variable in class org.infinispan.remoting.transport.impl.MapResponseCollector
 
map(InputStream) - Method in interface org.infinispan.stream.impl.intops.FlatMappingOperation
Instead of flat mapping this returns a stream of FlatMappingOperation.
map(DoubleUnaryOperator) - Method in interface org.infinispan.DoubleCacheStream
map(DoubleUnaryOperator) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
map(DoubleUnaryOperator) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
map(DoubleUnaryOperator) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
map(Function<? super R, ? extends R1>) - Method in interface org.infinispan.CacheStream
map(Function<? super R, ? extends R1>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
map(Function<? super R, ? extends R1>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
map(Function<? super R, ? extends R1>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
map(Function<? super R, ? extends R1>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
map(Function<? super T, ? extends R>) - Method in interface org.infinispan.functional.Traversable
An intermediate operation that returns a traversable containing the results of applying the given function over the elements of the traversable.
map(IntUnaryOperator) - Method in interface org.infinispan.IntCacheStream
map(IntUnaryOperator) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
map(IntUnaryOperator) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
map(IntUnaryOperator) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
map(LongUnaryOperator) - Method in interface org.infinispan.LongCacheStream
map(LongUnaryOperator) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
map(LongUnaryOperator) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
map(LongUnaryOperator) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
map(DoubleStream) - Method in class org.infinispan.stream.impl.intops.primitive.d.FlatMapDoubleOperation
 
map(IntStream) - Method in class org.infinispan.stream.impl.intops.primitive.i.FlatMapIntOperation
 
map(LongStream) - Method in class org.infinispan.stream.impl.intops.primitive.l.FlatMapLongOperation
 
map(Stream<I>) - Method in class org.infinispan.stream.impl.intops.object.FlatMapOperation
 
map(Stream<I>) - Method in class org.infinispan.stream.impl.intops.object.FlatMapToDoubleOperation
 
map(Stream<I>) - Method in class org.infinispan.stream.impl.intops.object.FlatMapToIntOperation
 
map(Stream<I>) - Method in class org.infinispan.stream.impl.intops.object.FlatMapToLongOperation
 
map(SerializableDoubleUnaryOperator) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleCacheStream.map(DoubleUnaryOperator) except that the DoubleUnaryOperator must also implement Serializable
map(SerializableDoubleUnaryOperator) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
map(SerializableFunction<? super R, ? extends R1>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.map(Function) except that the Function must also implement Serializable
map(SerializableIntUnaryOperator) - Method in interface org.infinispan.IntCacheStream
Same as IntCacheStream.map(IntUnaryOperator) except that the IntUnaryOperator must also implement Serializable
map(SerializableIntUnaryOperator) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
map(SerializableLongUnaryOperator) - Method in interface org.infinispan.LongCacheStream
Same as LongCacheStream.map(LongUnaryOperator) except that the LongUnaryOperator must also implement Serializable.
map(SerializableLongUnaryOperator) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
mapAddresses(List<Address>) - Method in interface org.infinispan.topology.PersistentUUIDManager
Returns a list of PersistentUUIDs for the supplied Addresses
mapAddresses(List<Address>) - Method in class org.infinispan.topology.PersistentUUIDManagerImpl
 
MapDoubleOperation - Class in org.infinispan.stream.impl.intops.primitive.d
Performs map operation on a DoubleStream
MapDoubleOperation(DoubleUnaryOperator) - Constructor for class org.infinispan.stream.impl.intops.primitive.d.MapDoubleOperation
 
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
 
MapIntOperation - Class in org.infinispan.stream.impl.intops.primitive.i
Performs map operation on a IntStream
MapIntOperation(IntUnaryOperator) - Constructor for class org.infinispan.stream.impl.intops.primitive.i.MapIntOperation
 
MapLongOperation - Class in org.infinispan.stream.impl.intops.primitive.l
Performs map operation on a LongStream
MapLongOperation(LongUnaryOperator) - Constructor for class org.infinispan.stream.impl.intops.primitive.l.MapLongOperation
 
MapOperation<I,​O> - Class in org.infinispan.stream.impl.intops.object
Performs map to operation on a regular Stream
MapOperation(Function<? super I, ? extends O>) - Constructor for class org.infinispan.stream.impl.intops.object.MapOperation
 
MapOperation(SerializableFunction<? super I, ? extends O>) - Constructor for class org.infinispan.stream.impl.intops.object.MapOperation
 
MapOpsExternalizer() - Constructor for class org.infinispan.stream.impl.AbstractCacheStream.MapOpsExternalizer
 
mapper - Variable in class org.infinispan.util.CollectionMapper
 
MAPPER - org.infinispan.configuration.parsing.Attribute
 
MappingOperation<InputType,​InputStream extends BaseStream<InputType,​InputStream>,​OutputType,​OutputStream extends BaseStream<OutputType,​OutputStream>> - Interface in org.infinispan.stream.impl.intops
Marker interface to signify that an IntermediateOperation is a map operation.
MapResponseCollector - Class in org.infinispan.remoting.transport.impl
maps - Variable in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
mapSupplier - Variable in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
mapToDouble(IntToDoubleFunction) - Method in interface org.infinispan.IntCacheStream
mapToDouble(IntToDoubleFunction) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
mapToDouble(IntToDoubleFunction) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
mapToDouble(IntToDoubleFunction) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
mapToDouble(LongToDoubleFunction) - Method in interface org.infinispan.LongCacheStream
mapToDouble(LongToDoubleFunction) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
mapToDouble(LongToDoubleFunction) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
mapToDouble(LongToDoubleFunction) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
mapToDouble(ToDoubleFunction<? super R>) - Method in interface org.infinispan.CacheStream
mapToDouble(ToDoubleFunction<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
mapToDouble(ToDoubleFunction<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
mapToDouble(ToDoubleFunction<? super R>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
mapToDouble(ToDoubleFunction<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
mapToDouble(SerializableIntToDoubleFunction) - Method in interface org.infinispan.IntCacheStream
Same as IntCacheStream.mapToDouble(IntToDoubleFunction) except that the IntToIntFunction must also implement Serializable
mapToDouble(SerializableIntToDoubleFunction) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
mapToDouble(SerializableLongToDoubleFunction) - Method in interface org.infinispan.LongCacheStream
Same as LongCacheStream.mapToDouble(LongToDoubleFunction) except that the LongToLongFunction must also implement Serializable.
mapToDouble(SerializableLongToDoubleFunction) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
mapToDouble(SerializableToDoubleFunction<? super R>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.mapToDouble(ToDoubleFunction) except that the ToDoubleFunction must also implement Serializable
MapToDoubleIntOperation - Class in org.infinispan.stream.impl.intops.primitive.i
Performs map to double operation on a IntStream
MapToDoubleIntOperation(IntToDoubleFunction) - Constructor for class org.infinispan.stream.impl.intops.primitive.i.MapToDoubleIntOperation
 
MapToDoubleLongOperation - Class in org.infinispan.stream.impl.intops.primitive.l
Performs map to double operation on a LongStream
MapToDoubleLongOperation(LongToDoubleFunction) - Constructor for class org.infinispan.stream.impl.intops.primitive.l.MapToDoubleLongOperation
 
MapToDoubleOperation<I> - Class in org.infinispan.stream.impl.intops.object
Performs map to double operation on a regular Stream
MapToDoubleOperation(ToDoubleFunction<? super I>) - Constructor for class org.infinispan.stream.impl.intops.object.MapToDoubleOperation
 
mapToInt(DoubleToIntFunction) - Method in interface org.infinispan.DoubleCacheStream
mapToInt(DoubleToIntFunction) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
mapToInt(DoubleToIntFunction) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
mapToInt(DoubleToIntFunction) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
mapToInt(LongToIntFunction) - Method in interface org.infinispan.LongCacheStream
mapToInt(LongToIntFunction) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
mapToInt(LongToIntFunction) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
mapToInt(LongToIntFunction) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
mapToInt(ToIntFunction<? super R>) - Method in interface org.infinispan.CacheStream
mapToInt(ToIntFunction<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
mapToInt(ToIntFunction<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
mapToInt(ToIntFunction<? super R>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
mapToInt(ToIntFunction<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
mapToInt(SerializableDoubleToIntFunction) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleCacheStream.mapToInt(DoubleToIntFunction) except that the DoubleToIntFunction must also implement Serializable
mapToInt(SerializableDoubleToIntFunction) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
mapToInt(SerializableLongToIntFunction) - Method in interface org.infinispan.LongCacheStream
Same as LongCacheStream.mapToInt(LongToIntFunction) except that the LongToIntFunction must also implement Serializable.
mapToInt(SerializableLongToIntFunction) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
mapToInt(SerializableToIntFunction<? super R>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.mapToInt(ToIntFunction) except that the ToIntFunction must also implement Serializable
MapToIntDoubleOperation - Class in org.infinispan.stream.impl.intops.primitive.d
Performs map to int operation on a DoubleStream
MapToIntDoubleOperation(DoubleToIntFunction) - Constructor for class org.infinispan.stream.impl.intops.primitive.d.MapToIntDoubleOperation
 
MapToIntLongOperation - Class in org.infinispan.stream.impl.intops.primitive.l
Performs map to int operation on a LongStream
MapToIntLongOperation(LongToIntFunction) - Constructor for class org.infinispan.stream.impl.intops.primitive.l.MapToIntLongOperation
 
MapToIntOperation<I> - Class in org.infinispan.stream.impl.intops.object
Performs map to int operation on a regular Stream
MapToIntOperation(ToIntFunction<? super I>) - Constructor for class org.infinispan.stream.impl.intops.object.MapToIntOperation
 
mapToLong(DoubleToLongFunction) - Method in interface org.infinispan.DoubleCacheStream
mapToLong(DoubleToLongFunction) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
mapToLong(DoubleToLongFunction) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
mapToLong(DoubleToLongFunction) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
mapToLong(IntToLongFunction) - Method in interface org.infinispan.IntCacheStream
mapToLong(IntToLongFunction) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
mapToLong(IntToLongFunction) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
mapToLong(IntToLongFunction) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
mapToLong(ToLongFunction<? super R>) - Method in interface org.infinispan.CacheStream
mapToLong(ToLongFunction<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
mapToLong(ToLongFunction<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
mapToLong(ToLongFunction<? super R>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
mapToLong(ToLongFunction<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
mapToLong(SerializableDoubleToLongFunction) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleCacheStream.mapToLong(DoubleToLongFunction) except that the DoubleToLongFunction must also implement Serializable
mapToLong(SerializableDoubleToLongFunction) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
mapToLong(SerializableIntToLongFunction) - Method in interface org.infinispan.IntCacheStream
Same as IntCacheStream.mapToLong(IntToLongFunction) except that the IntToLongFunction must also implement Serializable
mapToLong(SerializableIntToLongFunction) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
mapToLong(SerializableToLongFunction<? super R>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.mapToLong(ToLongFunction) except that the ToLongFunction must also implement Serializable
MapToLongDoubleOperation - Class in org.infinispan.stream.impl.intops.primitive.d
Performs map to long operation on a DoubleStream
MapToLongDoubleOperation(DoubleToLongFunction) - Constructor for class org.infinispan.stream.impl.intops.primitive.d.MapToLongDoubleOperation
 
MapToLongIntOperation - Class in org.infinispan.stream.impl.intops.primitive.i
Performs map to long operation on a IntStream
MapToLongIntOperation(IntToLongFunction) - Constructor for class org.infinispan.stream.impl.intops.primitive.i.MapToLongIntOperation
 
MapToLongOperation<I> - Class in org.infinispan.stream.impl.intops.object
Performs map to long operation on a regular Stream
MapToLongOperation(ToLongFunction<? super I>) - Constructor for class org.infinispan.stream.impl.intops.object.MapToLongOperation
 
mapToObj(DoubleFunction<? extends U>) - Method in interface org.infinispan.DoubleCacheStream
mapToObj(DoubleFunction<? extends U>) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
mapToObj(DoubleFunction<? extends U>) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
mapToObj(DoubleFunction<? extends U>) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
mapToObj(IntFunction<? extends U>) - Method in interface org.infinispan.IntCacheStream
mapToObj(IntFunction<? extends U>) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
mapToObj(IntFunction<? extends U>) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
mapToObj(IntFunction<? extends U>) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
mapToObj(LongFunction<? extends U>) - Method in interface org.infinispan.LongCacheStream
mapToObj(LongFunction<? extends U>) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
mapToObj(LongFunction<? extends U>) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
mapToObj(LongFunction<? extends U>) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
mapToObj(SerializableDoubleFunction<? extends U>) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleCacheStream.mapToObj(DoubleFunction) except that the DoubleFunction must also implement Serializable
mapToObj(SerializableDoubleFunction<? extends U>) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
mapToObj(SerializableIntFunction<? extends U>) - Method in interface org.infinispan.IntCacheStream
Same as IntCacheStream.mapToObj(IntFunction) except that the IntFunction must also implement Serializable
mapToObj(SerializableIntFunction<? extends U>) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
mapToObj(SerializableLongFunction<? extends U>) - Method in interface org.infinispan.LongCacheStream
Same as LongCacheStream.mapToObj(LongFunction) except that the LongFunction must also implement Serializable.
mapToObj(SerializableLongFunction<? extends U>) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
MapToObjDoubleOperation<R> - Class in org.infinispan.stream.impl.intops.primitive.d
Performs boxed operation on a DoubleStream
MapToObjDoubleOperation(DoubleFunction<? extends R>) - Constructor for class org.infinispan.stream.impl.intops.primitive.d.MapToObjDoubleOperation
 
MapToObjIntOperation<R> - Class in org.infinispan.stream.impl.intops.primitive.i
Performs map to object operation on a IntStream
MapToObjIntOperation(IntFunction<? extends R>) - Constructor for class org.infinispan.stream.impl.intops.primitive.i.MapToObjIntOperation
 
MapToObjLongOperation<R> - Class in org.infinispan.stream.impl.intops.primitive.l
Performs map to object operation on a LongStream
MapToObjLongOperation(LongFunction<? extends R>) - Constructor for class org.infinispan.stream.impl.intops.primitive.l.MapToObjLongOperation
 
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.impl.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.
markDelivered(int, long, int) - Method in class org.infinispan.distribution.TriangleOrderManager
 
markForRollback(boolean) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
markForRollback(boolean) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
markKeyAsProcessing(K) - Method in interface org.infinispan.notifications.cachelistener.QueueingSegmentListener
This should be invoked on a key before actually processing the data.
markPrepareSent() - Method in class org.infinispan.transaction.impl.LocalTransaction
Sets the prepare sent for this transaction
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
 
markTrackerWithException(ClusterStreamManagerImpl.RequestTracker<?>, Address, Throwable, Object) - Static method in class org.infinispan.stream.impl.ClusterStreamManagerImpl
 
markTransactionAsRemote(boolean) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
markTransactionAsRemote(boolean) - Method in interface org.infinispan.commands.tx.TransactionBoundaryCommand
 
markTransactionCompleted(GlobalTransaction, boolean) - Method in class org.infinispan.transaction.impl.TransactionTable
With the current state transfer implementation it is possible for a transaction to be prepared several times on a remote node.
MarshallableFunctionExternalizers - Class in org.infinispan.marshall.core
 
MarshallableFunctionExternalizers() - Constructor for class org.infinispan.marshall.core.MarshallableFunctionExternalizers
 
MarshallableFunctionExternalizers.ConstantLambdaExternalizer - Class in org.infinispan.marshall.core
 
MarshallableFunctionExternalizers.LambdaWithMetasExternalizer - Class in org.infinispan.marshall.core
 
MarshallableFunctionExternalizers.SetValueIfEqualsReturnBooleanExternalizer - Class in org.infinispan.marshall.core
 
MarshallableFunctions - Class in org.infinispan.marshall.core
 
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(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(ByteBuffer, ByteBuffer, ByteBuffer, StreamingMarshaller) - Constructor for class org.infinispan.marshall.core.MarshalledEntryImpl
 
MarshalledEntryImpl.Externalizer - Class in org.infinispan.marshall.core
 
marshalledEntryPurged(MarshalledEntry<K, V>) - Method in interface org.infinispan.persistence.spi.AdvancedCacheExpirationWriter.ExpirationPurgeListener
Optional.
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
 
marshaller - Variable in class org.infinispan.cache.impl.CacheImpl
 
marshaller - Variable in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
marshaller - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
marshaller() - Method in class org.infinispan.configuration.cache.CompatibilityModeConfiguration
 
marshaller() - Method in class org.infinispan.configuration.cache.CompatibilityModeConfigurationBuilder
 
marshaller() - Method in class org.infinispan.configuration.global.SerializationConfiguration
 
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.global.SerializationConfigurationBuilder
Set the marshaller instance that will marshall and unmarshall cache entries.
MARSHALLER - Static variable in class org.infinispan.configuration.cache.CompatibilityModeConfiguration
 
MARSHALLER - Static variable in class org.infinispan.configuration.global.SerializationConfiguration
 
MARSHALLER_CLASS - org.infinispan.configuration.parsing.Attribute
 
MarshallerFactory - Class in org.infinispan.factories
MarshallerFactory.
MarshallerFactory() - Constructor for class org.infinispan.factories.MarshallerFactory
 
MarshallingTwoWayKey2StringMapper - Interface in org.infinispan.persistence.keymappers
MarshallingTwoWayKey2StringMapper.
MATCH_ALWAYS - org.infinispan.commands.write.ValueMatcher
Always match.
MATCH_EXPECTED - org.infinispan.commands.write.ValueMatcher
Match when the existing value is equal to the expected value.
MATCH_EXPECTED_OR_NEW - org.infinispan.commands.write.ValueMatcher
Match when the existing value is equal to the expected value or to the new value.
MATCH_EXPECTED_OR_NULL - org.infinispan.commands.write.ValueMatcher
 
MATCH_NEVER - org.infinispan.commands.write.ValueMatcher
Never match.
MATCH_NON_NULL - org.infinispan.commands.write.ValueMatcher
Match any non-null value.
matcherForRetry() - Method in enum org.infinispan.commands.write.ValueMatcher
 
matches(int) - Method in enum org.infinispan.security.AuthorizationPermission
 
matches(int) - Method in class org.infinispan.security.impl.SubjectACL
 
matches(Object, Object, Object) - Method in enum org.infinispan.commands.write.ValueMatcher
 
matches(String) - Method in enum org.infinispan.configuration.parsing.ParsedCacheMode
 
matches(String, String, String) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
 
matches(ClusteringConfiguration) - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
 
matches(Configuration) - Method in class org.infinispan.configuration.cache.Configuration
 
matches(HashConfiguration) - Method in class org.infinispan.configuration.cache.HashConfiguration
 
matches(KeyPartitioner) - Method in interface org.infinispan.distribution.ch.KeyPartitioner
 
max() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
max() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
max() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
max() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
max() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
max() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
max() - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
max() - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
max() - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
max(Comparator<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
max(Comparator<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
max(Comparator<? super R>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
max(Comparator<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
max(Comparator<? super T>) - Method in interface org.infinispan.functional.Traversable
A terminal operation that returns an optional containing the maximum element of this traversable based on the comparator passed in.
max(SerializableComparator<? super R>) - Method in interface org.infinispan.CacheStream
Same as Stream.max(Comparator) except that the Comparator must also implement Serializable
MAX_BATCH_SIZE - org.infinispan.configuration.parsing.Attribute
 
MAX_BATCH_SIZE - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
MAX_ENTRIES - org.infinispan.configuration.parsing.Attribute
 
MAX_ENTRIES - Static variable in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
 
MAX_IDLE - org.infinispan.configuration.parsing.Attribute
 
MAX_IDLE - Static variable in class org.infinispan.configuration.cache.ExpirationConfiguration
 
MAX_RETRIES - org.infinispan.configuration.parsing.Attribute
 
MAX_RETRIES - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
MAX_THREADS - org.infinispan.configuration.parsing.Attribute
 
maxBatchSize() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
maxBatchSize() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
 
maxBatchSize(int) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
maxBatchSize(int) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
 
maxBatchSize(int) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
The maximum size of a batch to be inserted/deleted from the store.
maxEntries() - Method in class org.infinispan.configuration.cache.EvictionConfiguration
Deprecated.
maxEntries() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
 
maxEntries(int) - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
Deprecated.
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.
maxEntries(long) - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
Deprecated.
maxFailoverAttempts() - Method in interface org.infinispan.distexec.DistributedTaskFailoverPolicy
Maximum number of fail over attempts permitted by this DistributedTaskFailoverPolicy
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() - Method in class org.infinispan.configuration.cache.ExpirationConfiguration
Maximum idle time a cache entry will be maintained in the cache, in milliseconds.
maxIdle() - Method in class org.infinispan.container.entries.RemoteMetadata
 
maxIdle() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
 
maxIdle() - Method in class org.infinispan.metadata.EmbeddedMetadata
 
maxIdle() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
 
maxIdle() - Method in class org.infinispan.metadata.impl.L1Metadata
 
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(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) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata.Builder
 
maxIdle(long) - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
maxIdle(long) - Method in interface org.infinispan.metadata.Metadata.Builder
Set max idle time assuming that the time unit is 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(long, TimeUnit) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata.Builder
 
maxIdle(long, TimeUnit) - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
maxIdle(long, TimeUnit) - Method in interface org.infinispan.metadata.Metadata.Builder
Set max idle time with a given time unit.
MaxIdleExternalizer() - Constructor for class org.infinispan.marshall.exts.MetaParamExternalizers.MaxIdleExternalizer
 
maxIdleUnit - Variable in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
maxRetries() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
maxRetries(int) - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
The maximum number of retries when a push state command fails.
MaxRetriesPolicy(int) - Constructor for class org.infinispan.remoting.transport.RetryOnFailureXSiteCommand.MaxRetriesPolicy
 
maxSize - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
MBean - Annotation Type in org.infinispan.jmx.annotations
Classes annotated with this will be exposed as MBeans.
MBEAN_COMPONENT_NAME - Static variable in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
 
MBEAN_SERVER_LOOKUP - org.infinispan.configuration.parsing.Attribute
 
MBEAN_SERVER_LOOKUP - Static variable in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
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
Deprecated.
Use MBeanServerLookup instead
mbeansSuccessfullyRegistered() - Method in class org.infinispan.util.logging.Log_$logger
 
mbeansSuccessfullyRegistered() - Method in interface org.infinispan.util.logging.Log
 
mbeansSuccessfullyRegistered$str() - Method in class org.infinispan.util.logging.Log_$logger
 
MEASUREMENT - org.infinispan.jmx.annotations.DataType
 
measurementType() - Method in annotation type org.infinispan.jmx.annotations.ManagedAttribute
 
MeasurementType - Enum in org.infinispan.jmx.annotations
 
MEDIA_TYPE - org.infinispan.configuration.parsing.Attribute
 
MEDIA_TYPE - Static variable in class org.infinispan.configuration.cache.ContentTypeConfiguration
 
mediaType() - Method in class org.infinispan.configuration.cache.ContentTypeConfiguration
 
mediaType() - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
mediaType(String) - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
 
mediaType(MediaType) - Method in class org.infinispan.configuration.cache.ContentTypeConfiguration
 
members - Variable in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
The membership of the cache topology that uses this CH.
memory() - Method in class org.infinispan.configuration.cache.Configuration
 
memory() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
memory() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
MEMORY - org.infinispan.configuration.parsing.Element
 
MEMORY - org.infinispan.eviction.EvictionType
 
MemoryAddressHash - Class in org.infinispan.container.offheap
 
MemoryAddressHash(int, OffsetCalculator, OffHeapMemoryAllocator) - Constructor for class org.infinispan.container.offheap.MemoryAddressHash
 
memoryApproximationUnsupportedVM(String) - Method in class org.infinispan.util.logging.Log_$logger
 
memoryApproximationUnsupportedVM(String) - Method in interface org.infinispan.util.logging.Log
 
memoryApproximationUnsupportedVM$str() - Method in class org.infinispan.util.logging.Log_$logger
 
MemoryConfiguration - Class in org.infinispan.configuration.cache
Controls the memory storage configuration for the cache.
MemoryConfigurationBuilder - Class in org.infinispan.configuration.cache
Controls the data container for the cache.
memoryEvictionInvalidStrategyLIRS() - Method in class org.infinispan.util.logging.Log_$logger
 
memoryEvictionInvalidStrategyLIRS() - Method in interface org.infinispan.util.logging.Log
 
memoryEvictionInvalidStrategyLIRS$str() - Method in class org.infinispan.util.logging.Log_$logger
 
merge(Object) - Method in class org.infinispan.atomic.impl.AtomicKeySetImpl
 
merge(Object) - Method in interface org.infinispan.container.impl.MergeOnStore
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.CacheImpl
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.CacheSupport
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.EncoderCache
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in interface org.infinispan.Cache
merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheSupport
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
An overloaded form of Cache.merge(Object, Object, BiFunction), 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.
merge(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
merge(K, V, SerializableBiFunction<? super V, ? super V, ? extends V>) - Method in interface org.infinispan.Cache
merge(K, V, SerializableBiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
merge(DeltaAware) - Method in interface org.infinispan.atomic.Delta
Deprecated.
Merge the current Delta instance with a given DeltaAware instance, and return a coherent and complete DeltaAware instance.
merge(CacheEntry<K, V>, List<CacheEntry<K, V>>) - Method in interface org.infinispan.conflict.EntryMergePolicy
This method is called by ConflictManager.resolveConflicts() for each conflict discovered to determine which CacheEntry should be utilised.
merge(CacheEntry, List) - Method in enum org.infinispan.conflict.MergePolicy
 
merge(CacheEntry, List) - Method in class org.infinispan.conflict.MergePolicy.UnsupportedMergePolicy
 
merge(EntryVersionsMap) - Method in class org.infinispan.container.versioning.EntryVersionsMap
 
merge(Metadata) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata.Builder
 
merge(Metadata) - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
merge(Metadata) - Method in interface org.infinispan.metadata.Metadata.Builder
Merges the given metadata information into the given builder.
MERGE_POLICY - org.infinispan.configuration.parsing.Attribute
 
MERGE_POLICY - Static variable in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
 
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.CacheImpl
 
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.AdvancedCache
Overloaded AsyncCache.mergeAsync(Object, Object, BiFunction) which takes in lifespan parameters.
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.AdvancedCache
Overloaded AsyncCache.mergeAsync(Object, Object, BiFunction) which takes in lifespan parameters.
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
Overloaded AsyncCache.mergeAsync(Object, Object, BiFunction), 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.
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
mergeAsync(K, V, SerializableBiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
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.
MERGED - org.infinispan.notifications.cachemanagerlistener.event.Event.Type
 
MergeEvent - Interface in org.infinispan.notifications.cachemanagerlistener.event
This event is passed in to any method annotated with Merged.
MergeFunction<K,​V> - Class in org.infinispan.commands.functional.functions
 
MergeFunction(V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Constructor for class org.infinispan.commands.functional.functions.MergeFunction
 
MergeFunction.Externalizer - Class in org.infinispan.commands.functional.functions
 
mergeHashMap(ValidResponse, Map<Object, Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
mergeInternal(K, V, BiFunction<? super V, ? super V, ? extends V>, SimpleCacheImpl.CacheEntryChange<K, V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
mergeInternal(K, V, BiFunction<? super V, ? super V, ? extends V>, SimpleCacheImpl.CacheEntryChange<K, V>, Metadata) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
mergeList(ValidResponse, List<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
mergeLists(List<Address>, List<Address>) - Static method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
Adds all elements from src list that do not already exist in dest list to the latter.
MergeOnStore - Interface in org.infinispan.container.impl
This interface is not a public API.
MergePolicies - Class in org.infinispan.conflict
Deprecated.
since 9.2 please use MergePolicy instead
MergePolicies() - Constructor for class org.infinispan.conflict.MergePolicies
Deprecated.
 
mergePolicy() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
 
mergePolicy(EntryMergePolicy) - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
 
MergePolicy - Enum in org.infinispan.conflict
 
MergePolicy.UnsupportedMergePolicy - Class in org.infinispan.conflict
 
Messages - Interface in org.infinispan.util.logging.events
Messages.
MESSAGES - Static variable in interface org.infinispan.util.logging.events.Messages
 
Messages_$bundle - Class in org.infinispan.util.logging.events
Warning this class consists of generated code.
Messages_$bundle() - Constructor for class org.infinispan.util.logging.events.Messages_$bundle
 
MetaCreated(long) - Constructor for class org.infinispan.functional.MetaParam.MetaCreated
 
metadata - Variable in class org.infinispan.commands.write.RemoveCommand
 
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 - Variable in class org.infinispan.io.GridFilesystem
 
metadata() - Method in class org.infinispan.metadata.impl.L1Metadata
 
metadata() - Method in class org.infinispan.xsite.statetransfer.XSiteState
 
Metadata - Interface in org.infinispan.metadata
This interface encapsulates metadata information that can be stored alongside values in the cache.
Metadata() - Constructor for class org.infinispan.io.GridFile.Metadata
 
Metadata(int, long, int, byte) - Constructor for class org.infinispan.io.GridFile.Metadata
 
Metadata.Builder - Interface in org.infinispan.metadata
Metadata builder
MetadataAware - Interface in org.infinispan.container.entries.metadata
Marker interface for metadata 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
 
MetaEntryVersion(EntryVersion) - Constructor for class org.infinispan.functional.MetaParam.MetaEntryVersion
 
MetaLastUsed(long) - Constructor for class org.infinispan.functional.MetaParam.MetaLastUsed
 
MetaLifespan(long) - Constructor for class org.infinispan.functional.MetaParam.MetaLifespan
 
MetaLong(long) - Constructor for class org.infinispan.functional.MetaParam.MetaLong
 
MetaMaxIdle(long) - Constructor for class org.infinispan.functional.MetaParam.MetaMaxIdle
 
MetaParam<T> - Interface in org.infinispan.functional
An easily extensible metadata parameter that's stored along with the value in the the functional map.
MetaParam.Lookup - Interface in org.infinispan.functional
Provides metadata parameter lookup capabilities using Class as lookup key.
MetaParam.MetaCreated - Class in org.infinispan.functional
Read only metadata parameter representing a cached entry's created time in milliseconds.
MetaParam.MetaEntryVersion - Class in org.infinispan.functional
Writable metadata parameter representing a cached entry's generic version.
MetaParam.MetaLastUsed - Class in org.infinispan.functional
Read only metadata parameter representing a cached entry's last used time in milliseconds.
MetaParam.MetaLifespan - Class in org.infinispan.functional
Writable metadata parameter representing a cached entry's millisecond lifespan.
MetaParam.MetaLoadedFromPersistence - Class in org.infinispan.functional
Non-writable parameter telling if the entry was loaded from a persistence tier (CacheLoader) or not.
MetaParam.MetaLong - Class in org.infinispan.functional
Abstract class for numeric long-based metadata parameter instances.
MetaParam.MetaMaxIdle - Class in org.infinispan.functional
Writable metadata parameter representing a cached entry's millisecond max idle time.
MetaParam.Writable<T> - Interface in org.infinispan.functional
Writable MetaParam instances are those that the user can provide to be stored as part of the cache entry.
MetaParamExternalizers - Class in org.infinispan.marshall.exts
 
MetaParamExternalizers.EntryVersionParamExternalizer - Class in org.infinispan.marshall.exts
 
MetaParamExternalizers.LifespanExternalizer - Class in org.infinispan.marshall.exts
 
MetaParamExternalizers.MaxIdleExternalizer - Class in org.infinispan.marshall.exts
 
MetaParamsInternalMetadata - Class in org.infinispan.functional.impl
Metadata parameters backed internal metadata representation.
MetaParamsInternalMetadata.Builder - Class in org.infinispan.functional.impl
 
MetaParamsInternalMetadata.Externalizer - Class in org.infinispan.functional.impl
 
method - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
method - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl.ListenerInvocationImpl
 
MILLISECONDS - org.infinispan.jmx.annotations.Units
 
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
 
MIMECacheEntry.Externalizer - Class in org.infinispan.remoting
 
min() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
min() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
min() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
min() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
min() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
min() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
min() - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
min() - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
min() - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
min(Comparator<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
min(Comparator<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
min(Comparator<? super R>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
min(Comparator<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
min(Comparator<? super T>) - Method in interface org.infinispan.functional.Traversable
A terminal operation that returns an optional containing the minimum element of this traversable based on the comparator passed in.
min(AvailabilityMode) - Method in enum org.infinispan.partitionhandling.AvailabilityMode
 
min(SerializableComparator<? super R>) - Method in interface org.infinispan.CacheStream
Same as Stream.min(Comparator) except that the Comparator must also implement Serializable
MIN_TIME_TO_WAIT - Static variable in class org.infinispan.configuration.cache.TakeOfflineConfiguration
 
minorityPartition(Collection<Address>, Collection<Address>, Collection<Address>) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
minorityPartition(Collection<Address>, Collection<Address>, Collection<Address>) - Method in interface org.infinispan.util.logging.events.Messages
 
minorityPartition$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
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.
MISS - Static variable in class org.infinispan.functional.impl.StatsEnvelope
 
missedSegments - Variable in class org.infinispan.stream.impl.StreamResponseCommand
 
missingBackupFailurePolicyClass() - Method in class org.infinispan.util.logging.Log_$logger
 
missingBackupFailurePolicyClass() - Method in interface org.infinispan.util.logging.Log
 
missingBackupFailurePolicyClass$str() - Method in class org.infinispan.util.logging.Log_$logger
 
missingCustomInterceptorPosition(String) - Method in class org.infinispan.util.logging.Log_$logger
 
missingCustomInterceptorPosition(String) - Method in interface org.infinispan.util.logging.Log
 
missingCustomInterceptorPosition$str() - Method in class org.infinispan.util.logging.Log_$logger
 
missingDefaultCacheDeclaration(String) - Method in class org.infinispan.util.logging.Log_$logger
 
missingDefaultCacheDeclaration(String) - Method in interface org.infinispan.util.logging.Log
 
missingDefaultCacheDeclaration$str() - Method in class org.infinispan.util.logging.Log_$logger
 
missingForeignExternalizer(int) - Method in class org.infinispan.util.logging.Log_$logger
 
missingForeignExternalizer(int) - Method in interface org.infinispan.util.logging.Log
 
missingForeignExternalizer$str() - Method in class org.infinispan.util.logging.Log_$logger
 
missingGlobalStatePersistentLocation() - Method in class org.infinispan.util.logging.Log_$logger
 
missingGlobalStatePersistentLocation() - Method in interface org.infinispan.util.logging.Log
 
missingGlobalStatePersistentLocation$str() - Method in class org.infinispan.util.logging.Log_$logger
 
missingListPreparedTransactions(Object, Object) - Method in class org.infinispan.util.logging.Log_$logger
 
missingListPreparedTransactions(Object, Object) - Method in interface org.infinispan.util.logging.Log
 
missingListPreparedTransactions$str() - Method in class org.infinispan.util.logging.Log_$logger
 
missingMigrationData(String) - Method in class org.infinispan.util.logging.Log_$logger
 
missingMigrationData(String) - Method in interface org.infinispan.util.logging.Log
 
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.
missingTransportConfiguration() - Method in class org.infinispan.util.logging.Log_$logger
 
missingTransportConfiguration() - Method in interface org.infinispan.util.logging.Log
 
missingTransportConfiguration$str() - Method in class org.infinispan.util.logging.Log_$logger
 
mixedOn(String) - Method in class org.infinispan.xsite.status.ContainerSiteStatusBuilder
Adds the cache with an mixed connection to the site.
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
 
MODE - org.infinispan.configuration.parsing.Attribute
 
Modification - Interface in org.infinispan.persistence.modifications
An interface that defines a CacheWriter modification
MODIFICATION_QUEUE_SIZE - org.infinispan.configuration.parsing.Attribute
 
MODIFICATION_QUEUE_SIZE - Static variable in class org.infinispan.configuration.cache.AsyncStoreConfiguration
 
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.impl.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 - org.infinispan.configuration.parsing.Attribute
 
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.
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.
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
 
modules() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
Global modules configuration
MODULES - org.infinispan.configuration.parsing.Element
 
moduleStopError(String, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
moduleStopError(String, Throwable) - Method in interface org.infinispan.util.logging.Log
 
moduleStopError$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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
 
MultiClusterEventCallable<K,​V> - Class in org.infinispan.notifications.cachelistener.cluster
This DistributedCallable is used to invoke a raised notification on the cluster listener that registered to listen for this event.
MultiClusterEventCallable(Map<UUID, Collection<ClusterEvent<K, V>>>) - Constructor for class org.infinispan.notifications.cachelistener.cluster.MultiClusterEventCallable
 
MultiClusterEventCallable.Externalizer - Class in org.infinispan.notifications.cachelistener.cluster
 
MultiEntriesFunctionalBackupWriteCommand - Class in org.infinispan.commands.triangle
MultiEntriesFunctionalBackupWriteCommand() - Constructor for class org.infinispan.commands.triangle.MultiEntriesFunctionalBackupWriteCommand
 
MultiEntriesFunctionalBackupWriteCommand(ByteString) - Constructor for class org.infinispan.commands.triangle.MultiEntriesFunctionalBackupWriteCommand
 
multiKeyBackupAck(long, Address, int, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
Acknowledges a PutMapCommand completion in the backup owner.
MultiKeyFunctionalBackupWriteCommand - Class in org.infinispan.commands.triangle
MultiKeyFunctionalBackupWriteCommand() - Constructor for class org.infinispan.commands.triangle.MultiKeyFunctionalBackupWriteCommand
 
MultiKeyFunctionalBackupWriteCommand(ByteString) - Constructor for class org.infinispan.commands.triangle.MultiKeyFunctionalBackupWriteCommand
 
multipleCustomInterceptorPositions(String) - Method in class org.infinispan.util.logging.Log_$logger
 
multipleCustomInterceptorPositions(String) - Method in interface org.infinispan.util.logging.Log
 
multipleCustomInterceptorPositions$str() - Method in class org.infinispan.util.logging.Log_$logger
 
multipleKeys() - Method in class org.infinispan.commands.control.LockControlCommand
 
multipleSitesWithSameName(String) - Method in class org.infinispan.util.logging.Log_$logger
 
multipleSitesWithSameName(String) - Method in interface org.infinispan.util.logging.Log
 
multipleSitesWithSameName$str() - Method in class org.infinispan.util.logging.Log_$logger
 
MultiSubCommandInvoker - Class in org.infinispan.interceptors.impl
Invoke a sequence of sub-commands.
MultiTargetRequest<T> - Class in org.infinispan.remoting.transport.impl
Request implementation that waits for responses from multiple target nodes.
MultiTargetRequest(ResponseCollector<T>, long, RequestRepository, Collection<Address>, Address) - Constructor for class org.infinispan.remoting.transport.impl.MultiTargetRequest
 
Mutation<K,​V,​R> - Interface in org.infinispan.commands.functional
Simplified version of functional command used for read-only operations after transactional modifications.
MVCCEntry<K,​V> - Interface in org.infinispan.container.entries
An entry that can be safely copied when updates are made, to provide MVCC semantics

N

name() - Method in annotation type org.infinispan.filter.NamedFactory
 
name() - Method in annotation type org.infinispan.jmx.annotations.ManagedOperation
 
name() - Method in annotation type org.infinispan.jmx.annotations.Parameter
 
NAME - org.infinispan.configuration.parsing.Attribute
 
NAME_KEY - Static variable in class org.infinispan.jmx.ComponentsJmxRegistration
 
NAMED_CACHE - org.infinispan.factories.scopes.Scopes
Components bounded to this scope can only be created by a Cache and exist in the Cache's ComponentRegistry.
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
Deprecated.
Since 9.4, please implement AbstractComponentFactory.construct(String) directly.
NamedComponentFactory() - Constructor for class org.infinispan.factories.NamedComponentFactory
Deprecated.
 
NamedExecutorsFactory - Class in org.infinispan.factories
A factory that specifically knows how to create named executors.
NamedExecutorsFactory() - Constructor for class org.infinispan.factories.NamedExecutorsFactory
 
NamedFactory - Annotation Type in org.infinispan.filter
 
names() - Method in annotation type org.infinispan.factories.annotations.DefaultFactoryFor
 
NAMES - org.infinispan.configuration.parsing.Attribute
 
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.
NANOSECONDS - org.infinispan.jmx.annotations.Units
 
needMoreResponses() - Method in class org.infinispan.remoting.responses.ClusteredGetResponseValidityFilter
 
needMoreResponses() - Method in class org.infinispan.remoting.responses.IgnoreExtraResponsesValidityFilter
 
needMoreResponses() - Method in interface org.infinispan.remoting.rpc.ResponseFilter
Right after calling ResponseFilter.isAcceptable(Response, Address), this method is called to see whether we are done with the request and can unblock the caller
needsStateTransfer() - Method in enum org.infinispan.configuration.cache.CacheMode
 
needToDestroyFailedCache() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
needToInitializeBeforeStart() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
NEVER - org.infinispan.configuration.cache.BiasAcquisition
The bias is never acquired.
newCacheEntryMapper(DataConversion, DataConversion, InternalEntryFactory) - Static method in class org.infinispan.cache.impl.EncoderEntryMapper
 
newConfigurationBuilder(String) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
newConfigurationFrom(int) - Method in class org.infinispan.configuration.cache.AbstractSegmentedStoreConfiguration
Method that is invoked each time a new store is created for a segment.
newConfigurationFrom(int) - Method in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
 
newEntryMapper(DataConversion, DataConversion, InternalEntryFactory) - Static method in class org.infinispan.cache.impl.EncoderEntryMapper
 
newFixedThreadPool(int, int) - Static method in class org.infinispan.util.concurrent.BoundedExecutors
Creates a thread pool that reuses a fixed set of threads operating off a shared bounded queue.
newFixedThreadPool(int, ThreadFactory, int) - Static method in class org.infinispan.util.concurrent.BoundedExecutors
Creates a thread pool that reuses a fixed set of threads operating off a shared bounded queue, using the provided ThreadFactory to create new threads when needed.
newGlobalTransaction() - Method in class org.infinispan.transaction.xa.TransactionFactory
 
newGlobalTransaction() - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
 
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
 
newInstance(Cache<Object, Object>, MK, boolean) - Static method in class org.infinispan.atomic.impl.FineGrainedAtomicMapProxyImpl
 
newInstance(Cache<MK, Object>, MK, boolean) - Static method in class org.infinispan.atomic.impl.AtomicMapProxyImpl
 
newInstance(ResponseGenerator, CacheRpcCommand, CommandsFactory, Address) - Static method in class org.infinispan.remoting.LocalInvocation
 
newInstance(XSiteBackup, XSiteReplicateCommand, RetryOnFailureXSiteCommand.RetryPolicy) - Static method in class org.infinispan.remoting.transport.RetryOnFailureXSiteCommand
It builds a new instance with the destination site, the command and the retry policy.
newInstanceFromCache(Cache<?, ?>, CacheRpcCommand) - Static method in class org.infinispan.remoting.LocalInvocation
 
newKeyAffinityService(Cache<K, V>, Collection<Address>, KeyGenerator<K>, Executor, 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>, Executor, KeyGenerator<K>, int) - Static method in class org.infinispan.affinity.KeyAffinityServiceFactory
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.
newKeyDataConversion(Class<? extends Encoder>, Class<? extends Wrapper>, MediaType) - Static method in class org.infinispan.encoding.DataConversion
 
newLocalKeyAffinityService(Cache<K, V>, KeyGenerator<K>, Executor, int) - Static method in class org.infinispan.affinity.KeyAffinityServiceFactory
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.
newLocalTransaction(Transaction, GlobalTransaction, boolean, int) - Method in class org.infinispan.transaction.xa.TransactionFactory
 
newLocalTransaction(Transaction, GlobalTransaction, boolean, int, long) - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
 
newMarshalledEntry(Object, Object, InternalMetadata) - Method in interface org.infinispan.marshall.core.MarshalledEntryFactory
 
newMarshalledEntry(Object, Object, InternalMetadata) - Method in class org.infinispan.marshall.core.MarshalledEntryFactoryImpl
 
newMarshalledEntry(Object, ByteBuffer, ByteBuffer) - Method in interface org.infinispan.marshall.core.MarshalledEntryFactory
 
newMarshalledEntry(Object, ByteBuffer, ByteBuffer) - Method in class org.infinispan.marshall.core.MarshalledEntryFactoryImpl
 
newMarshalledEntry(ByteBuffer, ByteBuffer, ByteBuffer) - Method in interface org.infinispan.marshall.core.MarshalledEntryFactory
 
newMarshalledEntry(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.infinispan.marshall.core.MarshalledEntryFactoryImpl
 
newNonTxInvocationContext(Address) - Method in class org.infinispan.context.TransactionalInvocationContextFactory
Deprecated.
 
newPermissionCollection() - Method in class org.infinispan.security.CachePermission
 
newRemoteTransaction(WriteCommand[], GlobalTransaction, int) - Method in class org.infinispan.transaction.xa.TransactionFactory
 
newRemoteTransaction(WriteCommand[], GlobalTransaction, int, long) - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
 
newRemoteTransaction(GlobalTransaction, int) - Method in class org.infinispan.transaction.xa.TransactionFactory
 
newRemoteTransaction(GlobalTransaction, int, long) - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
 
newRequestId() - Method in class org.infinispan.remoting.transport.impl.RequestRepository
 
newState(boolean, State) - Method in class org.infinispan.persistence.async.AsyncCacheWriter
 
newStatePushCommand(AdvancedCache<?, ?>, List<XSiteState>) - Static method in class org.infinispan.xsite.BaseBackupReceiver
 
newTaskFor(Runnable, T) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
newTaskFor(Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
newThread(Runnable) - Method in class org.infinispan.factories.threads.DefaultThreadFactory
 
newValueDataConversion(Class<? extends Encoder>, Class<? extends Wrapper>, MediaType) - Static method in class org.infinispan.encoding.DataConversion
 
next - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator
 
next() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator
 
next() - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
 
next() - Method in class org.infinispan.util.CloseableSuppliedIterator
 
next() - Method in class org.infinispan.util.DataContainerRemoveIterator
 
next() - Method in class org.infinispan.util.LazyConcatIterator
 
next(int, int) - Method in class org.infinispan.distribution.TriangleOrderManager
 
nextElement(XMLStreamReader) - Static method in class org.infinispan.configuration.parsing.ParseUtils
 
nextSegment(int) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
NO_COMMIT - org.infinispan.interceptors.locking.ClusteringDependentLogic.Commit
Do not commit the entry.
NO_FAILOVER - Static variable in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
NO_OP - Static variable in interface org.infinispan.remoting.inboundhandler.Reply
 
NO_OP - Static variable in interface org.infinispan.util.concurrent.locks.KeyAwareLockPromise
 
NO_OP - Static variable in interface org.infinispan.util.concurrent.locks.PendingLockPromise
 
NO_REBALANCE - org.infinispan.topology.CacheTopology.Phase
Only currentCH should be set, this works as both readCH and writeCH
NO_REQUEST_ID - Static variable in interface org.infinispan.remoting.transport.impl.Request
 
NO_RETRY - Static variable in class org.infinispan.remoting.transport.RetryOnFailureXSiteCommand
 
NO_STATE_TRANSFER_IN_PROGRESS - Static variable in class org.infinispan.statetransfer.StateConsumerImpl
 
NO_SUCH_SITE - org.infinispan.xsite.BackupSender.BringSiteOnlineResponse
 
NO_SUCH_SITE - org.infinispan.xsite.BackupSender.TakeSiteOfflineResponse
 
noAnnotateMethodsFoundInListener(Class<?>) - Method in class org.infinispan.util.logging.Log_$logger
 
noAnnotateMethodsFoundInListener(Class<?>) - Method in interface org.infinispan.util.logging.Log
 
noAnnotateMethodsFoundInListener$str() - Method in class org.infinispan.util.logging.Log_$logger
 
noConfiguration(String) - Method in class org.infinispan.util.logging.Log_$logger
 
noConfiguration(String) - Method in interface org.infinispan.util.logging.Log
 
noConfiguration$str() - Method in class org.infinispan.util.logging.Log_$logger
 
noDataLossOnJoiner(Configuration) - Static method in class org.infinispan.configuration.cache.Configurations
 
NODE - org.infinispan.distribution.topologyaware.TopologyLevel
 
NODE_NAME - org.infinispan.configuration.parsing.Attribute
 
NODE_NAME - Static variable in class org.infinispan.configuration.global.TransportConfiguration
 
noDefaultCache() - Method in class org.infinispan.util.logging.Log_$logger
 
noDefaultCache() - Method in interface org.infinispan.util.logging.Log
 
noDefaultCache$str() - Method in class org.infinispan.util.logging.Log_$logger
 
nodeJoined(Address) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
nodeJoined(Address) - Method in interface org.infinispan.util.logging.events.Messages
 
nodeJoined$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
nodeLeft(Address) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
nodeLeft(Address) - Method in interface org.infinispan.util.logging.events.Messages
 
nodeLeft$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
nodeName() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
nodeName(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
Name of the current node.
nodeWithIncompatibleStateJoiningCache(Address, String) - Method in class org.infinispan.util.logging.Log_$logger
 
nodeWithIncompatibleStateJoiningCache(Address, String) - Method in interface org.infinispan.util.logging.Log
 
nodeWithIncompatibleStateJoiningCache$str() - Method in class org.infinispan.util.logging.Log_$logger
 
nodeWithoutPersistentStateJoiningCacheWithState(Address, String) - Method in class org.infinispan.util.logging.Log_$logger
 
nodeWithoutPersistentStateJoiningCacheWithState(Address, String) - Method in interface org.infinispan.util.logging.Log
 
nodeWithoutPersistentStateJoiningCacheWithState$str() - Method in class org.infinispan.util.logging.Log_$logger
 
nodeWithPersistentStateJoiningClusterWithoutState(Address, String) - Method in class org.infinispan.util.logging.Log_$logger
 
nodeWithPersistentStateJoiningClusterWithoutState(Address, String) - Method in interface org.infinispan.util.logging.Log
 
nodeWithPersistentStateJoiningClusterWithoutState$str() - Method in class org.infinispan.util.logging.Log_$logger
 
NODLD_NORECOVERY_NOXA - org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
 
NODLD_NORECOVERY_XA - org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
 
NODLD_RECOVERY_XA - org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
 
noFilter() - Method in interface org.infinispan.manager.ClusterExecutor
Applies no filtering and will send any invocations to any/all current nodes.
noFilterIndexingServiceProviderFound(String) - Method in class org.infinispan.util.logging.Log_$logger
 
noFilterIndexingServiceProviderFound(String) - Method in interface org.infinispan.util.logging.Log
 
noFilterIndexingServiceProviderFound$str() - Method in class org.infinispan.util.logging.Log_$logger
 
noFlags() - Method in interface org.infinispan.AdvancedCache
Unset all flags set on this cache using AdvancedCache.withFlags(Flag...) or AdvancedCache.withFlags(Collection) methods.
noFlags() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
noFlags() - Method in class org.infinispan.cache.impl.CacheImpl
 
noFlags() - Method in class org.infinispan.cache.impl.DecoratedCache
 
noFlags() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
noFlags() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
noIndexableClassesDefined() - Method in class org.infinispan.util.logging.Log_$logger
 
noIndexableClassesDefined() - Method in interface org.infinispan.util.logging.Log
 
noIndexableClassesDefined$str() - Method in class org.infinispan.util.logging.Log_$logger
 
noLiveOwnersFoundForSegments(Collection<Integer>, String, Collection<Address>) - Method in class org.infinispan.util.logging.Log_$logger
 
noLiveOwnersFoundForSegments(Collection<Integer>, String, Collection<Address>) - Method in interface org.infinispan.util.logging.Log
 
noLiveOwnersFoundForSegments$str() - Method in class org.infinispan.util.logging.Log_$logger
 
NON_DURABLE_XA - org.infinispan.configuration.cache.TransactionMode
 
NON_DURABLE_XA - org.infinispan.configuration.parsing.Parser.TransactionMode
 
NON_OWNER - org.infinispan.distribution.Ownership
This node is not an owner.
NON_TRANSACTIONAL - org.infinispan.transaction.TransactionMode
 
NON_XA - org.infinispan.configuration.cache.TransactionMode
 
NON_XA - org.infinispan.configuration.parsing.Parser.TransactionMode
 
nonBackupAddresses - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
nonClusteredDefault() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
Helper method that gets you a default constructed GlobalConfiguration, preconfigured for use in LOCAL mode
NONE - org.infinispan.configuration.cache.Index
No indexing is performed.
NONE - org.infinispan.configuration.cache.TransactionMode
 
NONE - org.infinispan.configuration.cache.VersioningScheme
 
NONE - org.infinispan.configuration.parsing.Parser.TransactionMode
 
NONE - org.infinispan.conflict.MergePolicy
 
NONE - org.infinispan.eviction.EvictionStrategy
Eviction Strategy where nothing is done by the cache and the user is probably not going to use eviction manually
NONE - org.infinispan.jmx.annotations.Units
 
NONE - org.infinispan.remoting.inboundhandler.DeliverOrder
The message is delivered as soon as it is received.
NONE - org.infinispan.security.AuthorizationPermission
No permissions
NONE - org.infinispan.statetransfer.RebalanceType
Used by local and invalidation cache modes.
NONE - org.infinispan.util.concurrent.IsolationLevel
No isolation.
noneMatch(DoublePredicate) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
noneMatch(DoublePredicate) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
noneMatch(DoublePredicate) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
noneMatch(IntPredicate) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
noneMatch(IntPredicate) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
noneMatch(IntPredicate) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
noneMatch(LongPredicate) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
noneMatch(LongPredicate) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
noneMatch(LongPredicate) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
noneMatch(Predicate<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
noneMatch(Predicate<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
noneMatch(Predicate<? super R>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
noneMatch(Predicate<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
noneMatch(Predicate<? super T>) - Method in interface org.infinispan.functional.Traversable
A terminal operation that returns whether no elements of this traversable match the provided predicate.
noneMatch(SerializableDoublePredicate) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleStream.noneMatch(DoublePredicate) except that the DoublePredicate must also implement Serializable
noneMatch(SerializableDoublePredicate) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
noneMatch(SerializableIntPredicate) - Method in interface org.infinispan.IntCacheStream
Same as IntStream.noneMatch(IntPredicate) except that the IntPredicate must also implement Serializable
noneMatch(SerializableIntPredicate) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
noneMatch(SerializableLongPredicate) - Method in interface org.infinispan.LongCacheStream
Same as LongStream.noneMatch(LongPredicate) except that the LongPredicate must also implement Serializable.
noneMatch(SerializableLongPredicate) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
noneMatch(SerializablePredicate<? super R>) - Method in interface org.infinispan.CacheStream
Same as Stream.noneMatch(Predicate) except that the Predicate must also implement Serializable
nonExistentEntryCanMatch() - Method in enum org.infinispan.commands.write.ValueMatcher
Deprecated.
Since 9.0, no longer used.
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
 
nonNullKeyFunction() - Method in class org.infinispan.stream.impl.AbstractCacheStream
 
nonNullPredicate() - Static method in class org.infinispan.stream.StreamMarshalling
Predicate that returns true if the object passed to it is not null.
nonSharedStoreConfiguredAsShared(String) - Method in class org.infinispan.util.logging.Log_$logger
 
nonSharedStoreConfiguredAsShared(String) - Method in interface org.infinispan.util.logging.Log
 
nonSharedStoreConfiguredAsShared$str() - Method in class org.infinispan.util.logging.Log_$logger
 
NonTotalOrderPerCacheInboundInvocationHandler - Class in org.infinispan.remoting.inboundhandler
A PerCacheInboundInvocationHandler implementation for non-total order caches.
NonTotalOrderPerCacheInboundInvocationHandler() - Constructor for class org.infinispan.remoting.inboundhandler.NonTotalOrderPerCacheInboundInvocationHandler
 
NonTotalOrderTxPerCacheInboundInvocationHandler - Class in org.infinispan.remoting.inboundhandler
A PerCacheInboundInvocationHandler implementation for non-total order caches.
NonTotalOrderTxPerCacheInboundInvocationHandler() - Constructor for class org.infinispan.remoting.inboundhandler.NonTotalOrderTxPerCacheInboundInvocationHandler
 
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
Deprecated.
Since 9.0, this class is going to be moved to an internal package.
NonTransactionalInvocationContextFactory() - Constructor for class org.infinispan.context.NonTransactionalInvocationContextFactory
Deprecated.
 
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, Address) - Constructor for class org.infinispan.context.impl.NonTxInvocationContext
 
NonTxInvocationContext(Address) - Constructor for class org.infinispan.context.impl.NonTxInvocationContext
 
nonTxLockAndInvokeNext(InvocationContext, VisitableCommand, LockPromise, InvocationFinallyAction) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
Locks and invoke the next interceptor for non-transactional commands.
nonWritableStateFile(File) - Method in class org.infinispan.util.logging.Log_$logger
 
nonWritableStateFile(File) - Method in interface org.infinispan.util.logging.Log
 
nonWritableStateFile$str() - Method in class org.infinispan.util.logging.Log_$logger
 
NoOpPendingLockManager - Class in org.infinispan.util.concurrent.locks.impl
An PendingLockManager implementation that does nothing.
normalizedHash(Hash, int) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
noSuchCacheConfiguration(String) - Method in class org.infinispan.util.logging.Log_$logger
 
noSuchCacheConfiguration(String) - Method in interface org.infinispan.util.logging.Log
 
noSuchCacheConfiguration$str() - Method in class org.infinispan.util.logging.Log_$logger
 
NOT_ASYNC - org.infinispan.persistence.manager.PersistenceManager.AccessMode
The operation is performed only in a CacheWriter or CacheLoader that doesn't have async write behind.
NOT_COMPLETED - org.infinispan.transaction.impl.TransactionTable.CompletedTransactionStatus
 
NOT_LOADED - Static variable in class org.infinispan.functional.MetaParam.MetaLoadedFromPersistence
 
NOT_LOCAL - org.infinispan.distribution.DataLocality
 
NOT_LOCAL_UNCERTAIN - org.infinispan.distribution.DataLocality
 
NOT_OWNED - org.infinispan.scattered.ScatteredVersionManager.SegmentState
 
NOT_READY - org.infinispan.remoting.inboundhandler.action.ActionStatus
The action isn't completed yet.
NOTHING - Static variable in interface org.infinispan.transaction.xa.recovery.RecoveryManager.RecoveryIterator
 
NotificationInterceptor - Class in org.infinispan.interceptors.impl
The interceptor in charge of firing off notifications to cache listeners
NotificationInterceptor() - Constructor for class org.infinispan.interceptors.impl.NotificationInterceptor
 
notifications() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
 
notifications(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
 
NOTIFICATIONS - org.infinispan.configuration.parsing.Attribute
 
NOTIFICATIONS - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
 
NOTIFIED - Static variable in interface org.infinispan.notifications.cachelistener.QueueingSegmentListener
 
notifiedKey(K) - Method in interface org.infinispan.notifications.cachelistener.QueueingSegmentListener
This should invoked after the key has been successfully processed to tell the handler that the key is done.
notifier - Variable in class org.infinispan.cache.impl.CacheImpl
 
notifier - Variable in class org.infinispan.commands.tx.PrepareCommand
 
notifier - Variable in class org.infinispan.commands.write.InvalidateCommand
 
notifier - Variable in class org.infinispan.commands.write.RemoveCommand
 
notifier - Variable in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
notifier - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
notifier - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
notify(InvocationContext, Object, Metadata, boolean) - Method in class org.infinispan.commands.write.EvictCommand
 
notify(InvocationContext, Object, Metadata, boolean) - Method in class org.infinispan.commands.write.RemoveCommand
 
notify(InvocationContext, Object, Metadata, boolean) - Method in class org.infinispan.commands.write.RemoveExpiredCommand
 
notify(InvocationContext, MVCCEntry, boolean) - Method in class org.infinispan.commands.write.InvalidateCommand
 
notifyCacheEntriesEvicted(Collection<InternalCacheEntry<? extends K, ? extends V>>, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntriesEvictedEvent event.
notifyCacheEntriesEvicted(Collection<InternalCacheEntry<? extends K, ? extends V>>, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryActivated(K, V, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryActivatedEvent event.
notifyCacheEntryActivated(K, V, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryCreated(K, V, Metadata, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryCreatedEvent event.
notifyCacheEntryCreated(K, V, Metadata, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryExpired(K, V, Metadata, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryExpired event.
notifyCacheEntryExpired(K, V, Metadata, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryInvalidated(K, V, Metadata, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryInvalidatedEvent event.
notifyCacheEntryInvalidated(K, V, Metadata, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryLoaded(K, V, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryLoadedEvent event.
notifyCacheEntryLoaded(K, V, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryModified(K, V, Metadata, V, Metadata, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryModifiedEvent event.
notifyCacheEntryModified(K, V, Metadata, V, Metadata, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryPassivated(K, V, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryPassivatedEvent event.
notifyCacheEntryPassivated(K, V, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryRemoved(K, V, Metadata, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryRemovedEvent event.
notifyCacheEntryRemoved(K, V, Metadata, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheEntryVisited(K, V, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a CacheEntryVisitedEvent event.
notifyCacheEntryVisited(K, V, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyCacheStarted(String) - Method in class org.infinispan.factories.GlobalComponentRegistry
 
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
 
notifyClusterListeners(Collection<? extends CacheEntryEvent<K, V>>, UUID) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyClusterListeners(Collection<? extends CacheEntryEvent<K, V>>, UUID) - Method in interface org.infinispan.notifications.cachelistener.cluster.ClusterCacheNotifier
Method that is invoked on the node that has the given cluster listener that when registered generated the given listenerId.
notifyDataRehashed(ConsistentHash, ConsistentHash, ConsistentHash, int, boolean) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
 
notifyDataRehashed(ConsistentHash, ConsistentHash, ConsistentHash, int, boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyEndOfStateTransferIfNeeded() - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
notifyFinish(LongConsumer) - Method in class org.infinispan.remoting.transport.AggregateBackupResponse
 
notifyFinish(LongConsumer) - Method in interface org.infinispan.remoting.transport.BackupResponse
Registers a listener that is notified when the cross-site request is finished.
notifyFinish(LongConsumer) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsBackupResponse
 
NotifyHelper - Class in org.infinispan.notifications.cachelistener
 
NotifyHelper() - Constructor for class org.infinispan.notifications.cachelistener.NotifyHelper
 
notifyKeyTransferFinished(int, boolean, boolean) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
notifyKeyTransferFinished(int, boolean, boolean) - Method in interface org.infinispan.scattered.ScatteredVersionManager
All key + version data from given segment have been received, or the key transfer failed.
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
 
notifyOnCreate(CacheEntry) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
 
notifyOnCreate(CacheEntry<K, V>) - Method in interface org.infinispan.functional.impl.FunctionalNotifier
Notify registered Listeners.ReadWriteListeners.ReadWriteListener instances of the created entry.
notifyOnModify(CacheEntry<K, V>, V, Metadata) - Method in interface org.infinispan.functional.impl.FunctionalNotifier
Notify registered Listeners.ReadWriteListeners.ReadWriteListener instances of the modified entry passing the previous and new value.
notifyOnModify(CacheEntry<K, V>, V, Metadata) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
 
notifyOnRemove(EntryView.ReadEntryView<K, V>) - Method in interface org.infinispan.functional.impl.FunctionalNotifier
Notify registered Listeners.ReadWriteListeners.ReadWriteListener instances of the removed entry passing in the removed entry.
notifyOnRemove(EntryView.ReadEntryView<K, V>) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
 
notifyOnTransactionFinished() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
notifyOnTransactionFinished() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
notifyOnWrite(CacheEntry<K, V>) - Method in interface org.infinispan.functional.impl.FunctionalNotifier
 
notifyOnWrite(CacheEntry<K, V>) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
 
notifyOnWriteRemove(K) - Method in interface org.infinispan.functional.impl.FunctionalNotifier
Notify registered Listeners.WriteListeners.WriteListener instances of the written entry.
notifyOnWriteRemove(K) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
 
notifyPartitionStatusChanged(AvailabilityMode, boolean) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
 
notifyPartitionStatusChanged(AvailabilityMode, boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyPersistenceAvailabilityChanged(boolean) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
 
notifyPersistenceAvailabilityChanged(boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyStatePushFinished(String, Address, boolean) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
It receives the notifications from local site when some node finishes pushing the state to the remote site.
notifyStatePushFinished(String, Address, boolean) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
notifyStateTransferEnd() - Method in class org.infinispan.transaction.totalorder.TotalOrderManager
It notifies the end of the state transfer possibly unblock waiting prepares.
notifyStateTransferStart(int, boolean) - Method in class org.infinispan.transaction.totalorder.TotalOrderManager
It notifies that a state transfer is about to start.
notifyTopologyChanged(CacheTopology, CacheTopology, int, boolean) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
 
notifyTopologyChanged(CacheTopology, CacheTopology, 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, boolean) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
Notifies all registered listeners of a transaction registration event.
notifyTransactionRegistered(GlobalTransaction, boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
notifyValueTransferFinished() - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
notifyValueTransferFinished() - Method in interface org.infinispan.scattered.ScatteredVersionManager
All entries have been received and we can put segments owned according to consistent hash to ScatteredVersionManager.SegmentState.OWNED state.
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(KeyFilter) - Static method in class org.infinispan.persistence.PersistenceUtil
 
notStartingEvictionThread() - Method in class org.infinispan.util.logging.Log_$logger
 
notStartingEvictionThread() - Method in interface org.infinispan.util.logging.Log
 
notStartingEvictionThread$str() - Method in class org.infinispan.util.logging.Log_$logger
 
notSupportedInSimpleCache() - Method in class org.infinispan.util.logging.Log_$logger
 
notSupportedInSimpleCache() - Method in interface org.infinispan.util.logging.Log
 
notSupportedInSimpleCache$str() - Method in class org.infinispan.util.logging.Log_$logger
 
noValue(Object) - Static method in class org.infinispan.functional.impl.EntryViews
 
noValue(Object, DataConversion) - Static method in class org.infinispan.functional.impl.EntryViews
 
NoValueReadOnlyViewExternalizer() - Constructor for class org.infinispan.functional.impl.EntryViews.NoValueReadOnlyViewExternalizer
 
NullAuditLogger - Class in org.infinispan.security.impl
NullAuditLogger.
NullAuditLogger() - Constructor for class org.infinispan.security.impl.NullAuditLogger
 
NullCacheEntry<K,​V> - Class in org.infinispan.container.entries
 
NUM_OWNERS - Static variable in class org.infinispan.configuration.cache.HashConfiguration
 
NUM_SEGMENTS - Static variable in class org.infinispan.configuration.cache.HashConfiguration
 
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 - Variable in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
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.
numSegments - Variable in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
numSegments - Variable in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
numSegments() - Method in class org.infinispan.configuration.cache.HashConfiguration
Controls the total number of hash space segments (per cluster).
numSegments(int) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
Controls the total number of hash space segments (per cluster).
numVirtualNodes(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 - org.infinispan.configuration.cache.StorageType
Objects are stored on heap as objects as provided.
OBJECT - org.infinispan.configuration.parsing.Element
 
OBJECT_NAME - Static variable in class org.infinispan.cache.impl.CacheImpl
 
OBJECT_NAME - Static variable in interface org.infinispan.health.jmx.HealthJMXExposer
JMX Object name.
OBJECT_NAME - Static variable in class org.infinispan.manager.DefaultCacheManager
 
OBJECT_NAME - Static variable in interface org.infinispan.stats.CacheContainerStats
 
objectFromByteBuffer(byte[]) - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
objectFromInputStream(InputStream) - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
objectFromObjectStream(ObjectInput) - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
objectName() - Method in annotation type org.infinispan.jmx.annotations.MBean
 
objectToBuffer(Object) - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
objectToByteBuffer(Object) - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
objectToByteBuffer(Object, int) - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
objectToObjectStream(Object, ObjectOutput) - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
observation - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
observation() - Method in annotation type org.infinispan.notifications.Listener
Returns the type of observation level this listener defines.
of(boolean) - Static method in class org.infinispan.functional.MetaParam.MetaLoadedFromPersistence
 
of(Class<?>) - Static method in class org.infinispan.factories.impl.ComponentAlias
 
of(String) - Static method in class org.infinispan.factories.impl.ComponentAlias
 
of(Stream<T>) - Static method in class org.infinispan.functional.impl.Traversables
 
OFF_HEAP - org.infinispan.configuration.cache.StorageType
Entries are stored in internal memory off the normal Java heap.
OFFHEAP - org.infinispan.configuration.parsing.Element
 
OffHeapConcurrentMap - Class in org.infinispan.container.offheap
 
OffHeapConcurrentMap(int, OffHeapMemoryAllocator, OffHeapEntryFactory, OffHeapConcurrentMap.EntryListener) - Constructor for class org.infinispan.container.offheap.OffHeapConcurrentMap
 
OffHeapConcurrentMap.EntryListener - Interface in org.infinispan.container.offheap
Listener interface that is notified when certain operations occur for various memory addresses.
OffHeapDataContainer - Class in org.infinispan.container.offheap
 
OffHeapDataContainer(int) - Constructor for class org.infinispan.container.offheap.OffHeapDataContainer
 
offHeapEntryFactory - Variable in class org.infinispan.container.offheap.OffHeapDataContainer
 
offHeapEntryFactory - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
OffHeapEntryFactory - Interface in org.infinispan.container.offheap
Factory that can create InternalCacheEntry objects that use off-heap heap memory.
OffHeapEntryFactoryImpl - Class in org.infinispan.container.offheap
Factory that can create CacheEntry instances from off-heap memory.
OffHeapEntryFactoryImpl() - Constructor for class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
 
OffHeapMemoryAllocator - Interface in org.infinispan.container.offheap
Allows for allocation of memory outside of the heap as well additional functionality surrounding it if necessary.
offHeapMemoryEvictionNotSupportedWithObject() - Method in class org.infinispan.util.logging.Log_$logger
 
offHeapMemoryEvictionNotSupportedWithObject() - Method in interface org.infinispan.util.logging.Log
 
offHeapMemoryEvictionNotSupportedWithObject$str() - Method in class org.infinispan.util.logging.Log_$logger
 
offHeapMemoryEvictionSizeNotLargeEnoughForAddresses(long, long, int) - Method in class org.infinispan.util.logging.Log_$logger
 
offHeapMemoryEvictionSizeNotLargeEnoughForAddresses(long, long, int) - Method in interface org.infinispan.util.logging.Log
 
offHeapMemoryEvictionSizeNotLargeEnoughForAddresses$str() - Method in class org.infinispan.util.logging.Log_$logger
 
offline - Variable in class org.infinispan.xsite.status.AbstractMixedSiteStatus
 
OFFLINE - org.infinispan.xsite.XSiteAdminCommand.Status
 
OFFLINE - Static variable in class org.infinispan.xsite.XSiteAdminOperations
 
offlineOn(E) - Method in class org.infinispan.xsite.status.AbstractSiteStatusBuilder
Adds the member with an offline connection to the site.
OfflineSiteStatus - Class in org.infinispan.xsite.status
SiteStatus implementation for offline sites.
OfflineStatus - Class in org.infinispan.xsite
Keeps state needed for knowing when a site needs to be taken offline.
OfflineStatus(TakeOfflineConfiguration, TimeService, SiteStatusListener) - Constructor for class org.infinispan.xsite.OfflineStatus
 
oldMetadata - Variable in class org.infinispan.container.entries.RepeatableReadEntry
 
oldValue - Variable in class org.infinispan.container.entries.RepeatableReadEntry
 
ON_READ - org.infinispan.configuration.cache.BiasAcquisition
Bias is acquired when the entry is read TODO: Not implemented yet
ON_REHASH - org.infinispan.configuration.parsing.Attribute
 
ON_WRITE - org.infinispan.configuration.cache.BiasAcquisition
Bias is acquired by the writing entry.
onClose(Runnable) - Method in interface org.infinispan.CacheStream
onClose(Runnable) - Method in interface org.infinispan.DoubleCacheStream
onClose(Runnable) - Method in interface org.infinispan.IntCacheStream
onClose(Runnable) - Method in interface org.infinispan.LongCacheStream
onClose(Runnable) - Method in class org.infinispan.stream.impl.AbstractCacheStream
 
onClose(Runnable) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
onClose(Runnable) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
onClose(Runnable) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
onClose(Runnable) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
onClose(Runnable) - Method in interface org.infinispan.stream.impl.IteratorHandler.OnCloseIterator
Register a runnable to be invoked when this iterator is closed
onClose(Runnable) - Method in class org.infinispan.stream.impl.local.AbstractLocalCacheStream
 
onClose(Runnable) - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
onClose(Runnable) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
onCloseRunnables - Variable in class org.infinispan.stream.impl.local.AbstractLocalCacheStream
 
onClusterViewChange(AvailabilityStrategyContext, List<Address>) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategy
Called when the cluster view changed (e.g.
onClusterViewChange(AvailabilityStrategyContext, List<Address>) - Method in class org.infinispan.partitionhandling.impl.PreferAvailabilityStrategy
 
onClusterViewChange(AvailabilityStrategyContext, List<Address>) - Method in class org.infinispan.partitionhandling.impl.PreferConsistencyStrategy
 
onComplete() - Method in interface org.infinispan.remoting.inboundhandler.action.ActionListener
Invoked when an Action is completed.
onComplete() - Method in class org.infinispan.remoting.inboundhandler.action.CompositeAction
 
onComplete() - Method in class org.infinispan.remoting.inboundhandler.action.DefaultReadyAction
 
onCompletion() - Method in interface org.infinispan.transaction.xa.CacheTransaction.TransactionCompletedListener
 
onCompletion(Address, IntSet, R) - Method in interface org.infinispan.stream.impl.ClusterStreamManager.ResultsCallback
Essentially the same as ClusterStreamManager.ResultsCallback.onIntermediateResult(Address address, Object) except that this is the last time this callback will be invoked and it tells which segments were completed
onCreate(Consumer<EntryView.ReadEntryView<K, V>>) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
 
onCreate(Consumer<EntryView.ReadEntryView<K, V>>) - Method in interface org.infinispan.functional.Listeners.ReadWriteListeners
Add a create event specific listener by passing in a Consumer to be called back each time a new cache entry is created, passing in a EntryView.ReadEntryView of that new entry.
onCreate(EntryView.ReadEntryView<K, V>) - Method in interface org.infinispan.functional.Listeners.ReadWriteListeners.ReadWriteListener
Entry created event callback that receives a EntryView.ReadEntryView of the created entry.
onDataRehash(DataRehashedEvent) - Method in class org.infinispan.conflict.impl.StateReceiverImpl
 
onEntryEviction(Map<? extends K, InternalCacheEntry<? extends K, ? extends V>>) - Method in interface org.infinispan.eviction.EvictionManager
Handles notifications of evicted entries
onEntryEviction(Map<? extends K, InternalCacheEntry<? extends K, ? extends V>>) - Method in class org.infinispan.eviction.impl.EvictionManagerImpl
 
onEntryValueReplaced(Object, InternalCacheEntry) - Method in class org.infinispan.context.impl.AbstractInvocationContext
Deprecated.
Since 8.1, no longer used.
onePhaseCommit - Variable in class org.infinispan.commands.tx.PrepareCommand
 
onEvent(Object, LockState) - Method in interface org.infinispan.util.concurrent.locks.KeyAwareLockListener
Invoked when the lock is available.
onEvent(LockState) - Method in class org.infinispan.remoting.inboundhandler.action.LockAction
 
onEvent(LockState) - Method in class org.infinispan.remoting.inboundhandler.NonTotalOrderPerCacheInboundInvocationHandler
 
onEvent(LockState) - Method in class org.infinispan.remoting.inboundhandler.TrianglePerCacheInboundInvocationHandler
 
onEvent(LockState) - Method in interface org.infinispan.util.concurrent.locks.LockListener
Invoked when the lock is available.
onException() - Method in class org.infinispan.remoting.inboundhandler.action.CompositeAction
 
onException() - Method in class org.infinispan.remoting.inboundhandler.action.DefaultReadyAction
 
onException() - Method in interface org.infinispan.remoting.inboundhandler.action.ReadyAction
Cleanup when the command throws an exception while executing.
onException(Throwable) - Method in class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
 
onException(ActionState) - Method in interface org.infinispan.remoting.inboundhandler.action.Action
Invoked when an exception occurs while processing the command.
onException(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.LockAction
 
onFinally() - Method in class org.infinispan.remoting.inboundhandler.action.CompositeAction
 
onFinally() - Method in class org.infinispan.remoting.inboundhandler.action.DefaultReadyAction
 
onFinally() - Method in interface org.infinispan.remoting.inboundhandler.action.ReadyAction
Invoked always after the command is executed and the reply is sent.
onFinally() - Method in class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
 
onFinally(ActionState) - Method in interface org.infinispan.remoting.inboundhandler.action.Action
Invoked always after the command is executed.
onFinally(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.TriangleOrderAction
 
onFinally(ActionState) - Method in class org.infinispan.remoting.inboundhandler.TrianglePerCacheInboundInvocationHandler
 
onGracefulLeave(AvailabilityStrategyContext, Address) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategy
Called when a node leaves gracefully.
onGracefulLeave(AvailabilityStrategyContext, Address) - Method in class org.infinispan.partitionhandling.impl.PreferAvailabilityStrategy
 
onGracefulLeave(AvailabilityStrategyContext, Address) - Method in class org.infinispan.partitionhandling.impl.PreferConsistencyStrategy
 
onIntermediateResult(Address, R) - Method in interface org.infinispan.stream.impl.ClusterStreamManager.ResultsCallback
Called back for intermediate data returned from an operation.
onJoin(AvailabilityStrategyContext, Address) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategy
Called when a node joins.
onJoin(AvailabilityStrategyContext, Address) - Method in class org.infinispan.partitionhandling.impl.PreferAvailabilityStrategy
 
onJoin(AvailabilityStrategyContext, Address) - Method in class org.infinispan.partitionhandling.impl.PreferConsistencyStrategy
 
onKeysLost(Collection<?>) - Method in interface org.infinispan.interceptors.distribution.BaseDistributionInterceptor.RemoteGetAllHandler
 
online - Variable in class org.infinispan.xsite.status.AbstractMixedSiteStatus
 
ONLINE - org.infinispan.xsite.XSiteAdminCommand.Status
 
ONLINE - Static variable in class org.infinispan.xsite.XSiteAdminOperations
 
onlineOn(E) - Method in class org.infinispan.xsite.status.AbstractSiteStatusBuilder
Adds the element with an online connection to the site.
OnlineSiteStatus - Class in org.infinispan.xsite.status
SiteStatus implementation for online sites.
onlyOneFetchPersistentStoreAllowed() - Method in class org.infinispan.util.logging.Log_$logger
 
onlyOneFetchPersistentStoreAllowed() - Method in interface org.infinispan.util.logging.Log
 
onlyOneFetchPersistentStoreAllowed$str() - Method in class org.infinispan.util.logging.Log_$logger
 
onlyPrimary - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
onManualAvailabilityChange(AvailabilityStrategyContext, AvailabilityMode) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategy
Called when the administrator manually changes the availability status.
onManualAvailabilityChange(AvailabilityStrategyContext, AvailabilityMode) - Method in class org.infinispan.partitionhandling.impl.PreferAvailabilityStrategy
 
onManualAvailabilityChange(AvailabilityStrategyContext, AvailabilityMode) - Method in class org.infinispan.partitionhandling.impl.PreferConsistencyStrategy
 
onMembersChange(Collection<Address>) - Method in class org.infinispan.util.concurrent.CommandAckCollector
Notifies a change in member list.
onModify(BiConsumer<EntryView.ReadEntryView<K, V>, EntryView.ReadEntryView<K, V>>) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
 
onModify(BiConsumer<EntryView.ReadEntryView<K, V>, EntryView.ReadEntryView<K, V>>) - Method in interface org.infinispan.functional.Listeners.ReadWriteListeners
Add a modify/update event specific listener by passing in a BiConsumer to be called back each time an entry is modified or updated, passing in a EntryView.ReadEntryView of the previous entry as first parameter, and a EntryView.ReadEntryView of the new value as second parameter.
onModify(EntryView.ReadEntryView<K, V>, EntryView.ReadEntryView<K, V>) - Method in interface org.infinispan.functional.Listeners.ReadWriteListeners.ReadWriteListener
Entry modify/update event callback that receives EntryView.ReadEntryView of the previous entry as first parameter, and the EntryView.ReadEntryView of the new entry.
onNewView(Set<Address>) - Method in class org.infinispan.remoting.transport.impl.MultiTargetRequest
 
onNewView(Set<Address>) - Method in interface org.infinispan.remoting.transport.impl.Request
Called when the node received a new cluster view.
onNewView(Set<Address>) - Method in class org.infinispan.remoting.transport.impl.SingleTargetRequest
 
onNewView(Set<Address>) - Method in class org.infinispan.remoting.transport.jgroups.SingleSiteRequest
 
onPartitionMerge(AvailabilityStrategyContext, Map<Address, CacheStatusResponse>) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategy
Called when two or more partitions merge, to compute the stable and current cache topologies for the merged cluster.
onPartitionMerge(AvailabilityStrategyContext, Map<Address, CacheStatusResponse>) - Method in class org.infinispan.partitionhandling.impl.PreferAvailabilityStrategy
 
onPartitionMerge(AvailabilityStrategyContext, Map<Address, CacheStatusResponse>) - Method in class org.infinispan.partitionhandling.impl.PreferConsistencyStrategy
 
onPostExecute(Callable<T>) - Method in class org.infinispan.distexec.spi.DefaultDistributedTaskLifecycle
 
onPostExecute(Callable<T>) - Method in interface org.infinispan.distexec.spi.DistributedTaskLifecycle
 
onPostExecute(Callable<T>) - Method in class org.infinispan.distexec.spi.DistributedTaskLifecycleService
 
onPreExecute(Callable<T>, Cache<K, V>, Collection<K>) - Method in class org.infinispan.distexec.spi.DefaultDistributedTaskLifecycle
 
onPreExecute(Callable<T>, Cache<K, V>, Collection<K>) - Method in interface org.infinispan.distexec.spi.DistributedTaskLifecycle
 
onPreExecute(Callable<T>, Cache<K, V>, Collection<K>) - Method in class org.infinispan.distexec.spi.DistributedTaskLifecycleService
 
onReady() - Method in class org.infinispan.remoting.inboundhandler.action.PendingTxAction
 
onReady() - Method in interface org.infinispan.util.concurrent.locks.PendingLockListener
Invoked when PendingLockPromise is ready.
onRebalanceEnd(AvailabilityStrategyContext) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategy
Called when a rebalance ends.
onRebalanceEnd(AvailabilityStrategyContext) - Method in class org.infinispan.partitionhandling.impl.PreferAvailabilityStrategy
 
onRebalanceEnd(AvailabilityStrategyContext) - Method in class org.infinispan.partitionhandling.impl.PreferConsistencyStrategy
 
onRemove(Object, boolean) - Method in interface org.infinispan.eviction.ActivationManager
Remove key and associated value from cache store and update the activation counter.
onRemove(Object, boolean) - Method in class org.infinispan.eviction.impl.ActivationManagerImpl
 
onRemove(Object, boolean) - Method in class org.infinispan.eviction.impl.ActivationManagerStub
 
onRemove(Consumer<EntryView.ReadEntryView<K, V>>) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
 
onRemove(Consumer<EntryView.ReadEntryView<K, V>>) - Method in interface org.infinispan.functional.Listeners.ReadWriteListeners
Add a remove event specific listener by passing in a Consumer to be called back each time an entry is removed, passing in the EntryView.ReadEntryView of the removed entry.
onRemove(EntryView.ReadEntryView<K, V>) - Method in interface org.infinispan.functional.Listeners.ReadWriteListeners.ReadWriteListener
Entry removed event callback that receives a EntryView.ReadEntryView of the removed entry.
onResponse(Address, Response) - Method in class org.infinispan.remoting.transport.impl.MultiTargetRequest
 
onResponse(Address, Response) - Method in interface org.infinispan.remoting.transport.impl.Request
Called when a response is received for this response.
onResponse(Address, Response) - Method in class org.infinispan.remoting.transport.impl.SingleTargetRequest
 
onResponse(Address, Response) - Method in class org.infinispan.remoting.transport.jgroups.SingleSiteRequest
 
onResponse(Address, Response) - Method in class org.infinispan.remoting.transport.jgroups.StaggeredRequest
 
onSegmentsLost(IntSet) - Method in interface org.infinispan.stream.impl.ClusterStreamManager.ResultsCallback
Called back when a segment is found to have been lost that is no longer remote This method should return as soon as possible and not block in any fashion.
onStateReceived(int, boolean) - Method in class org.infinispan.statetransfer.InboundTransferTask
 
onTaskCompletion(InboundTransferTask) - Method in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
onTaskCompletion(InboundTransferTask) - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
onTaskCompletion(OutboundTransferTask) - Method in class org.infinispan.statetransfer.StateProviderImpl
 
onTimeout() - Method in class org.infinispan.remoting.transport.AbstractRequest
Called when the timeout task scheduled with AbstractRequest.setTimeout(ScheduledExecutorService, long, TimeUnit) expires.
onTimeout() - Method in class org.infinispan.remoting.transport.impl.MultiTargetRequest
 
onTimeout() - Method in class org.infinispan.remoting.transport.impl.SingleTargetRequest
 
onTimeout() - Method in class org.infinispan.remoting.transport.jgroups.SingleSiteRequest
 
onTimeout() - Method in class org.infinispan.remoting.transport.jgroups.StaggeredRequest
 
onTopologyChange(TopologyChangedEvent) - Method in class org.infinispan.scattered.impl.BiasManagerImpl
 
onTopologyChange(TopologyChangedEvent<?, ?>) - Method in class org.infinispan.container.versioning.SimpleClusteredVersionGenerator.TopologyIdUpdater
 
onTopologyChange(TopologyChangedEvent<?, ?>) - Method in class org.infinispan.transaction.impl.TransactionTable
 
onTopologyUpdate(CacheTopology) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
onTopologyUpdate(CacheTopology) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
Notifies the PartitionHandlingManager that the cache topology was update.
onTopologyUpdate(CacheTopology) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
onTopologyUpdate(CacheTopology, boolean) - Method in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
onTopologyUpdate(CacheTopology, boolean) - Method in class org.infinispan.scattered.impl.ScatteredStateProviderImpl
 
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
 
onUnsureResponse() - Method in interface org.infinispan.interceptors.distribution.BaseDistributionInterceptor.RemoteGetAllHandler
 
onUpdate(Object, boolean) - Method in interface org.infinispan.eviction.ActivationManager
Remove key and associated value from cache store and update the activation counter.
onUpdate(Object, boolean) - Method in class org.infinispan.eviction.impl.ActivationManagerImpl
 
onUpdate(Object, boolean) - Method in class org.infinispan.eviction.impl.ActivationManagerStub
 
onViewChange(ViewChangedEvent) - Method in class org.infinispan.transaction.impl.TransactionTable
 
onWrite(Consumer<EntryView.ReadEntryView<K, V>>) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
 
onWrite(Consumer<EntryView.ReadEntryView<K, V>>) - Method in interface org.infinispan.functional.Listeners.WriteListeners
Add a write event listener by passing in a Consumer to be called each time a cache entry is created, modified/updated or removed.
onWrite(EntryView.ReadEntryView<K, V>) - Method in interface org.infinispan.functional.Listeners.WriteListeners.WriteListener
Entry write event callback that receives a EntryView.ReadEntryView of the written entry.
open() - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
openIterators() - Method in class org.infinispan.stream.impl.IteratorHandler
Returns how many iterators are currently open
OPERATION_HOTROD - org.infinispan.context.Flag
Flag to identify cache operations coming from the Hot Rod server.
OPERATION_HOTROD - Static variable in class org.infinispan.context.impl.FlagBitSets
 
OPERATION_MEMCACHED - org.infinispan.context.Flag
Flag to identify cache operations coming from the Memcached server.
OPERATION_MEMCACHED - Static variable in class org.infinispan.context.impl.FlagBitSets
 
OPTIMISTIC - org.infinispan.transaction.LockingMode
 
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
 
OptionalExternalizer - Class in org.infinispan.marshall.exts
 
OptionalExternalizer() - Constructor for class org.infinispan.marshall.exts.OptionalExternalizer
 
orderedUpdatesManager - Variable in class org.infinispan.commands.write.InvalidateVersionsCommand
 
OrderedUpdatesManager - Interface in org.infinispan.persistence.manager
 
OrderedUpdatesManagerImpl - Class in org.infinispan.persistence.manager
 
OrderedUpdatesManagerImpl() - Constructor for class org.infinispan.persistence.manager.OrderedUpdatesManagerImpl
 
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
This package contains the KeyAffinityService interfaces which allow user code to determine mapping of keys onto nodes
org.infinispan.affinity.impl - package org.infinispan.affinity.impl
 
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.atomic.impl - package org.infinispan.atomic.impl
 
org.infinispan.batch - package org.infinispan.batch
Support for batching calls using the BatchingCache.startBatch() and BatchingCache.endBatch(boolean) API.
org.infinispan.cache.impl - package org.infinispan.cache.impl
 
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.functional - package org.infinispan.commands.functional
 
org.infinispan.commands.functional.functions - package org.infinispan.commands.functional.functions
 
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.expiration - package org.infinispan.commands.remote.expiration
 
org.infinispan.commands.remote.recovery - package org.infinispan.commands.remote.recovery
 
org.infinispan.commands.triangle - package org.infinispan.commands.triangle
 
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.compat - package org.infinispan.compat
 
org.infinispan.configuration - package org.infinispan.configuration
 
org.infinispan.configuration.cache - package org.infinispan.configuration.cache
Cache configuration
org.infinispan.configuration.format - package org.infinispan.configuration.format
 
org.infinispan.configuration.global - package org.infinispan.configuration.global
EmbeddedCacheManager configuration
org.infinispan.configuration.internal - package org.infinispan.configuration.internal
A private configuration package.
org.infinispan.configuration.parsing - package org.infinispan.configuration.parsing
 
org.infinispan.configuration.serializing - package org.infinispan.configuration.serializing
 
org.infinispan.conflict - package org.infinispan.conflict
This package contains the APIs that enable users to search for, and amend, data inconsistencies within their cache.
org.infinispan.conflict.impl - package org.infinispan.conflict.impl
This package contains implementations of the conflict resolution API.
org.infinispan.container - package org.infinispan.container
Package that contains the interface describing the underlyling API for storage in Infinispan
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.impl - package org.infinispan.container.impl
Data containers which store cache entries.
org.infinispan.container.offheap - package org.infinispan.container.offheap
 
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
Distributed Executor APIs (deprecated)
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
Consistent Hash interfaces
org.infinispan.distribution.ch.impl - package org.infinispan.distribution.ch.impl
 
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.group.impl - package org.infinispan.distribution.group.impl
 
org.infinispan.distribution.impl - package org.infinispan.distribution.impl
 
org.infinispan.distribution.topologyaware - package org.infinispan.distribution.topologyaware
 
org.infinispan.distribution.util - package org.infinispan.distribution.util
 
org.infinispan.encoding - package org.infinispan.encoding
 
org.infinispan.eviction - package org.infinispan.eviction
Classes related to eviction.
org.infinispan.eviction.impl - package org.infinispan.eviction.impl
 
org.infinispan.executors - package org.infinispan.executors
Implementations of different executors used for asynchronous operation.
org.infinispan.expiration - package org.infinispan.expiration
Cache expiration.
org.infinispan.expiration.impl - package org.infinispan.expiration.impl
 
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.impl - package org.infinispan.factories.impl
 
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.factories.threads - package org.infinispan.factories.threads
 
org.infinispan.filter - package org.infinispan.filter
Provides capabilities around filtering and converting entries that are found in the cache or cache store/loader.
org.infinispan.functional - package org.infinispan.functional
Functional API package
org.infinispan.functional.impl - package org.infinispan.functional.impl
 
org.infinispan.globalstate - package org.infinispan.globalstate
 
org.infinispan.globalstate.impl - package org.infinispan.globalstate.impl
 
org.infinispan.health - package org.infinispan.health
 
org.infinispan.health.impl - package org.infinispan.health.impl
 
org.infinispan.health.impl.jmx - package org.infinispan.health.impl.jmx
 
org.infinispan.health.jmx - package org.infinispan.health.jmx
 
org.infinispan.interceptors - package org.infinispan.interceptors
Infinispan is designed around a set of interceptors around a data container.
org.infinispan.interceptors.base - package org.infinispan.interceptors.base
Base interceptors containing common, reusable behavior.
org.infinispan.interceptors.distribution - package org.infinispan.interceptors.distribution
Interceptors dealing with command replication in distributed/replicated mode.
org.infinispan.interceptors.impl - package org.infinispan.interceptors.impl
Basic interceptors
org.infinispan.interceptors.locking - package org.infinispan.interceptors.locking
Interceptors dealing with locking.
org.infinispan.interceptors.totalorder - package org.infinispan.interceptors.totalorder
Interceptors dealing with total order.
org.infinispan.interceptors.xsite - package org.infinispan.interceptors.xsite
Interceptors dealing with cross-site replication.
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.manager - package org.infinispan.manager
Cache manager API.
org.infinispan.manager.impl - package org.infinispan.manager.impl
 
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
Metadata interfaces
org.infinispan.metadata.impl - package org.infinispan.metadata.impl
 
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
Cache-specific listener annotations
org.infinispan.notifications.cachelistener.cluster - package org.infinispan.notifications.cachelistener.cluster
 
org.infinispan.notifications.cachelistener.cluster.impl - package org.infinispan.notifications.cachelistener.cluster.impl
 
org.infinispan.notifications.cachelistener.event - package org.infinispan.notifications.cachelistener.event
Cache-specific listener events
org.infinispan.notifications.cachelistener.event.impl - package org.infinispan.notifications.cachelistener.event.impl
 
org.infinispan.notifications.cachelistener.filter - package org.infinispan.notifications.cachelistener.filter
Cache-specific notifications and eventing filtering classes.
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
EmbeddedCacheManager-specific listener annotations
org.infinispan.notifications.cachemanagerlistener.event - package org.infinispan.notifications.cachemanagerlistener.event
EmbeddedCacheManager-specific listener events
org.infinispan.notifications.cachemanagerlistener.event.impl - package org.infinispan.notifications.cachemanagerlistener.event.impl
 
org.infinispan.notifications.impl - package org.infinispan.notifications.impl
 
org.infinispan.partitionhandling - package org.infinispan.partitionhandling
 
org.infinispan.partitionhandling.impl - package org.infinispan.partitionhandling.impl
 
org.infinispan.persistence - package org.infinispan.persistence
Persistence API.
org.infinispan.persistence.async - package org.infinispan.persistence.async
 
org.infinispan.persistence.cluster - package org.infinispan.persistence.cluster
A CacheLoader (not CacheWriter) that polls other nodes in the cluster for state.
org.infinispan.persistence.factory - package org.infinispan.persistence.factory
 
org.infinispan.persistence.file - package org.infinispan.persistence.file
Simple filesystem-based CacheWriter implementation.
org.infinispan.persistence.internal - package org.infinispan.persistence.internal
 
org.infinispan.persistence.keymappers - package org.infinispan.persistence.keymappers
 
org.infinispan.persistence.manager - package org.infinispan.persistence.manager
Implementations of the PersistenceManager interface, which define the logic of how infinispan interacts with external stores.
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.spi - package org.infinispan.persistence.spi
The Persistence SPI.
org.infinispan.persistence.support - package org.infinispan.persistence.support
 
org.infinispan.persistence.util - package org.infinispan.persistence.util
 
org.infinispan.registry - package org.infinispan.registry
The internal cache registry API
org.infinispan.registry.impl - package org.infinispan.registry.impl
 
org.infinispan.remoting - package org.infinispan.remoting
Remote communication between cache instances.
org.infinispan.remoting.inboundhandler - package org.infinispan.remoting.inboundhandler
Handling of inbound commands on remote nodes.
org.infinispan.remoting.inboundhandler.action - package org.infinispan.remoting.inboundhandler.action
 
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.impl - package org.infinispan.remoting.transport.impl
 
org.infinispan.remoting.transport.jgroups - package org.infinispan.remoting.transport.jgroups
A transport implementation based on JGroups.
org.infinispan.scattered - package org.infinispan.scattered
SCATTERED CACHE DESIGN
org.infinispan.scattered.impl - package org.infinispan.scattered.impl
 
org.infinispan.security - package org.infinispan.security
Security API.
org.infinispan.security.actions - package org.infinispan.security.actions
 
org.infinispan.security.impl - package org.infinispan.security.impl
 
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.stats.impl - package org.infinispan.stats.impl
 
org.infinispan.stream - package org.infinispan.stream
Cache stream processing.
org.infinispan.stream.impl - package org.infinispan.stream.impl
 
org.infinispan.stream.impl.interceptor - package org.infinispan.stream.impl.interceptor
 
org.infinispan.stream.impl.intops - package org.infinispan.stream.impl.intops
 
org.infinispan.stream.impl.intops.object - package org.infinispan.stream.impl.intops.object
 
org.infinispan.stream.impl.intops.primitive.d - package org.infinispan.stream.impl.intops.primitive.d
 
org.infinispan.stream.impl.intops.primitive.i - package org.infinispan.stream.impl.intops.primitive.i
 
org.infinispan.stream.impl.intops.primitive.l - package org.infinispan.stream.impl.intops.primitive.l
 
org.infinispan.stream.impl.local - package org.infinispan.stream.impl.local
 
org.infinispan.stream.impl.spliterators - package org.infinispan.stream.impl.spliterators
 
org.infinispan.stream.impl.termop - package org.infinispan.stream.impl.termop
 
org.infinispan.stream.impl.termop.object - package org.infinispan.stream.impl.termop.object
 
org.infinispan.stream.impl.termop.primitive - package org.infinispan.stream.impl.termop.primitive
 
org.infinispan.stream.impl.tx - package org.infinispan.stream.impl.tx
 
org.infinispan.topology - package org.infinispan.topology
 
org.infinispan.transaction - package org.infinispan.transaction
JTA transaction support.
org.infinispan.transaction.impl - package org.infinispan.transaction.impl
 
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.impl - package org.infinispan.util.concurrent.locks.impl
 
org.infinispan.util.function - package org.infinispan.util.function
 
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.logging.events - package org.infinispan.util.logging.events
 
org.infinispan.util.logging.events.impl - package org.infinispan.util.logging.events.impl
 
org.infinispan.util.rxjava - package org.infinispan.util.rxjava
 
org.infinispan.util.stream - package org.infinispan.util.stream
 
org.infinispan.xsite - package org.infinispan.xsite
 
org.infinispan.xsite.notification - package org.infinispan.xsite.notification
 
org.infinispan.xsite.statetransfer - package org.infinispan.xsite.statetransfer
 
org.infinispan.xsite.status - package org.infinispan.xsite.status
 
OTHER_THAN_FIRST_OR_LAST - org.infinispan.configuration.cache.InterceptorConfiguration.Position
Specifies that the new interceptor can be placed anywhere, except first or last.
OutboundTransferTask - Class in org.infinispan.statetransfer
Outbound state transfer task.
OutboundTransferTask(Address, IntSet, int, int, int, KeyPartitioner, Consumer<OutboundTransferTask>, Consumer<List<StateChunk>>, BiFunction<InternalCacheEntry, InternalEntryFactory, InternalCacheEntry>, BiFunction<MarshalledEntry, InternalEntryFactory, InternalCacheEntry>, InternalDataContainer, PersistenceManager, RpcManager, CommandsFactory, InternalEntryFactory, long, String, boolean, boolean) - 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(int) - Constructor for exception org.infinispan.statetransfer.OutdatedTopologyException
Request retrying the command in explicitly set topology (or later one).
OutdatedTopologyException(String) - Constructor for exception org.infinispan.statetransfer.OutdatedTopologyException
 
OVERLAY - org.infinispan.globalstate.ConfigurationStorage
A configuration storage provider which stores configurations on the filesystem
OVERLAY_CONFIGURATION_STORAGE - org.infinispan.configuration.parsing.Element
 
OverlayLocalConfigurationStorage - Class in org.infinispan.globalstate.impl
An implementation of LocalConfigurationStorage which stores CacheContainerAdmin.AdminFlag.PERMANENT This component persists cache configurations to the GlobalStateConfiguration.persistentLocation() in a
OverlayLocalConfigurationStorage() - Constructor for class org.infinispan.globalstate.impl.OverlayLocalConfigurationStorage
 
overrideWrapper(Class<? extends Wrapper>, ComponentRegistry) - Method in class org.infinispan.encoding.DataConversion
 
OWNED - org.infinispan.scattered.ScatteredVersionManager.SegmentState
 
OWNED_SEGMENTS_ALLOWED_VARIATION - Static variable in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory
 
OWNED_SEGMENTS_ALLOWED_VARIATION - Static variable in class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory
 
OWNER - org.infinispan.commands.VisitableCommand.LoadType
In non-transactional cache, load previous value on both primary and backups.
OWNERS - org.infinispan.configuration.parsing.Attribute
 
ownersConsistentHash(CacheTopology, ConsistentHashFactory) - Static method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategy
Compute the read consistent hash for a topology with a null union consistent hash.
Ownership - Enum in org.infinispan.distribution
 
OwnershipStatistics - Class in org.infinispan.distribution.ch.impl
This class holds statistics about a consistent hash.
OwnershipStatistics(List<Address>) - Constructor for class org.infinispan.distribution.ch.impl.OwnershipStatistics
 
OwnershipStatistics(ConsistentHash, List<Address>) - Constructor for class org.infinispan.distribution.ch.impl.OwnershipStatistics
 
OwnershipStatistics(OwnershipStatistics) - Constructor for class org.infinispan.distribution.ch.impl.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
Deprecated.
Since 9.4, will be removed.
ownsData() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
ownsLock(Object) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
ownsLock(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
ownsLock(Object, Object) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
 
ownsLock(Object, Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Tests if the lockOwner owns a lock on the key.

P

parallel - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
parallel - Variable in class org.infinispan.stream.impl.local.AbstractLocalCacheStream
 
parallel() - Method in interface org.infinispan.CacheStream
parallel() - Method in interface org.infinispan.DoubleCacheStream
parallel() - Method in interface org.infinispan.IntCacheStream
parallel() - Method in interface org.infinispan.LongCacheStream
parallel() - Method in class org.infinispan.stream.impl.AbstractCacheStream
 
parallel() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
parallel() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
parallel() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
parallel() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
parallel() - Method in class org.infinispan.stream.impl.local.AbstractLocalCacheStream
 
parallel() - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
parallel() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
parallelDistribution - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
parallelDistribution() - Method in interface org.infinispan.BaseCacheStream
This would enable sending requests to all other remote nodes when a terminal operator is performed.
parallelDistribution() - Method in interface org.infinispan.CacheStream
 
parallelDistribution() - Method in interface org.infinispan.DoubleCacheStream
 
parallelDistribution() - Method in interface org.infinispan.IntCacheStream
 
parallelDistribution() - Method in interface org.infinispan.LockedStream
This would enable sending requests to all other remote nodes when a terminal operator is performed.
parallelDistribution() - Method in interface org.infinispan.LongCacheStream
 
parallelDistribution() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
parallelDistribution() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
parallelDistribution() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
parallelDistribution() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
parallelDistribution() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
parallelDistribution() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
parallelDistribution() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
parallelDistribution() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
parallelDistribution() - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
parallelDistribution() - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
parallelDistribution() - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
parallelDistribution() - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
parallelDistribution() - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
parallelDistribution() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
parallelizePublisher(IntSet, Scheduler, IntFunction<Publisher<R>>) - Static method in class org.infinispan.persistence.internal.PersistenceUtil
 
parallelizePublisher(IntSet, Executor, IntFunction<Publisher<R>>) - Static method in class org.infinispan.persistence.PersistenceUtil
Will create a publisher that parallelizes each publisher returned from the publisherFunction by executing them on the executor as needed.
parallelStream() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntrySet
 
parallelStream() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySet
 
parallelStream() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.KeySet
 
parallelStream() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.Values
 
parallelStream() - Method in interface org.infinispan.CacheCollection
 
parallelStream() - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingEntrySet
 
parallelStream() - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingKeySet
 
parallelStream() - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.TxBackingEntrySet
 
parallelStream() - Method in class org.infinispan.stream.impl.interceptor.AbstractDelegatingEntryCacheSet
 
parallelStream() - Method in class org.infinispan.stream.impl.interceptor.AbstractDelegatingKeyCacheSet
 
parallelStream() - Method in class org.infinispan.stream.impl.local.ValueCacheCollection
 
parallelStream() - Method in class org.infinispan.util.AbstractDelegatingCacheCollection
 
parallelStream() - Method in class org.infinispan.util.CacheCollectionMapper
Deprecated.
 
parallelStream() - Method in class org.infinispan.util.CacheSetMapper
 
parallelStream() - Method in class org.infinispan.util.CollectionMapper
 
parallelStream() - Method in class org.infinispan.util.WriteableCacheCollectionMapper
 
Param<P> - Interface in org.infinispan.functional
An easily extensible parameter that allows functional map operations to be tweaked.
Param.ExecutionMode - Enum in org.infinispan.functional
Defines where is the command executed.
Param.LockingMode - Enum in org.infinispan.functional
Normally the cache has to acquire locks during any write operation to guarantee its correctness.
Param.PersistenceMode - Enum in org.infinispan.functional
When a persistence store is attached to a cache, by default all write operations, regardless of whether they are inserts, updates or removes, are persisted to the store.
Param.ReplicationMode - Enum in org.infinispan.functional
 
Param.StatisticsMode - Enum in org.infinispan.functional
Defines how statistics are gathered for this command.
Parameter - Annotation Type in org.infinispan.jmx.annotations
 
ParamIds - Class in org.infinispan.functional
Parameter identifiers.
ParamKeyValueFilterConverterFactory<K,​V,​C> - Interface in org.infinispan.filter
Factory for KeyValueFilterConverter instances supporting parameters.
params - Variable in class org.infinispan.commands.functional.ReadOnlyKeyCommand
 
params - Variable in class org.infinispan.commands.functional.ReadOnlyManyCommand
 
Params - Class in org.infinispan.functional.impl
Internal class that encapsulates collection of parameters used to tweak functional map operations.
parse(InputStream) - Method in class org.infinispan.configuration.parsing.ParserRegistry
 
parse(InputStream, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.ParserRegistry
 
parse(String) - Method in class org.infinispan.configuration.parsing.ParserRegistry
 
parse(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.ParserRegistry
 
parseCacheElement(XMLExtendedStreamReader, Element, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.Parser
 
parseCapacityFactors(ScopedPersistentState) - Static method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
parseDataType(XMLExtendedStreamReader, ConfigurationBuilder, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.Parser
 
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
 
parseFile(String) - Method in class org.infinispan.configuration.parsing.ParserRegistry
 
parseFileStore(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.Parser
 
parseHashFunction(ScopedPersistentState) - Static method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
parseLocking(XMLExtendedStreamReader, ConfigurationBuilder) - Method in class org.infinispan.configuration.parsing.Parser
 
parseMembers(ScopedPersistentState) - Static method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
parseNumSegments(ScopedPersistentState) - Static method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
parseProperties(XMLExtendedStreamReader) - Static method in class org.infinispan.configuration.parsing.Parser
 
Parser - Class in org.infinispan.configuration.parsing
This class implements the parser for Infinispan/AS7/EAP/JDG schema files
Parser() - Constructor for class org.infinispan.configuration.parsing.Parser
 
Parser.Mode - Enum in org.infinispan.configuration.parsing
 
Parser.TransactionMode - Enum in org.infinispan.configuration.parsing
 
Parser72 - Class in org.infinispan.configuration.parsing
Deprecated.
Parser72() - Constructor for class org.infinispan.configuration.parsing.Parser72
Deprecated.
 
ParserContext - Interface in org.infinispan.configuration.parsing
ParserContext.
ParserContextListener - Interface in org.infinispan.configuration.parsing
ParserContextListener.
parserDoesNotDeclareNamespaces(String) - Method in class org.infinispan.util.logging.Log_$logger
 
parserDoesNotDeclareNamespaces(String) - Method in interface org.infinispan.util.logging.Log
 
parserDoesNotDeclareNamespaces$str() - Method in class org.infinispan.util.logging.Log_$logger
 
parserRegistry - Variable in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
 
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
 
ParserRegistry(ClassLoader, boolean) - Constructor for class org.infinispan.configuration.parsing.ParserRegistry
 
ParserRegistry.NamespaceParserPair - Class in org.infinispan.configuration.parsing
 
parserRootElementAlreadyRegistered(QName, String, String) - Method in class org.infinispan.util.logging.Log_$logger
 
parserRootElementAlreadyRegistered(QName, String, String) - Method in interface org.infinispan.util.logging.Log
 
parserRootElementAlreadyRegistered$str() - Method in class org.infinispan.util.logging.Log_$logger
 
ParserScope - Enum in org.infinispan.configuration.parsing
ParserScope indicates the configuration parser scope.
parseStoreAttribute(XMLExtendedStreamReader, int, AbstractStoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.Parser
This method is public static so that it can be reused by custom cache store/loader configuration parsers
parseStoreElement(XMLExtendedStreamReader, StoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.Parser
 
parseStoreElement(XMLExtendedStreamReader, StoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.Parser72
Deprecated.
 
parseStoreProperty(XMLExtendedStreamReader, StoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.Parser
 
parseStoreWriteBehind(XMLExtendedStreamReader, AsyncStoreConfigurationBuilder<?>) - Static method in class org.infinispan.configuration.parsing.Parser
 
parseTransaction(XMLExtendedStreamReader, ConfigurationBuilder, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.Parser
 
ParseUtils - Class in org.infinispan.configuration.parsing
 
parsingComplete(ParserContext) - Method in interface org.infinispan.configuration.parsing.ParserContextListener
 
partition - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
PARTITION_HANDLING - org.infinispan.configuration.parsing.Element
 
PARTITION_STATUS_CHANGED - org.infinispan.notifications.cachelistener.event.Event.Type
 
PartitionAwareClusterStreamManager<Original,​K> - Class in org.infinispan.stream.impl
Cluster stream manager that also pays attention to partition status and properly closes iterators and throws exceptions when the availability mode changes.
PartitionAwareClusterStreamManager() - Constructor for class org.infinispan.stream.impl.PartitionAwareClusterStreamManager
 
partitionDegraded() - Method in class org.infinispan.util.logging.Log_$logger
 
partitionDegraded() - Method in interface org.infinispan.util.logging.Log
 
partitionDegraded$str() - Method in class org.infinispan.util.logging.Log_$logger
 
partitioner - Variable in class org.infinispan.expiration.impl.TxClusterExpirationManager
 
PartitionerConsistentHash - Class in org.infinispan.distribution.group.impl
ConsistentHash wrapper that uses a KeyPartitioner instead of a Hash.
PartitionerConsistentHash(ConsistentHash, KeyPartitioner) - Constructor for class org.infinispan.distribution.group.impl.PartitionerConsistentHash
 
partitionHandling() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
Configures cluster's behaviour in the presence of partitions or node failures.
partitionHandling() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
partitionHandling() - Method in interface org.infinispan.configuration.cache.ClusteringConfigurationChildBuilder
Configures how the cache will react to cluster partitions.
PartitionHandling - Enum in org.infinispan.partitionhandling
 
PartitionHandlingConfiguration - Class in org.infinispan.configuration.cache
Controls how the cache handles partitioning and/or multiple node failures.
PartitionHandlingConfiguration(AttributeSet) - Constructor for class org.infinispan.configuration.cache.PartitionHandlingConfiguration
 
PartitionHandlingConfigurationBuilder - Class in org.infinispan.configuration.cache
Controls how the cache handles partitioning and/or multiple node failures.
PartitionHandlingConfigurationBuilder(ClusteringConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
 
partitionHandlingConfigurationEnabledDeprecated() - Method in class org.infinispan.util.logging.Log_$logger
 
partitionHandlingConfigurationEnabledDeprecated() - Method in interface org.infinispan.util.logging.Log
 
partitionHandlingConfigurationEnabledDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
PartitionHandlingInterceptor - Class in org.infinispan.partitionhandling.impl
 
PartitionHandlingInterceptor() - Constructor for class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
 
partitionHandlingManager - Variable in class org.infinispan.transaction.impl.TransactionTable
 
PartitionHandlingManager - Interface in org.infinispan.partitionhandling.impl
 
PartitionHandlingManagerFactory - Class in org.infinispan.factories
 
PartitionHandlingManagerFactory() - Constructor for class org.infinispan.factories.PartitionHandlingManagerFactory
 
PartitionHandlingManagerImpl - Class in org.infinispan.partitionhandling.impl
 
PartitionHandlingManagerImpl() - Constructor for class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
PartitionStatusChanged - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when the AvailabilityMode in use by the PartitionHandlingManager changes due to a change in cluster topology.
PartitionStatusChangedEvent<K,​V> - Interface in org.infinispan.notifications.cachelistener.event
The event passed in to methods annotated with PartitionStatusChanged.
passivate(InternalCacheEntry) - Method in class org.infinispan.eviction.impl.PassivationManagerImpl
 
passivate(InternalCacheEntry) - Method in class org.infinispan.eviction.impl.PassivationManagerStub
 
passivate(InternalCacheEntry) - Method in interface org.infinispan.eviction.PassivationManager
 
passivateAll() - Method in class org.infinispan.eviction.impl.PassivationManagerImpl
 
passivateAll() - Method in class org.infinispan.eviction.impl.PassivationManagerStub
 
passivateAll() - Method in interface org.infinispan.eviction.PassivationManager
 
passivatedEntries(long, String) - Method in class org.infinispan.util.logging.Log_$logger
 
passivatedEntries(long, String) - Method in interface org.infinispan.util.logging.Log
 
passivatedEntries$str() - Method in class org.infinispan.util.logging.Log_$logger
 
passivatingAllEntries() - Method in class org.infinispan.util.logging.Log_$logger
 
passivatingAllEntries() - Method in interface org.infinispan.util.logging.Log
 
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
 
PASSIVATION - org.infinispan.configuration.parsing.Attribute
 
PASSIVATION - Static variable in class org.infinispan.configuration.cache.PersistenceConfiguration
 
PassivationManager - Interface in org.infinispan.eviction
A passivation manager
PassivationManagerImpl - Class in org.infinispan.eviction.impl
 
PassivationManagerImpl() - Constructor for class org.infinispan.eviction.impl.PassivationManagerImpl
 
PassivationManagerStub - Class in org.infinispan.eviction.impl
 
PassivationManagerStub() - Constructor for class org.infinispan.eviction.impl.PassivationManagerStub
 
passivationStoreCannotBeShared(String) - Method in class org.infinispan.util.logging.Log_$logger
 
passivationStoreCannotBeShared(String) - Method in interface org.infinispan.util.logging.Log
 
passivationStoreCannotBeShared$str() - Method in class org.infinispan.util.logging.Log_$logger
 
passivationWithoutEviction() - Method in class org.infinispan.util.logging.Log_$logger
 
passivationWithoutEviction() - Method in interface org.infinispan.util.logging.Log
 
passivationWithoutEviction$str() - Method in class org.infinispan.util.logging.Log_$logger
 
PassivationWriterInterceptor - Class in org.infinispan.interceptors.impl
Handles store write operations when passivation enabled that don't entail reading the entry first
PassivationWriterInterceptor() - Constructor for class org.infinispan.interceptors.impl.PassivationWriterInterceptor
 
passivator - Variable in class org.infinispan.container.impl.AbstractInternalDataContainer
 
passivator - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
PassthroughMapResponseCollector - Class in org.infinispan.remoting.transport.impl
Receive responses from multiple nodes, without checking that the responses are valid.
PassthroughMapResponseCollector(int) - Constructor for class org.infinispan.remoting.transport.impl.PassthroughMapResponseCollector
 
PassthroughSingleResponseCollector - Class in org.infinispan.remoting.transport.impl
RPC to a single node, without any validity checks.
PATH - org.infinispan.configuration.parsing.Attribute
 
peek() - Method in interface org.infinispan.functional.EntryView.ReadEntryView
The same as EntryView.ReadEntryView.find() but does not update any hit/miss statistics.
peek(int, Object) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
peek(int, Object) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
peek(int, Object) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
peek(int, Object) - Method in interface org.infinispan.container.impl.InternalDataContainer
Same as DataContainer.peek(Object) except that the segment of the key can provided to lookup entries without calculating the segment for the given key
peek(int, Object) - Method in class org.infinispan.container.impl.InternalDataContainerAdapter
 
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.impl.AbstractDelegatingDataContainer
 
peek(Object) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
peek(Object) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
peek(Object) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
peek(Object) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
peek(Consumer<? super R>) - Method in interface org.infinispan.CacheStream
peek(Consumer<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
peek(Consumer<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
peek(Consumer<? super R>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
peek(Consumer<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
peek(DoubleConsumer) - Method in interface org.infinispan.DoubleCacheStream
peek(DoubleConsumer) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
peek(DoubleConsumer) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
peek(DoubleConsumer) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
peek(IntConsumer) - Method in interface org.infinispan.IntCacheStream
peek(IntConsumer) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
peek(IntConsumer) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
peek(IntConsumer) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
peek(LongConsumer) - Method in interface org.infinispan.LongCacheStream
peek(LongConsumer) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
peek(LongConsumer) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
peek(LongConsumer) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
peek(SerializableConsumer<? super R>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.peek(Consumer) except that the Consumer must also implement Serializable
peek(SerializableDoubleConsumer) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleCacheStream.flatMap(DoubleFunction) except that the DoubleFunction must also implement Serializable
peek(SerializableDoubleConsumer) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
peek(SerializableIntConsumer) - Method in interface org.infinispan.IntCacheStream
Same as IntCacheStream.flatMap(IntFunction) except that the IntFunction must also implement Serializable
peek(SerializableIntConsumer) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
peek(SerializableLongConsumer) - Method in interface org.infinispan.LongCacheStream
Same as LongCacheStream.flatMap(LongFunction) except that the LongFunction must also implement Serializable.
peek(SerializableLongConsumer) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
PeekDoubleOperation - Class in org.infinispan.stream.impl.intops.primitive.d
Performs peek operation on a DoubleStream
PeekDoubleOperation(DoubleConsumer) - Constructor for class org.infinispan.stream.impl.intops.primitive.d.PeekDoubleOperation
 
PeekIntOperation - Class in org.infinispan.stream.impl.intops.primitive.i
Performs peek operation on a IntStream
PeekIntOperation(IntConsumer) - Constructor for class org.infinispan.stream.impl.intops.primitive.i.PeekIntOperation
 
PeekLongOperation - Class in org.infinispan.stream.impl.intops.primitive.l
Performs peek operation on a LongStream
PeekLongOperation(LongConsumer) - Constructor for class org.infinispan.stream.impl.intops.primitive.l.PeekLongOperation
 
PeekOperation<S> - Class in org.infinispan.stream.impl.intops.object
Performs peek operation on a regular Stream
PeekOperation(Consumer<? super S>) - Constructor for class org.infinispan.stream.impl.intops.object.PeekOperation
 
PENDING - org.infinispan.topology.RebalancingStatus
 
PendingLockListener - Interface in org.infinispan.util.concurrent.locks
A listener that is invoked when PendingLockPromise is ready.
PendingLockManager - Interface in org.infinispan.util.concurrent.locks
A manager that checks and waits for older topology transaction with conflicting keys.
PendingLockPromise - Interface in org.infinispan.util.concurrent.locks
A promise returned by PendingLockManager.
pendingTransactionCount() - Method in class org.infinispan.interceptors.impl.TransactionalExceptionEvictionInterceptor
 
PendingTxAction - Class in org.infinispan.remoting.inboundhandler.action
An Action implementation that check for older topology transactions.
PendingTxAction(PendingLockManager, DistributionManager) - Constructor for class org.infinispan.remoting.inboundhandler.action.PendingTxAction
 
PER_SENDER - org.infinispan.remoting.inboundhandler.DeliverOrder
The message is delivered by the order they are sent.
PerCacheInboundInvocationHandler - Interface in org.infinispan.remoting.inboundhandler
Interface to invoke when a CacheRpcCommand is received from other node in the local site.
PERCENTAGE - org.infinispan.jmx.annotations.Units
 
perform(InputStream) - Method in interface org.infinispan.stream.impl.intops.IntermediateOperation
Performs the actualy intermediate operation returning the resulting stream
perform(BaseStream) - Method in class org.infinispan.stream.impl.intops.UnorderedOperation
 
perform(DoubleStream) - Method in class org.infinispan.stream.impl.intops.primitive.d.BoxedDoubleOperation
 
perform(DoubleStream) - Method in class org.infinispan.stream.impl.intops.primitive.d.DistinctDoubleOperation
 
perform(DoubleStream) - Method in class org.infinispan.stream.impl.intops.primitive.d.FilterDoubleOperation
 
perform(DoubleStream) - Method in class org.infinispan.stream.impl.intops.primitive.d.FlatMapDoubleOperation
 
perform(DoubleStream) - Method in class org.infinispan.stream.impl.intops.primitive.d.LimitDoubleOperation
 
perform(DoubleStream) - Method in class org.infinispan.stream.impl.intops.primitive.d.MapDoubleOperation
 
perform(DoubleStream) - Method in class org.infinispan.stream.impl.intops.primitive.d.MapToIntDoubleOperation
 
perform(DoubleStream) - Method in class org.infinispan.stream.impl.intops.primitive.d.MapToLongDoubleOperation
 
perform(DoubleStream) - Method in class org.infinispan.stream.impl.intops.primitive.d.MapToObjDoubleOperation
 
perform(DoubleStream) - Method in class org.infinispan.stream.impl.intops.primitive.d.PeekDoubleOperation
 
perform(DoubleStream) - Method in class org.infinispan.stream.impl.intops.primitive.d.SkipDoubleOperation
 
perform(DoubleStream) - Method in class org.infinispan.stream.impl.intops.primitive.d.SortedDoubleOperation
 
perform(IntStream) - Method in class org.infinispan.stream.impl.intops.primitive.i.AsDoubleIntOperation
 
perform(IntStream) - Method in class org.infinispan.stream.impl.intops.primitive.i.AsLongIntOperation
 
perform(IntStream) - Method in class org.infinispan.stream.impl.intops.primitive.i.BoxedIntOperation
 
perform(IntStream) - Method in class org.infinispan.stream.impl.intops.primitive.i.DistinctIntOperation
 
perform(IntStream) - Method in class org.infinispan.stream.impl.intops.primitive.i.FilterIntOperation
 
perform(IntStream) - Method in class org.infinispan.stream.impl.intops.primitive.i.FlatMapIntOperation
 
perform(IntStream) - Method in class org.infinispan.stream.impl.intops.primitive.i.LimitIntOperation
 
perform(IntStream) - Method in class org.infinispan.stream.impl.intops.primitive.i.MapIntOperation
 
perform(IntStream) - Method in class org.infinispan.stream.impl.intops.primitive.i.MapToDoubleIntOperation
 
perform(IntStream) - Method in class org.infinispan.stream.impl.intops.primitive.i.MapToLongIntOperation
 
perform(IntStream) - Method in class org.infinispan.stream.impl.intops.primitive.i.MapToObjIntOperation
 
perform(IntStream) - Method in class org.infinispan.stream.impl.intops.primitive.i.PeekIntOperation
 
perform(IntStream) - Method in class org.infinispan.stream.impl.intops.primitive.i.SkipIntOperation
 
perform(IntStream) - Method in class org.infinispan.stream.impl.intops.primitive.i.SortedIntOperation
 
perform(LongStream) - Method in class org.infinispan.stream.impl.intops.primitive.l.AsDoubleLongOperation
 
perform(LongStream) - Method in class org.infinispan.stream.impl.intops.primitive.l.BoxedLongOperation
 
perform(LongStream) - Method in class org.infinispan.stream.impl.intops.primitive.l.DistinctLongOperation
 
perform(LongStream) - Method in class org.infinispan.stream.impl.intops.primitive.l.FilterLongOperation
 
perform(LongStream) - Method in class org.infinispan.stream.impl.intops.primitive.l.FlatMapLongOperation
 
perform(LongStream) - Method in class org.infinispan.stream.impl.intops.primitive.l.LimitLongOperation
 
perform(LongStream) - Method in class org.infinispan.stream.impl.intops.primitive.l.MapLongOperation
 
perform(LongStream) - Method in class org.infinispan.stream.impl.intops.primitive.l.MapToDoubleLongOperation
 
perform(LongStream) - Method in class org.infinispan.stream.impl.intops.primitive.l.MapToIntLongOperation
 
perform(LongStream) - Method in class org.infinispan.stream.impl.intops.primitive.l.MapToObjLongOperation
 
perform(LongStream) - Method in class org.infinispan.stream.impl.intops.primitive.l.PeekLongOperation
 
perform(LongStream) - Method in class org.infinispan.stream.impl.intops.primitive.l.SkipLongOperation
 
perform(LongStream) - Method in class org.infinispan.stream.impl.intops.primitive.l.SortedLongOperation
 
perform(Stream<I>) - Method in class org.infinispan.stream.impl.intops.object.FlatMapOperation
 
perform(Stream<I>) - Method in class org.infinispan.stream.impl.intops.object.FlatMapToDoubleOperation
 
perform(Stream<I>) - Method in class org.infinispan.stream.impl.intops.object.FlatMapToIntOperation
 
perform(Stream<I>) - Method in class org.infinispan.stream.impl.intops.object.FlatMapToLongOperation
 
perform(Stream<I>) - Method in class org.infinispan.stream.impl.intops.object.MapOperation
 
perform(Stream<I>) - Method in class org.infinispan.stream.impl.intops.object.MapToDoubleOperation
 
perform(Stream<I>) - Method in class org.infinispan.stream.impl.intops.object.MapToIntOperation
 
perform(Stream<I>) - Method in class org.infinispan.stream.impl.intops.object.MapToLongOperation
 
perform(Stream<S>) - Method in class org.infinispan.stream.impl.intops.object.DistinctOperation
 
perform(Stream<S>) - Method in class org.infinispan.stream.impl.intops.object.FilterOperation
 
perform(Stream<S>) - Method in class org.infinispan.stream.impl.intops.object.LimitOperation
 
perform(Stream<S>) - Method in class org.infinispan.stream.impl.intops.object.PeekOperation
 
perform(Stream<S>) - Method in class org.infinispan.stream.impl.intops.object.SkipOperation
 
perform(Stream<S>) - Method in class org.infinispan.stream.impl.intops.object.SortedComparatorOperation
 
perform(Stream<S>) - Method in class org.infinispan.stream.impl.intops.object.SortedOperation
 
perform(InvocationContext) - Method in class org.infinispan.commands.functional.ReadOnlyKeyCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.functional.ReadOnlyManyCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.functional.ReadWriteKeyCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.functional.ReadWriteKeyValueCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.functional.ReadWriteManyCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.functional.TxReadOnlyKeyCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.functional.TxReadOnlyManyCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.functional.WriteOnlyKeyCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.functional.WriteOnlyKeyValueCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.functional.WriteOnlyManyCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.functional.WriteOnlyManyEntriesCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.read.EntrySetCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.read.GetAllCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.read.GetCacheEntryCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.read.GetKeyValueCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.read.KeySetCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.read.SizeCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.remote.GetKeysInGroupCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.remote.recovery.GetInDoubtTransactionsCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
perform(InvocationContext) - Method in interface org.infinispan.commands.ReplicableCommand
perform(InvocationContext) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
perform(InvocationContext) - Method in interface org.infinispan.commands.VisitableCommand
Performs the primary function of the command.
perform(InvocationContext) - Method in class org.infinispan.commands.write.ApplyDeltaCommand
Deprecated.
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.ComputeCommand
 
perform(InvocationContext) - Method in class org.infinispan.commands.write.ComputeIfAbsentCommand
 
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.RemoveExpiredCommand
Performs an expiration on a specified entry
perform(InvocationContext) - Method in class org.infinispan.commands.write.ReplaceCommand
 
performCheckOnSegment(int) - Method in interface org.infinispan.transaction.impl.WriteSkewHelper.KeySpecificLogic
 
performCommandWithL1WriteIfAble(InvocationContext, DataCommand, boolean, boolean, boolean) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
performForEachOperation(KeyTrackingTerminalOperation.IntermediateCollector<Collection<K>>) - Method in interface org.infinispan.stream.impl.KeyTrackingTerminalOperation
Invoked when a key and rehash aware operation is desired.
performForEachOperation(KeyTrackingTerminalOperation.IntermediateCollector<Collection<K>>) - Method in class org.infinispan.stream.impl.termop.AbstractForEachOperation
 
performForEachOperation(KeyTrackingTerminalOperation.IntermediateCollector<Collection<K>>) - Method in class org.infinispan.stream.impl.termop.primitive.AbstractForEachDoubleOperation
 
performForEachOperation(KeyTrackingTerminalOperation.IntermediateCollector<Collection<K>>) - Method in class org.infinispan.stream.impl.termop.primitive.AbstractForEachIntOperation
 
performForEachOperation(KeyTrackingTerminalOperation.IntermediateCollector<Collection<K>>) - Method in class org.infinispan.stream.impl.termop.primitive.AbstractForEachLongOperation
 
performGracefulShutdown() - Method in class org.infinispan.cache.impl.CacheImpl
 
performInLocalSite(BackupReceiver) - Method in class org.infinispan.xsite.SingleXSiteRpcCommand
 
performInLocalSite(BackupReceiver) - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
 
performInLocalSite(BackupReceiver) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
 
performInLocalSite(BackupReceiver) - Method in class org.infinispan.xsite.XSiteReplicateCommand
 
performOnLostData() - Method in class org.infinispan.commands.functional.ReadOnlyKeyCommand
Apply function on entry without any data
performOperation() - Method in interface org.infinispan.stream.impl.TerminalOperation
Actually runs the terminal operation returning the result from the operation
performOperation() - Method in class org.infinispan.stream.impl.termop.SegmentRetryingOperation
 
performOperation() - Method in class org.infinispan.stream.impl.termop.SingleRunOperation
 
performOperation(KeyTrackingTerminalOperation.IntermediateCollector<Collection<Double>>) - Method in class org.infinispan.stream.impl.termop.primitive.AbstractForEachDoubleOperation
 
performOperation(KeyTrackingTerminalOperation.IntermediateCollector<Collection<Integer>>) - Method in class org.infinispan.stream.impl.termop.primitive.AbstractForEachIntOperation
 
performOperation(KeyTrackingTerminalOperation.IntermediateCollector<Collection<Long>>) - Method in class org.infinispan.stream.impl.termop.primitive.AbstractForEachLongOperation
 
performOperation(KeyTrackingTerminalOperation.IntermediateCollector<Collection<R>>) - Method in interface org.infinispan.stream.impl.KeyTrackingTerminalOperation
Invoked when a key aware operation is desired without rehash being enabled.
performOperation(KeyTrackingTerminalOperation.IntermediateCollector<Collection<V>>) - Method in class org.infinispan.stream.impl.termop.AbstractForEachOperation
 
performRemove(MVCCEntry, Object, InvocationContext) - Method in class org.infinispan.commands.write.RemoveCommand
 
performTotalOrderWriteSkewCheckAndReturnNewVersions(VersionedPrepareCommand, DataContainer, PersistenceManager, VersionGenerator, TxInvocationContext, WriteSkewHelper.KeySpecificLogic, TimeService, KeyPartitioner) - Static method in class org.infinispan.transaction.impl.WriteSkewHelper
 
performWriteSkewCheck(DataContainer, int, PersistenceManager, TxInvocationContext, EntryVersion, VersionGenerator, TimeService) - Method in class org.infinispan.container.entries.VersionedRepeatableReadEntry
 
performWriteSkewCheckAndReturnNewVersions(VersionedPrepareCommand, DataContainer, PersistenceManager, VersionGenerator, TxInvocationContext, WriteSkewHelper.KeySpecificLogic, TimeService, KeyPartitioner) - Static method in class org.infinispan.transaction.impl.WriteSkewHelper
 
PerKeyLockContainer - Class in org.infinispan.util.concurrent.locks.impl
A lock container that creates and maintains a new lock per entry.
PerKeyLockContainer() - Constructor for class org.infinispan.util.concurrent.locks.impl.PerKeyLockContainer
 
permission(String) - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
Adds a permission to a role
permission(AuthorizationPermission) - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
Adds a permission to a role
PERMISSIONS - org.infinispan.configuration.parsing.Attribute
 
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 - org.infinispan.configuration.parsing.Element
 
PERSISTENCE_AVAILABILITY_CHANGED - org.infinispan.notifications.cachelistener.event.Event.Type
 
PERSISTENCE_EXECUTOR - org.infinispan.configuration.parsing.Attribute
 
PERSISTENCE_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
PERSISTENCE_MODE_ID - Static variable in class org.infinispan.functional.ParamIds
 
PersistenceAvailabilityChanged - Annotation Type in org.infinispan.notifications.cachelistener.annotation
Use this annotation on methods that require notification when the availability of the PersistenceManager changes.
PersistenceAvailabilityChangedEvent<K,​V> - Interface in org.infinispan.notifications.cachelistener.event
 
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
 
PersistenceEntryStreamSupplier<K,​V> - Class in org.infinispan.stream.impl.local
StreamSupplier that allows for creating streams where they utilize the PersistenceManager to publish entries using segments if possible.
PersistenceEntryStreamSupplier(Cache<K, V>, InternalEntryFactory, ToIntFunction<Object>, CacheStream<CacheEntry<K, V>>, PersistenceManager) - Constructor for class org.infinispan.stream.impl.local.PersistenceEntryStreamSupplier
 
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
Deprecated.
This method always returns null now. Look for a thread pool named as GlobalConfiguration.persistenceThreadPool() instead.
PersistenceKeyStreamSupplier<K> - Class in org.infinispan.stream.impl.local
StreamSupplier that allows for creating streams where they utilize the PersistenceManager to publish keys using segments if possible.
PersistenceKeyStreamSupplier(Cache<K, ?>, ToIntFunction<Object>, CacheStream<K>, PersistenceManager) - Constructor for class org.infinispan.stream.impl.local.PersistenceKeyStreamSupplier
 
persistenceManager - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
persistenceManager - Variable in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
persistenceManager - Variable in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
persistenceManager - Variable in class org.infinispan.interceptors.impl.PassivationWriterInterceptor
 
persistenceManager - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
persistenceManager - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
persistenceManager - Variable in class org.infinispan.statetransfer.StateProviderImpl
 
PersistenceManager - Interface in org.infinispan.persistence.manager
Defines the logic for interacting with the chain of external storage.
PersistenceManager.AccessMode - Enum in org.infinispan.persistence.manager
 
PersistenceManagerCloseableSupplier<K,​V> - Class in org.infinispan.persistence.util
PersistenceManagerCloseableSupplier(Executor, AdvancedCacheLoader<K, V>, Predicate<? super K>, boolean, boolean, long, TimeUnit, int) - Constructor for class org.infinispan.persistence.util.PersistenceManagerCloseableSupplier
Deprecated.
 
PersistenceManagerImpl - Class in org.infinispan.persistence.manager
 
PersistenceManagerImpl() - Constructor for class org.infinispan.persistence.manager.PersistenceManagerImpl
 
PersistenceManagerStub - Class in org.infinispan.persistence.manager
 
PersistenceManagerStub() - Constructor for class org.infinispan.persistence.manager.PersistenceManagerStub
 
persistenceThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
persistenceThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
persistenceThreadPool() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
Configuration for the persistence thread pool
PersistenceUtil - Class in org.infinispan.persistence.internal
Persistence Utility that is useful for internal classes.
PersistenceUtil - Class in org.infinispan.persistence
 
PersistenceUtil() - Constructor for class org.infinispan.persistence.internal.PersistenceUtil
 
PersistenceUtil() - Constructor for class org.infinispan.persistence.PersistenceUtil
 
persistenceWithoutCacheLoaderInterceptor() - Method in class org.infinispan.util.logging.Log_$logger
 
persistenceWithoutCacheLoaderInterceptor() - Method in interface org.infinispan.util.logging.Log
 
persistenceWithoutCacheLoaderInterceptor$str() - Method in class org.infinispan.util.logging.Log_$logger
 
persistenceWithoutCacheWriteInterceptor() - Method in class org.infinispan.util.logging.Log_$logger
 
persistenceWithoutCacheWriteInterceptor() - Method in interface org.infinispan.util.logging.Log
 
persistenceWithoutCacheWriteInterceptor$str() - Method in class org.infinispan.util.logging.Log_$logger
 
PERSISTENT - org.infinispan.registry.InternalCacheRegistry.Flag
means the cache should be made persistent across restarts if global state persistence is enabled
PERSISTENT_LOCATION - org.infinispan.configuration.parsing.Element
 
PERSISTENT_LOCATION - Static variable in class org.infinispan.configuration.global.GlobalStateConfiguration
 
persistentConsistentHashMismatch(String, String) - Method in class org.infinispan.util.logging.Log_$logger
 
persistentConsistentHashMismatch(String, String) - Method in interface org.infinispan.util.logging.Log
 
persistentConsistentHashMismatch$str() - Method in class org.infinispan.util.logging.Log_$logger
 
persistentLocation() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
Returns the filesystem path where persistent state data which needs to survive container restarts should be stored.
persistentLocation(String) - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
Defines the filesystem path where persistent state data which needs to survive container restarts should be stored.
PersistentUUID - Class in org.infinispan.topology
PersistentUUID.
PersistentUUID(long, long) - Constructor for class org.infinispan.topology.PersistentUUID
 
PersistentUUID.Externalizer - Class in org.infinispan.topology
 
PersistentUUIDManager - Interface in org.infinispan.topology
PersistentUUIDManager maintains a mapping of PersistentUUIDs present in the cluster
PersistentUUIDManagerImpl - Class in org.infinispan.topology
Implementation of the PersistentUUIDManager interface
PersistentUUIDManagerImpl() - Constructor for class org.infinispan.topology.PersistentUUIDManagerImpl
 
persistentUUIDToAddress() - Method in interface org.infinispan.topology.PersistentUUIDManager
Provides a remapping operator which translates persistentuuids to addresses
persistentUUIDToAddress() - Method in class org.infinispan.topology.PersistentUUIDManagerImpl
 
PESSIMISTIC - org.infinispan.transaction.LockingMode
 
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
 
pickConsistentHashFactory(GlobalConfiguration, Configuration) - Static method in class org.infinispan.statetransfer.StateTransferManagerImpl
If no ConsistentHashFactory was explicitly configured we choose a suitable one based on cache mode.
pickRoute(String, List<Route>, Address) - Method in class org.infinispan.remoting.transport.jgroups.SiteMasterPickerImpl
 
pickSiteMaster(List<Address>, Address) - Method in class org.infinispan.remoting.transport.jgroups.SiteMasterPickerImpl
 
PIGGYBACK - org.infinispan.eviction.EvictionThreadPolicy
 
PlatformMBeanServerLookup - Class in org.infinispan.jmx
Deprecated.
Use PlatformMBeanServerLookup instead
PlatformMBeanServerLookup() - Constructor for class org.infinispan.jmx.PlatformMBeanServerLookup
Deprecated.
 
POLICY_DISABLE - org.infinispan.topology.CacheTopologyControlCommand.Type
 
POLICY_ENABLE - org.infinispan.topology.CacheTopologyControlCommand.Type
 
POLICY_GET_STATUS - org.infinispan.topology.CacheTopologyControlCommand.Type
 
poll() - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
{@inheritDoc CompletionService}
poll() - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
poll() - Method in class org.infinispan.executors.SemaphoreCompletionService
 
poll(long, TimeUnit) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
{@inheritDoc CompletionService}
poll(long, TimeUnit) - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
poll(long, TimeUnit) - Method in class org.infinispan.executors.SemaphoreCompletionService
 
pollStoreAvailability() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
popNDC(boolean) - Static method in class org.infinispan.util.logging.LogFactory
 
populateOwners(int) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
position() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
position() - Method in class org.infinispan.io.ReadableGridFileChannel
 
position(long) - Method in class org.infinispan.io.ReadableGridFileChannel
 
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 - org.infinispan.configuration.parsing.Attribute
 
POSITION - Static variable in class org.infinispan.configuration.cache.InterceptorConfiguration
 
POST - org.infinispan.notifications.Listener.Observation
Observation level used to only be notified of an operation after it has completed
PostCacheEventFilter<K,​V> - Class in org.infinispan.notifications.cachelistener.filter
A Filter that only allows post events to be accepted.
PostCacheEventFilter() - Constructor for class org.infinispan.notifications.cachelistener.filter.PostCacheEventFilter
 
postStart() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
postStart() - Method in class org.infinispan.factories.ComponentRegistry
 
postStart() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
PostStart - Annotation Type in org.infinispan.factories.annotations
Deprecated.
Since 9.4, please use Start instead.
postStop() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
postStop() - Method in class org.infinispan.factories.ComponentRegistry
 
postStop() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
postTxCommandCheck(InvocationContext, VisitableCommand, Object) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
 
PRE - org.infinispan.notifications.Listener.Observation
Observation level used to only be notified of an operation before it completes
predicate(KeyValueFilter<? super K, ? super V>) - Static method in class org.infinispan.filter.CacheFilters
Creates a new Predicate using the provided key value filter as a basis for the operation.
PreferAvailabilityStrategy - Class in org.infinispan.partitionhandling.impl
 
PreferAvailabilityStrategy(EventLogManager, PersistentUUIDManager, LostDataCheck) - Constructor for class org.infinispan.partitionhandling.impl.PreferAvailabilityStrategy
 
PreferConsistencyStrategy - Class in org.infinispan.partitionhandling.impl
 
PreferConsistencyStrategy(EventLogManager, PersistentUUIDManager, LostDataCheck) - Constructor for class org.infinispan.partitionhandling.impl.PreferConsistencyStrategy
 
PREFERRED_ALWAYS - org.infinispan.conflict.MergePolicy
 
PREFERRED_ALWAYS - Static variable in class org.infinispan.conflict.MergePolicies
Deprecated.
 
PREFERRED_NON_NULL - org.infinispan.conflict.MergePolicy
 
PREFERRED_NON_NULL - Static variable in class org.infinispan.conflict.MergePolicies
Deprecated.
 
PrefetchInterceptor<K,​V> - Class in org.infinispan.interceptors.impl
 
PrefetchInterceptor() - Constructor for class org.infinispan.interceptors.impl.PrefetchInterceptor
 
preload - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
Deprecated.
preload() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
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() - 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
 
preload() - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
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(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 - org.infinispan.configuration.parsing.Attribute
 
PRELOAD - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
PreloadManager - Class in org.infinispan.persistence.manager
Separate the preload into its own component
PreloadManager() - Constructor for class org.infinispan.persistence.manager.PreloadManager
 
prepare(Xid) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
This can be call for any transaction object.
prepare(Xid) - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
prepare(LocalTransaction) - Method in class org.infinispan.transaction.impl.TransactionCoordinator
 
prepare(LocalTransaction, boolean) - Method in class org.infinispan.transaction.impl.TransactionCoordinator
 
prepareAllTxStores(Transaction, BatchModification, Predicate<? super StoreConfiguration>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
Perform the prepare phase of 2PC on all Tx stores.
prepareAllTxStores(Transaction, BatchModification, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
prepareAllTxStores(Transaction, BatchModification, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
PrepareCommand - Class in org.infinispan.commands.tx
Command corresponding to the 1st phase of 2PC.
PrepareCommand(ByteString) - Constructor for class org.infinispan.commands.tx.PrepareCommand
 
PrepareCommand(ByteString, GlobalTransaction, boolean, WriteCommand...) - Constructor for class org.infinispan.commands.tx.PrepareCommand
 
PrepareCommand(ByteString, GlobalTransaction, List<WriteCommand>, boolean) - Constructor for class org.infinispan.commands.tx.PrepareCommand
 
prepared() - Method in class org.infinispan.transaction.impl.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.util.logging.Log_$logger
 
preparedTxAlreadyExists(RecoveryAwareTransaction, RecoveryAwareRemoteTransaction) - Method in interface org.infinispan.util.logging.Log
 
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
 
prepareForPersist(ScopedPersistentState) - Method in interface org.infinispan.globalstate.GlobalStateProvider
This method is invoked by the GlobalStateManager just before persisting the global state
prepareForPersist(ScopedPersistentState) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
prepareForRestore(ScopedPersistentState) - Method in interface org.infinispan.globalstate.GlobalStateProvider
This method is invoked by the GlobalStateManager after starting up to notify that global state has been restored.
prepareForRestore(ScopedPersistentState) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
prepareOnAffectedNodes(TxInvocationContext<?>, PrepareCommand, Collection<Address>) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
prepareOnAffectedNodes(TxInvocationContext<?>, PrepareCommand, Collection<Address>) - Method in class org.infinispan.interceptors.distribution.VersionedDistributionInterceptor
 
prepareOnAffectedNodes(TxInvocationContext<?>, PrepareCommand, Collection<Address>) - Method in class org.infinispan.interceptors.totalorder.TotalOrderDistributionInterceptor
 
prepareOnAffectedNodes(TxInvocationContext<?>, PrepareCommand, Collection<Address>) - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedDistributionInterceptor
 
prepareWithModifications(Transaction, BatchModification) - Method in interface org.infinispan.persistence.spi.TransactionalCacheWriter
Write modifications to the store in the prepare phase, as this is the only way we know the FINAL values of the entries.
preparing() - Method in class org.infinispan.transaction.impl.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
Deprecated.
Since 9.0, please extend AsyncInterceptor instead.
PrePostProcessingCommandInterceptor() - Constructor for class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
Deprecated.
 
preserveOrder() - Method in enum org.infinispan.remoting.inboundhandler.DeliverOrder
 
preStart() - Method in class org.infinispan.cache.impl.CacheImpl
 
preStart() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
preStart() - Method in class org.infinispan.factories.ComponentRegistry
 
preStart() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
preStart() - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
preStop() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
preStop() - Method in class org.infinispan.factories.ComponentRegistry
 
preStop() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
prettyPrintOwnership() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
 
primary() - Method in class org.infinispan.distribution.DistributionInfo
 
PRIMARY - org.infinispan.commands.VisitableCommand.LoadType
In non-transactional cache, load previous value only on the primary owner.
PRIMARY - org.infinispan.distribution.Ownership
This node is the primary owner.
PRIMARY_OWNER - org.infinispan.configuration.cache.Index
Only the primary owner of an entry will add it to the index.
PRIMARY_SEGMENTS_ALLOWED_VARIATION - Static variable in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory
 
PRIMARY_SEGMENTS_ALLOWED_VARIATION - Static variable in class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory
 
primaryException(Throwable) - Method in interface org.infinispan.interceptors.distribution.Collector
The exception results of the primary owner.
primaryException(Throwable) - Method in class org.infinispan.interceptors.distribution.PrimaryOwnerOnlyCollector
 
primaryOnly() - Method in annotation type org.infinispan.notifications.Listener
Specifies whether the event should be fired on the primary data owner of the affected key, or all nodes that see the update.
PrimaryOwnerFilter<K> - Class in org.infinispan.persistence
 
PrimaryOwnerFilter(ClusteringDependentLogic) - Constructor for class org.infinispan.persistence.PrimaryOwnerFilter
 
PrimaryOwnerOnlyCollector<T> - Class in org.infinispan.interceptors.distribution
A Collector implementation that only waits for the primary owner.
PrimaryOwnerOnlyCollector() - Constructor for class org.infinispan.interceptors.distribution.PrimaryOwnerOnlyCollector
 
PrimaryResponseGenerator(CacheEntry, Object) - Constructor for class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseGenerator
 
PrimaryResponseHandler(Object) - Constructor for class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
 
primaryResult(T, boolean) - Method in interface org.infinispan.interceptors.distribution.Collector
The write operation's return value.
primaryResult(T, boolean) - Method in class org.infinispan.interceptors.distribution.PrimaryOwnerOnlyCollector
 
PrimitiveEntrySizeCalculator - Class in org.infinispan.container.entries
Entry Size calculator that returns an approximation of how much various primitives, primitive wrappers, Strings, and arrays
PrimitiveEntrySizeCalculator() - Constructor for class org.infinispan.container.entries.PrimitiveEntrySizeCalculator
 
PRINCIPAL_ROLE_MAPPER - Static variable in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
principalRoleMapper() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
principalRoleMapper(PrincipalRoleMapper) - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
The class of a mapper which converts the Principals associated with a Subject into a set of roles
PrincipalRoleMapper - Interface in org.infinispan.security
PrincipalRoleMapper.
PrincipalRoleMapperContext - Interface in org.infinispan.security
PrincipalRoleMapperContext.
PrincipalRoleMapperContextImpl - Class in org.infinispan.security.impl
PrincipalRoleMapperContextImpl.
PrincipalRoleMapperContextImpl(EmbeddedCacheManager) - Constructor for class org.infinispan.security.impl.PrincipalRoleMapperContextImpl
 
principalToRoles(Principal) - Method in class org.infinispan.security.impl.ClusterRoleMapper
 
principalToRoles(Principal) - Method in class org.infinispan.security.impl.CommonNameRoleMapper
 
principalToRoles(Principal) - Method in class org.infinispan.security.impl.IdentityRoleMapper
 
principalToRoles(Principal) - Method in interface org.infinispan.security.PrincipalRoleMapper
Maps a principal name to a set of role names.
printFlags() - Method in class org.infinispan.commands.AbstractFlagAffectedCommand
 
printFlags() - Method in class org.infinispan.commands.read.AbstractDataCommand
 
printFlags() - Method in class org.infinispan.commands.remote.BaseClusteredReadCommand
 
printFullVersionInformation() - Static method in class org.infinispan.Version
Prints full version information to the standard output.
printLockInfo() - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
 
printLockInfo() - Method in interface org.infinispan.util.concurrent.locks.LockManager
Prints lock information for all locks.
printVersion() - Static method in class org.infinispan.Version
Returns version information as a string.
PrioritizedMethodMetadata(String, int) - Constructor for class org.infinispan.factories.components.ComponentMetadata.PrioritizedMethodMetadata
 
priority() - Method in annotation type org.infinispan.factories.annotations.PostStart
Deprecated.
Optional parameter which defines the order in which this method will be called.
priority() - Method in annotation type org.infinispan.factories.annotations.Start
Optional parameter which defines the order in which this method will be called when a component has more than one method annotated with Start.
priority() - Method in annotation type org.infinispan.factories.annotations.Stop
Optional parameter which defines the order in which this method will be called when a component has more than one method annotated with Start.
PRIORITY - org.infinispan.configuration.parsing.Attribute
 
PriorityMergingProcessor<T> - Class in org.infinispan.stream.impl
An iterable that will automatically poll entries from the given publishers.
PriorityMergingProcessor.Builder<T> - Class in org.infinispan.stream.impl
 
PRIVATE - org.infinispan.persistence.manager.PersistenceManager.AccessMode
The operation is performed only in non-shared CacheWriter or CacheLoader
PrivateGlobalConfiguration - Class in org.infinispan.configuration.internal
An internal configuration.
PrivateGlobalConfigurationBuilder - Class in org.infinispan.configuration.internal
A Builder implementation of PrivateGlobalConfiguration.
PrivateGlobalConfigurationBuilder(GlobalConfigurationBuilder) - Constructor for class org.infinispan.configuration.internal.PrivateGlobalConfigurationBuilder
 
PrivateGlobalConfigurationSerializer - Class in org.infinispan.configuration.internal
PrivateGlobalConfigurationSerializer() - Constructor for class org.infinispan.configuration.internal.PrivateGlobalConfigurationSerializer
 
problemApplyingStateForKey(String, Object, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
problemApplyingStateForKey(String, Object, Throwable) - Method in interface org.infinispan.util.logging.Log
 
problemApplyingStateForKey$str() - Method in class org.infinispan.util.logging.Log_$logger
 
problemClosingChannel(Exception, String) - Method in class org.infinispan.util.logging.Log_$logger
 
problemClosingChannel(Exception, String) - Method in interface org.infinispan.util.logging.Log
 
problemClosingChannel$str() - Method in class org.infinispan.util.logging.Log_$logger
 
problemsUnregisteringMBeans(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
problemsUnregisteringMBeans(Exception) - Method in interface org.infinispan.util.logging.Log
 
problemsUnregisteringMBeans$str() - Method in class org.infinispan.util.logging.Log_$logger
 
process(KeyFilter<? super K>, AdvancedCacheLoader.CacheLoaderTask<K, V>, Executor, boolean, boolean) - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader
Deprecated.
since 9.3 This is to be removed and replaced by AdvancedCacheLoader.publishEntries(Predicate, boolean, boolean)
processBackupResponse(TxInvocationContext, VisitableCommand, BackupResponse) - Method in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
 
processConfiguration(StoreConfiguration) - Method in interface org.infinispan.persistence.factory.CacheStoreFactory
 
processConfiguration(StoreConfiguration) - Method in class org.infinispan.persistence.factory.LocalClassLoaderCacheStoreFactory
 
processEntry(MarshalledEntry<K, V>, AdvancedCacheLoader.TaskContext) - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader.CacheLoaderTask
Deprecated.
 
processExpiration() - Method in interface org.infinispan.expiration.ExpirationManager
Processes the expiration event queue.
processExpiration() - Method in class org.infinispan.expiration.impl.ClusterExpirationManager
 
processExpiration() - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
processIterableBatch(InvocationContext, PutMapCommand, PersistenceManager.AccessMode, Predicate<Object>) - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
processResponses(BackupResponse, VisitableCommand) - Method in interface org.infinispan.xsite.BackupSender
Processes the responses of a backup command.
processResponses(BackupResponse, VisitableCommand) - Method in class org.infinispan.xsite.BackupSenderImpl
 
processResponses(BackupResponse, VisitableCommand, Transaction) - Method in interface org.infinispan.xsite.BackupSender
 
processResponses(BackupResponse, VisitableCommand, Transaction) - Method in class org.infinispan.xsite.BackupSenderImpl
 
processStoreConfiguration(StoreConfiguration) - Method in class org.infinispan.persistence.factory.CacheStoreFactoryRegistry
 
processVisitableCommand(ReplicableCommand) - Method in class org.infinispan.commands.remote.BaseRpcInvokingCommand
Deprecated.
 
processVisitableCommandAsync(ReplicableCommand) - Method in class org.infinispan.commands.remote.BaseRpcInvokingCommand
Deprecated.
 
properties - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
Deprecated.
properties() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
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
 
properties(Properties) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
PROPERTIES - org.infinispan.configuration.parsing.Element
 
PROPERTIES - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
PROPERTIES - Static variable in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
PROPERTIES - Static variable in class org.infinispan.configuration.global.TransportConfiguration
 
PROPERTY - org.infinispan.configuration.parsing.Element
 
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
 
PROTECTED - org.infinispan.registry.InternalCacheRegistry.Flag
means that his cache requires security to be accessible remotely
publishEntries(boolean, boolean) - Method in interface org.infinispan.persistence.manager.PersistenceManager
publishEntries(Predicate<? super K>, boolean, boolean) - Method in class org.infinispan.persistence.async.AdvancedAsyncCacheLoader
 
publishEntries(Predicate<? super K>, boolean, boolean) - Method in class org.infinispan.persistence.file.SingleFileStore
 
publishEntries(Predicate<? super K>, boolean, boolean) - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader
Publishes all entries from this store.
publishEntries(Predicate<? super K>, boolean, boolean) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
publishEntries(Predicate<? super K>, boolean, boolean, Predicate<? super StoreConfiguration>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
Returns a publisher that will publish all entries stored by the underlying cache store.
publishEntries(Predicate<? super K>, boolean, boolean, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
publishEntries(Predicate<? super K>, boolean, boolean, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
publishEntries(IntSet, Predicate<? super K>, boolean, boolean) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
Publishes all entries from this store.
publishEntries(IntSet, Predicate<? super K>, boolean, boolean) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
publishEntries(IntSet, Predicate<? super K>, boolean, boolean, Predicate<? super StoreConfiguration>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
Returns a publisher that will publish entries that map to the provided segments.
publishEntries(IntSet, Predicate<? super K>, boolean, boolean, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
publishEntries(IntSet, Predicate<? super K>, boolean, boolean, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
publishKeys(Predicate<? super K>) - Method in class org.infinispan.persistence.async.AdvancedAsyncCacheLoader
 
publishKeys(Predicate<? super K>) - Method in class org.infinispan.persistence.file.SingleFileStore
 
publishKeys(Predicate<? super K>) - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader
Publishes all the keys from this store.
publishKeys(Predicate<? super K>) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
publishKeys(Predicate<? super K>, Predicate<? super StoreConfiguration>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
Returns a publisher that will publish all keys stored by the underlying cache store.
publishKeys(Predicate<? super K>, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
publishKeys(Predicate<? super K>, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
publishKeys(IntSet, Predicate<? super K>) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
Publishes all the keys that map to the given segments from this store.
publishKeys(IntSet, Predicate<? super K>) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
publishKeys(IntSet, Predicate<? super K>, Predicate<? super StoreConfiguration>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
Returns a publisher that will publish keys that map to the provided segments.
publishKeys(IntSet, Predicate<? super K>, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
publishKeys(IntSet, Predicate<? super K>, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
purge(Executor, AdvancedCacheExpirationWriter.ExpirationPurgeListener<K, V>) - Method in interface org.infinispan.persistence.spi.AdvancedCacheExpirationWriter
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.async.AdvancedAsyncCacheWriter
 
purge(Executor, AdvancedCacheWriter.PurgeListener) - Method in class org.infinispan.persistence.file.SingleFileStore
 
purge(Executor, AdvancedCacheWriter.PurgeListener) - Method in class org.infinispan.persistence.support.AdvancedSingletonCacheWriter
Deprecated.
 
purge(Executor, AdvancedCacheWriter.PurgeListener<? super K>) - Method in interface org.infinispan.persistence.spi.AdvancedCacheExpirationWriter
This method is never called.
purge(Executor, AdvancedCacheWriter.PurgeListener<? super K>) - 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<? super K>) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
PURGE - org.infinispan.configuration.parsing.Attribute
 
PURGE_ON_STARTUP - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
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
 
purgeExpired() - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
purgeOnStartup - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
Deprecated.
purgeOnStartup() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
If true, purges this cache store when it starts up.
purgeOnStartup() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
If true, purges this cache store when it starts up.
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(boolean) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
If true, purges this cache store when it starts up.
PUSH_STATE_TIMEOUT - Static variable in class org.infinispan.configuration.cache.SingletonStoreConfiguration
Deprecated.
 
PUSH_STATE_WHEN_COORDINATOR - Static variable in class org.infinispan.configuration.cache.SingletonStoreConfiguration
Deprecated.
 
pushNDC(String, boolean) - Static method in class org.infinispan.util.logging.LogFactory
 
pushNDC(ByteString, boolean) - Static method in class org.infinispan.util.logging.LogFactory
 
pushState(String) - Method in class org.infinispan.xsite.GlobalXSiteAdminOperations
 
pushState(String) - Method in class org.infinispan.xsite.XSiteAdminOperations
 
pushState(Cache<?, ?>) - Method in class org.infinispan.persistence.support.SingletonCacheWriter
Deprecated.
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
Deprecated.
 
pushStateTimeout() - Method in class org.infinispan.configuration.cache.SingletonStoreConfiguration
Deprecated.
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
Deprecated.
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
Deprecated.
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
Deprecated.
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
Deprecated.
If true, when a node becomes the coordinator, it will transfer in-memory state to the underlying cache store.
put(int, K, V, Metadata) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
put(int, K, V, Metadata) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
put(int, K, V, Metadata) - Method in interface org.infinispan.container.impl.InternalDataContainer
Same as DataContainer.put(Object, Object, Metadata) except that the segment of the key can provided to write/lookup entries without calculating the segment for the given key.
put(int, K, V, Metadata) - Method in class org.infinispan.container.impl.InternalDataContainerAdapter
 
put(int, WrappedBytes, WrappedBytes, Metadata) - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
put(K, V) - Method in class org.infinispan.atomic.impl.AtomicMapProxyImpl
 
put(K, V) - Method in class org.infinispan.atomic.impl.FineGrainedAtomicMapProxyImpl
 
put(K, V) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
put(K, V) - Method in class org.infinispan.cache.impl.CacheImpl
 
put(K, V) - Method in class org.infinispan.cache.impl.CacheSupport
 
put(K, V) - Method in class org.infinispan.cache.impl.DecoratedCache
 
put(K, V) - Method in class org.infinispan.cache.impl.EncoderCache
 
put(K, V) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
put(K, V) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
put(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
put(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
put(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheSupport
 
put(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
 
put(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
put(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
put(K, V, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
 
put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
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, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
put(K, V, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
put(K, V, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
 
put(K, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
put(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
put(K, V, 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(K, V, Metadata) - Method in class org.infinispan.container.impl.AbstractDelegatingDataContainer
 
put(K, V, Metadata) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
put(K, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
put(WrappedBytes, WrappedBytes, Metadata) - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
put(WrappedBytes, InternalCacheEntry<WrappedBytes, WrappedBytes>) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
PUT_FOR_EXTERNAL_READ - org.infinispan.context.Flag
Flags the invocation as a Cache.putForExternalRead(Object, Object) call, as opposed to a regular BasicCache.put(Object, Object).
PUT_FOR_EXTERNAL_READ - Static variable in class org.infinispan.context.impl.FlagBitSets
 
PUT_FOR_STATE_TRANSFER - org.infinispan.context.Flag
Flags the invocation as a put operation done internally by the state transfer.
PUT_FOR_STATE_TRANSFER - Static variable in class org.infinispan.context.impl.FlagBitSets
 
PUT_FOR_X_SITE_STATE_TRANSFER - org.infinispan.context.Flag
Flags the invocation as a put operation done internally by the cross-site state transfer.
PUT_FOR_X_SITE_STATE_TRANSFER - Static variable in class org.infinispan.context.impl.FlagBitSets
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.atomic.impl.AtomicMapProxyImpl
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.atomic.impl.FineGrainedAtomicMapProxyImpl
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.CacheImpl
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.CacheSupport
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.EncoderCache
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheSupport
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
putAll(Map<? extends K, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
An overloaded form of Map.putAll(Map), which takes in an instance of Metadata which can be used to provide metadata information for the entries being stored, such as lifespan, version of value...etc.
putAll(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
putAll(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
putAll(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putAll(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
putAll(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putAll(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
putAll(Map<? extends WrappedBytes, ? extends InternalCacheEntry<WrappedBytes, WrappedBytes>>) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.CacheImpl
 
putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.CacheSupport
 
putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.EncoderCache
 
putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheSupport
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
putAllAsync(Map<? extends K, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
 
putAllAsync(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
putAllAsync(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
putAllAsync(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putAllAsync(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
putAllAsync(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putAllAsync(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
putAllInternal(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putAsync(K, V) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
putAsync(K, V) - Method in class org.infinispan.cache.impl.CacheImpl
 
putAsync(K, V) - Method in class org.infinispan.cache.impl.CacheSupport
 
putAsync(K, V) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putAsync(K, V) - Method in class org.infinispan.cache.impl.EncoderCache
 
putAsync(K, V) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putAsync(K, V) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheSupport
 
putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
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, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
putAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
putAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
putAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putAsync(K, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
putConfiguration(String, Configuration) - Method in class org.infinispan.configuration.ConfigurationManager
 
putConfiguration(String, ConfigurationBuilder) - Method in class org.infinispan.configuration.ConfigurationManager
 
putForExternalRead(K, V) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
putForExternalRead(K, V) - Method in class org.infinispan.cache.impl.CacheImpl
 
putForExternalRead(K, V) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putForExternalRead(K, V) - Method in class org.infinispan.cache.impl.EncoderCache
 
putForExternalRead(K, V) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
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.security.impl.SecureCacheImpl
 
putForExternalRead(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
putForExternalRead(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
putForExternalRead(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putForExternalRead(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
putForExternalRead(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putForExternalRead(K, V, long, TimeUnit) - Method in interface org.infinispan.Cache
An overloaded form of #putForExternalRead(K, V), which takes in lifespan parameters.
putForExternalRead(K, V, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
putForExternalRead(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
putForExternalRead(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
putForExternalRead(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putForExternalRead(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
putForExternalRead(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putForExternalRead(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
An overloaded form of #putForExternalRead(K, V), which takes in lifespan parameters.
putForExternalRead(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
putForExternalRead(K, V, EnumSet<Flag>, ClassLoader) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
putForExternalRead(K, V, Metadata) - Method in interface org.infinispan.AdvancedCache
An overloaded form of #putForExternalRead(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.
putForExternalRead(K, V, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
putForExternalRead(K, V, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
putForExternalRead(K, V, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putForExternalRead(K, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
putForExternalRead(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putForExternalRead(K, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
putForExternalRead(K, V, Metadata, EnumSet<Flag>, ClassLoader) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
putForExternalReadInternal(K, V, Metadata, ByRef.Boolean) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putForExternalReadInternal(K, V, Metadata, ByRef.Boolean) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
putIfAbsent(K, V) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
putIfAbsent(K, V) - Method in class org.infinispan.cache.impl.CacheImpl
 
putIfAbsent(K, V) - Method in class org.infinispan.cache.impl.CacheSupport
 
putIfAbsent(K, V) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putIfAbsent(K, V) - Method in class org.infinispan.cache.impl.EncoderCache
 
putIfAbsent(K, V) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putIfAbsent(K, V) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheSupport
 
putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
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, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
putIfAbsent(K, V, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
putIfAbsent(K, V, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putIfAbsent(K, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
putIfAbsent(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putIfAbsent(K, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
putIfAbsent(WrappedBytes, InternalCacheEntry<WrappedBytes, WrappedBytes>) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
putIfAbsentAsync(K, V) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
putIfAbsentAsync(K, V) - Method in class org.infinispan.cache.impl.CacheImpl
 
putIfAbsentAsync(K, V) - Method in class org.infinispan.cache.impl.CacheSupport
 
putIfAbsentAsync(K, V) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putIfAbsentAsync(K, V) - Method in class org.infinispan.cache.impl.EncoderCache
 
putIfAbsentAsync(K, V) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putIfAbsentAsync(K, V) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheSupport
 
putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
putIfAbsentAsync(K, V, Metadata) - Method in interface org.infinispan.AdvancedCache
An overloaded form of #putIfAbsentAsync(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.
putIfAbsentAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
putIfAbsentAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
putIfAbsentAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
 
putIfAbsentAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
putIfAbsentAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putIfAbsentAsync(K, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
putIfAbsentInternal(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
putIfAbsentInternal(K, V, Metadata) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
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, int, long, CommandInvocationId) - Constructor for class org.infinispan.commands.write.PutKeyValueCommand
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in class org.infinispan.transaction.impl.LocalTransaction
 
putLookedUpEntries(Map<Object, CacheEntry>) - Method in class org.infinispan.transaction.impl.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.AbstractTxInvocationContext
 
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.context.impl.ClearInvocationContext
 
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.context.impl.ImmutableContext
 
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
Deprecated.
 
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.transaction.impl.LocalTransaction
 
putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.transaction.impl.RemoteTransaction
 
putLookedUpEntry(Object, CacheEntry) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
putLookedUpRemoteVersion(Object, EntryVersion) - Method in interface org.infinispan.transaction.xa.CacheTransaction
Deprecated.
since 9.0
PutMapBackupWriteCommand - Class in org.infinispan.commands.triangle
A BackupWriteCommand implementation for PutMapCommand.
PutMapBackupWriteCommand() - Constructor for class org.infinispan.commands.triangle.PutMapBackupWriteCommand
 
PutMapBackupWriteCommand(ByteString) - Constructor for class org.infinispan.commands.triangle.PutMapBackupWriteCommand
 
PutMapCommand - Class in org.infinispan.commands.write
 
PutMapCommand() - Constructor for class org.infinispan.commands.write.PutMapCommand
 
PutMapCommand(Map<?, ?>, CacheNotifier, Metadata, long, CommandInvocationId) - Constructor for class org.infinispan.commands.write.PutMapCommand
 
PutMapCommand(PutMapCommand) - Constructor for class org.infinispan.commands.write.PutMapCommand
 
putMemoryAddress(Object, long) - Method in class org.infinispan.container.offheap.MemoryAddressHash
 

Q

queriedAttributeNotFound(String) - Method in class org.infinispan.util.logging.Log_$logger
 
queriedAttributeNotFound(String) - Method in interface org.infinispan.util.logging.Log
 
queriedAttributeNotFound$str() - Method in class org.infinispan.util.logging.Log_$logger
 
QUERYABLE - org.infinispan.registry.InternalCacheRegistry.Flag
means that this cache should be queryable
QUEUE_FLUSH_INTERVAL - org.infinispan.configuration.parsing.Attribute
Deprecated.
QUEUE_LENGTH - org.infinispan.configuration.parsing.Attribute
 
QUEUE_SIZE - org.infinispan.configuration.parsing.Attribute
Deprecated.
QueueAsyncInvocationStage - Class in org.infinispan.interceptors.impl
Invocation stage representing a computation that may or may not be done yet.
QueueAsyncInvocationStage(InvocationContext, VisitableCommand, CompletableFuture<?>, InvocationCallback) - Constructor for class org.infinispan.interceptors.impl.QueueAsyncInvocationStage
 
queueConflictResolution(CacheTopology, Set<Address>) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
Initiates conflict resolution using the conflictTopology, which should have already been broadcast via {@link this#updateTopologiesAfterMerge(CacheTopology, CacheTopology, AvailabilityMode)}
queueConflictResolution(CacheTopology, Set<Address>) - Method in class org.infinispan.topology.ClusterCacheStatus
 
QueueingSegmentListener<K,​V,​E extends Event<K,​V>> - Interface in org.infinispan.notifications.cachelistener
This interface describes methods needed for a segment listener that is used when iterating over the current events and be able to queue them properly
queueRebalance(List<Address>) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
Queue (or start) a rebalance.
queueRebalance(List<Address>) - Method in class org.infinispan.topology.ClusterCacheStatus
 

R

RACK - org.infinispan.distribution.topologyaware.TopologyLevel
 
RACK_ID - org.infinispan.configuration.parsing.Attribute
 
RACK_ID - Static variable in class org.infinispan.configuration.global.TransportConfiguration
 
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
Deprecated.
 
randomCacheModeSynonymsDeprecated(String, String, List<String>) - Method in class org.infinispan.util.logging.Log_$logger
 
randomCacheModeSynonymsDeprecated(String, String, List<String>) - Method in interface org.infinispan.util.logging.Log
 
randomCacheModeSynonymsDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
randomClusterMembers(List<Address>, int) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
randomUUID() - Static method in class org.infinispan.topology.PersistentUUID
 
randomUUID(String, String, String, String) - Static method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
 
RangeSet - Class in org.infinispan.util
Deprecated.
Use RangeSet instead
RangeSet(int) - Constructor for class org.infinispan.util.RangeSet
Deprecated.
 
RankCalculator() - Constructor for class org.infinispan.container.versioning.NumericVersionGenerator.RankCalculator
 
read() - Method in class org.infinispan.io.GridInputStream
 
read() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
read(byte[]) - Method in class org.infinispan.io.GridInputStream
 
read(byte[]) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
read(byte[], int, int) - Method in class org.infinispan.io.GridInputStream
 
read(byte[], int, int) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
read(ByteBuffer) - Method in class org.infinispan.io.ReadableGridFileChannel
 
read(AsyncStoreConfiguration) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
read(AuthorizationConfiguration) - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
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(ContentTypeConfiguration) - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
 
read(CustomInterceptorsConfiguration) - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
 
read(CustomStoreConfiguration) - Method in class org.infinispan.configuration.cache.CustomStoreConfigurationBuilder
 
read(DataContainerConfiguration) - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
Deprecated.
 
read(DeadlockDetectionConfiguration) - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
Deprecated.
 
read(EncodingConfiguration) - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
 
read(EvictionConfiguration) - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
Deprecated.
 
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(MemoryConfiguration) - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
 
read(PartitionHandlingConfiguration) - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
 
read(PersistenceConfiguration) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
read(RecoveryConfiguration) - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
 
read(SecurityConfiguration) - Method in class org.infinispan.configuration.cache.SecurityConfigurationBuilder
 
read(SingleFileStoreConfiguration) - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
 
read(SingletonStoreConfiguration) - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
Deprecated.
 
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
Deprecated.
 
read(SyncConfiguration) - Method in class org.infinispan.configuration.cache.SyncConfigurationBuilder
Deprecated.
 
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
Deprecated.
 
read(XSiteStateTransferConfiguration) - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
 
read(ExecutorFactoryConfiguration) - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
 
read(GlobalAuthorizationConfiguration) - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
 
read(GlobalConfiguration) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
read(GlobalJmxStatisticsConfiguration) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
 
read(GlobalSecurityConfiguration) - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
 
read(GlobalStateConfiguration) - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
 
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(ThreadPoolConfiguration) - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
 
read(TransportConfiguration) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
read(PrivateGlobalConfiguration) - Method in class org.infinispan.configuration.internal.PrivateGlobalConfigurationBuilder
 
read(Role) - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
 
read(T) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
READ - org.infinispan.container.entries.ReadCommittedEntry.Flags
 
READ - org.infinispan.security.AuthorizationPermission
Allows reading data from a cache
READ_ALL_WRITE_ALL - org.infinispan.topology.CacheTopology.Phase
Used after state transfer completes: readCH == writeCH = unionCH
READ_COMMITTED - org.infinispan.util.concurrent.IsolationLevel
 
READ_NEW_WRITE_ALL - org.infinispan.topology.CacheTopology.Phase
Intermediate state that prevents ISPN-5021: readCH == pendingCH, writeCH = unionCH
READ_OLD_WRITE_ALL - org.infinispan.topology.CacheTopology.Phase
Used during state transfer: readCH == currentCH, writeCH = unionCH
READ_ONLY - org.infinispan.configuration.parsing.Attribute
 
READ_UNCOMMITTED - org.infinispan.util.concurrent.IsolationLevel
 
ReadableGridFileChannel - Class in org.infinispan.io
 
readBoolean() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readBooleanAttributeElement(XMLStreamReader, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Read an element which contains only a single boolean attribute.
readByte() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readChar() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
ReadCommittedEntry - Class in org.infinispan.container.entries
A wrapper around a cached entry that encapsulates read committed semantics when writes are initiated, committed or rolled back.
ReadCommittedEntry(Object, Object, Metadata) - Constructor for class org.infinispan.container.entries.ReadCommittedEntry
 
ReadCommittedEntry.Flags - Enum in org.infinispan.container.entries
 
readContext(int) - Method in class org.infinispan.cache.impl.DecoratedCache
 
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.Parser
 
readExternal(ObjectInput) - Method in class org.infinispan.io.GridFile.Metadata
 
readFloat() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.CancelCommand
 
readFrom(ObjectInput) - Static method in class org.infinispan.commands.CommandInvocationId
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.control.LockControlCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.CreateCacheCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.functional.ReadOnlyKeyCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.functional.ReadOnlyManyCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.functional.ReadWriteKeyCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.functional.ReadWriteKeyValueCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.functional.ReadWriteManyCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.functional.TxReadOnlyKeyCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.functional.TxReadOnlyManyCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.functional.WriteOnlyKeyCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.functional.WriteOnlyKeyValueCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.functional.WriteOnlyManyCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.functional.WriteOnlyManyEntriesCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.read.AbstractLocalCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.read.GetAllCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.read.GetCacheEntryCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.read.GetKeyValueCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.remote.ClusteredGetAllCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.remote.expiration.RetrieveLastAccessCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.remote.expiration.UpdateLastAccessCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.remote.GetKeysInGroupCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.remote.recovery.CompleteTransactionCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.remote.recovery.GetInDoubtTransactionsCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.remote.recovery.GetInDoubtTxInfoCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.remote.RenewBiasCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.remote.RevokeBiasCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.RemoveCacheCommand
Deprecated.
 
readFrom(ObjectInput) - Method in interface org.infinispan.commands.ReplicableCommand
Reads this instance from the stream written by ReplicableCommand.writeTo(ObjectOutput).
readFrom(ObjectInput) - Method in class org.infinispan.commands.triangle.MultiEntriesFunctionalBackupWriteCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.triangle.MultiKeyFunctionalBackupWriteCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.triangle.PutMapBackupWriteCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.triangle.SingleKeyBackupWriteCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.triangle.SingleKeyFunctionalBackupWriteCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.tx.PrepareCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.tx.VersionedCommitCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.tx.VersionedPrepareCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.write.ApplyDeltaCommand
Deprecated.
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.write.BackupAckCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.write.BackupMultiKeyAckCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.write.ClearCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.write.ComputeCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.write.ComputeIfAbsentCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.write.ExceptionAckCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.write.InvalidateCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.write.InvalidateL1Command
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.write.InvalidateVersionsCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.write.PutMapCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.write.RemoveCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.write.RemoveExpiredCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.commands.write.ReplaceCommand
 
readFrom(ObjectInput) - Static method in class org.infinispan.encoding.DataConversion
 
readFrom(ObjectInput) - Method in class org.infinispan.manager.impl.ReplicableCommandManagerFunction
 
readFrom(ObjectInput) - Method in class org.infinispan.manager.impl.ReplicableCommandRunnable
 
readFrom(ObjectInput) - Method in class org.infinispan.statetransfer.StateRequestCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.statetransfer.StateResponseCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.stream.impl.StreamIteratorCloseCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.stream.impl.StreamIteratorNextCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.stream.impl.StreamIteratorRequestCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.stream.impl.StreamRequestCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.stream.impl.StreamResponseCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.topology.HeartBeatCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.xsite.SingleXSiteRpcCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
 
readFrom(ObjectInput) - Method in class org.infinispan.xsite.XSiteAdminCommand
 
readFully(byte[]) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readFully(byte[], int, int) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readInt() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readLine() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readLong() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readMetadata(URL) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
 
readNeedsRemoteValue(AbstractDataCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
readObject() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readObject(ObjectInput) - Method in class org.infinispan.atomic.DeltaCompositeKey.DeltaCompositeKeyExternalizer
Deprecated.
 
readObject(ObjectInput) - Method in class org.infinispan.atomic.impl.ApplyDelta.Externalizer
Deprecated.
 
readObject(ObjectInput) - Method in class org.infinispan.atomic.impl.AtomicKeySetImpl.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.atomic.impl.AtomicKeySetImpl.FunctionExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.atomic.impl.AtomicMapProxyImpl.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.cache.impl.EncoderEntryMapper.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.cache.impl.EncoderKeyMapper.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.cache.impl.EncoderValueMapper.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.commands.functional.functions.MergeFunction.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.compat.BiFunctionMapper.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.compat.FunctionMapper.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.ImmortalCacheEntry.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.ImmortalCacheValue.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.container.entries.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.RemoteMetadata.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.impl.DefaultConsistentHashFactory.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.distribution.ch.impl.TopologyAwareConsistentHashFactory.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.encoding.DataConversion.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.filter.AcceptAllKeyValueFilter.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.filter.CacheFilters.CacheFiltersExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.filter.CollectionKeyFilter.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.filter.CompositeKeyFilter.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.filter.CompositeKeyValueFilter.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.filter.KeyFilterAsKeyValueFilter.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.filter.KeyValueFilterAsKeyFilter.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.functional.impl.EntryViews.NoValueReadOnlyViewExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.functional.impl.EntryViews.ReadOnlySnapshotViewExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.functional.impl.EntryViews.ReadWriteSnapshotViewExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata.Externalizer
 
readObject(ObjectInput) - Static method in class org.infinispan.functional.impl.Params
 
readObject(ObjectInput) - Method in class org.infinispan.functional.impl.StatsEnvelope.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.globalstate.impl.CacheState.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.globalstate.ScopedState.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.globalstate.ScopeFilter.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.interceptors.distribution.VersionedResult.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.interceptors.distribution.VersionedResults.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.ConstantLambdaExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.LambdaWithMetasExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.SetValueIfEqualsReturnBooleanExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.core.MarshalledEntryImpl.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.CollectionExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.DoubleSummaryStatisticsExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.EnumSetExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.IntSummaryStatisticsExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.LongSummaryStatisticsExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.MapExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.EntryVersionParamExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.LifespanExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.MaxIdleExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.OptionalExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.TriangleAckExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.UuidExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.metadata.EmbeddedMetadata.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.metadata.impl.InternalMetadataImpl.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEventCallable.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerRemoveCallable.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerReplicateCallable.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.notifications.cachelistener.cluster.MultiClusterEventCallable.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventConverterAsConverter.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterAsKeyValueFilter.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverterAsKeyValueFilterConverter.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.notifications.cachelistener.filter.KeyFilterAsCacheEventFilter.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterAsCacheEventFilter.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.partitionhandling.AvailabilityMode.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.remoting.MIMECacheEntry.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.remoting.responses.BiasRevocationResponse.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.statetransfer.StateChunk.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.statetransfer.TransactionInfo.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.stream.impl.AbstractCacheStream.MapOpsExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.stream.impl.EndIterator.EndIteratorExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.stream.impl.intops.IntermediateOperationExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.stream.impl.IteratorResponses.IteratorResponsesExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.stream.impl.termop.TerminalOperationExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.stream.StreamMarshalling.StreamMarshallingExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.topology.CacheJoinInfo.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.topology.CacheStatusResponse.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.topology.PersistentUUID.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction.Externalizer
Deprecated.
 
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
Deprecated.
 
readObject(ObjectInput) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.transaction.xa.recovery.SerializableXid.XidExternalizer
Deprecated.
 
readObject(ObjectInput) - Static method in class org.infinispan.util.ByteString
 
readObject(ObjectInput) - Method in class org.infinispan.util.IntSetExternalizer
 
readObject(ObjectInput) - Method in class org.infinispan.util.KeyValuePair.Externalizer
 
readObject(ObjectInput) - Method in class org.infinispan.xsite.statetransfer.XSiteState.XSiteStateExternalizer
 
readOnly(K, V, Metadata) - Static method in class org.infinispan.functional.impl.EntryViews
 
readOnly(CacheEntry) - Static method in class org.infinispan.functional.impl.EntryViews
 
readOnly(CacheEntry<K, V>, DataConversion, DataConversion) - Static method in class org.infinispan.functional.impl.EntryViews
 
ReadOnlyCollectionAsSet<T> - Class in org.infinispan.util
Assumes that the delegate collection already contains unique elements.
ReadOnlyCollectionAsSet(Collection<? extends T>) - Constructor for class org.infinispan.util.ReadOnlyCollectionAsSet
 
ReadOnlyDataContainerBackedKeySet - Class in org.infinispan.util
Deprecated.
DataContainer keySet method will be removed in the future. See DataContainer.keySet()
ReadOnlyDataContainerBackedKeySet(DataContainer) - Constructor for class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
Deprecated.
 
ReadOnlyKeyCommand<K,​V,​R> - Class in org.infinispan.commands.functional
 
ReadOnlyKeyCommand() - Constructor for class org.infinispan.commands.functional.ReadOnlyKeyCommand
 
ReadOnlyKeyCommand(Object, Function<EntryView.ReadEntryView<K, V>, R>, int, Params, DataConversion, DataConversion, ComponentRegistry) - Constructor for class org.infinispan.commands.functional.ReadOnlyKeyCommand
 
ReadOnlyManyCommand<K,​V,​R> - Class in org.infinispan.commands.functional
 
ReadOnlyManyCommand() - Constructor for class org.infinispan.commands.functional.ReadOnlyManyCommand
 
ReadOnlyManyCommand(Collection<?>, Function<EntryView.ReadEntryView<K, V>, R>, Params, DataConversion, DataConversion, ComponentRegistry) - Constructor for class org.infinispan.commands.functional.ReadOnlyManyCommand
 
ReadOnlyManyCommand(ReadOnlyManyCommand) - Constructor for class org.infinispan.commands.functional.ReadOnlyManyCommand
 
ReadOnlyManyHelper() - Constructor for class org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadOnlyManyHelper
 
ReadOnlyMapImpl<K,​V> - Class in org.infinispan.functional.impl
Read-only map implementation.
readOnlyPermissionCollection() - Method in class org.infinispan.util.logging.Log_$logger
 
readOnlyPermissionCollection() - Method in interface org.infinispan.util.logging.Log
 
readOnlyPermissionCollection$str() - Method in class org.infinispan.util.logging.Log_$logger
 
ReadOnlySegmentAwareCollection<E> - Class in org.infinispan.distribution.util
Set implementation that shows a read only view of the provided set by only allowing entries that map to a given segment using the provided consistent hash.
ReadOnlySegmentAwareCollection(Collection<E>, ConsistentHash, IntSet) - Constructor for class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
 
ReadOnlySegmentAwareEntryCollection<K,​V> - Class in org.infinispan.distribution.util
Iterator implementation that shows a read only view of the provided iterator by only allowing values that map to a given segment using the provided consistent hash.
ReadOnlySegmentAwareEntryCollection(Set<Map.Entry<K, V>>, ConsistentHash, IntSet) - Constructor for class org.infinispan.distribution.util.ReadOnlySegmentAwareEntryCollection
 
ReadOnlySegmentAwareEntryIterator<K,​V> - Class in org.infinispan.distribution.util
Iterator implementation that shows a read only view of the provided iterator by only allowing values that map to a given segment using the provided consistent hash.
ReadOnlySegmentAwareEntryIterator(Iterator<Map.Entry<K, V>>, ConsistentHash, IntSet) - Constructor for class org.infinispan.distribution.util.ReadOnlySegmentAwareEntryIterator
 
ReadOnlySegmentAwareIterator<E> - Class in org.infinispan.distribution.util
Iterator implementation that shows a read only view of the provided iterator by only allowing values that map to a given segment using the provided consistent hash.
ReadOnlySegmentAwareIterator(Iterator<E>, ConsistentHash, IntSet) - Constructor for class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator
 
ReadOnlySegmentAwareMap<K,​V> - Class in org.infinispan.distribution.util
Map implementation that shows a read only view of the provided entry by only allowing entries whose key maps to a given segment using the provided consistent hash.
ReadOnlySegmentAwareMap(Map<K, V>, ConsistentHash, IntSet) - Constructor for class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
 
ReadOnlySnapshotViewExternalizer() - Constructor for class org.infinispan.functional.impl.EntryViews.ReadOnlySnapshotViewExternalizer
 
readOwners() - Method in class org.infinispan.distribution.DistributionInfo
 
readOwnership() - Method in class org.infinispan.distribution.DistributionInfo
 
readResolve() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
readScopedState(String) - Method in interface org.infinispan.globalstate.GlobalStateManager
Reads the persistent state for the specified scope.
readScopedState(String) - Method in class org.infinispan.globalstate.impl.GlobalStateManagerImpl
 
readShort() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
readStringAttributeElement(XMLStreamReader, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Read an element which contains only a single string attribute.
readUnsignedByte() - Method in class org.infinispan.io.UnclosableObjectInputStream
 
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.impl.WriteSkewHelper
 
readWrite(MVCCEntry, Object, Metadata, DataConversion, DataConversion) - Static method in class org.infinispan.functional.impl.EntryViews
 
readWrite(MVCCEntry, DataConversion, DataConversion) - Static method in class org.infinispan.functional.impl.EntryViews
 
ReadWriteKeyCommand<K,​V,​R> - Class in org.infinispan.commands.functional
 
ReadWriteKeyCommand() - Constructor for class org.infinispan.commands.functional.ReadWriteKeyCommand
 
ReadWriteKeyCommand(Object, Function<EntryView.ReadWriteEntryView<K, V>, R>, int, CommandInvocationId, ValueMatcher, Params, DataConversion, DataConversion, ComponentRegistry) - Constructor for class org.infinispan.commands.functional.ReadWriteKeyCommand
 
ReadWriteKeyValueCommand<K,​V,​T,​R> - Class in org.infinispan.commands.functional
 
ReadWriteKeyValueCommand() - Constructor for class org.infinispan.commands.functional.ReadWriteKeyValueCommand
 
ReadWriteKeyValueCommand(Object, Object, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>, int, CommandInvocationId, ValueMatcher, Params, DataConversion, DataConversion, ComponentRegistry) - Constructor for class org.infinispan.commands.functional.ReadWriteKeyValueCommand
 
ReadWriteManyCommand<K,​V,​R> - Class in org.infinispan.commands.functional
 
ReadWriteManyCommand() - Constructor for class org.infinispan.commands.functional.ReadWriteManyCommand
 
ReadWriteManyCommand(Collection<?>, Function<EntryView.ReadWriteEntryView<K, V>, R>, Params, CommandInvocationId, DataConversion, DataConversion, ComponentRegistry) - Constructor for class org.infinispan.commands.functional.ReadWriteManyCommand
 
ReadWriteManyCommand(ReadWriteManyCommand) - Constructor for class org.infinispan.commands.functional.ReadWriteManyCommand
 
ReadWriteManyEntriesCommand<K,​V,​T,​R> - Class in org.infinispan.commands.functional
 
ReadWriteManyEntriesCommand() - Constructor for class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
ReadWriteManyEntriesCommand(Map<?, ?>, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>, Params, CommandInvocationId, DataConversion, DataConversion, ComponentRegistry) - Constructor for class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
ReadWriteManyEntriesCommand(ReadWriteManyEntriesCommand) - Constructor for class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
ReadWriteMapImpl<K,​V> - Class in org.infinispan.functional.impl
Read-write map implementation.
ReadWriteSnapshotViewExternalizer() - Constructor for class org.infinispan.functional.impl.EntryViews.ReadWriteSnapshotViewExternalizer
 
READY - org.infinispan.remoting.inboundhandler.action.ActionStatus
The action is completed successfully.
READY - org.infinispan.remoting.inboundhandler.action.BaseLockingAction.InternalState
 
READY_TOPOLOGY - org.infinispan.remoting.inboundhandler.TopologyMode
 
READY_TX_DATA - org.infinispan.remoting.inboundhandler.TopologyMode
 
ReadyAction - Interface in org.infinispan.remoting.inboundhandler.action
An interface that allows the PerCacheInboundInvocationHandler to check when this action is ready.
realCacheCollection - Variable in class org.infinispan.util.CacheCollectionMapper
Deprecated.
 
realCacheCollection - Variable in class org.infinispan.util.WriteableCacheCollectionMapper
 
realCollection - Variable in class org.infinispan.util.CollectionMapper
 
realSet - Variable in class org.infinispan.util.CacheSetMapper
 
REAPER_ENABLED - Static variable in class org.infinispan.configuration.cache.ExpirationConfiguration
 
REAPER_WAKE_UP_INTERVAL - org.infinispan.configuration.parsing.Attribute
 
REAPER_WAKE_UP_INTERVAL - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
 
reaperEnabled() - Method in class org.infinispan.configuration.cache.ExpirationConfiguration
Determines whether the background reaper thread is enabled to test entries for expiration.
reaperEnabled() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
 
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.impl.DefaultConsistentHashFactory
 
rebalance(DefaultConsistentHash) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory
 
rebalance(ReplicatedConsistentHash) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory
 
rebalance(ReplicatedConsistentHash) - Method in class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory
 
rebalance(ScatteredConsistentHash) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory
 
rebalance(CacheTopology) - Method in interface org.infinispan.topology.CacheTopologyHandler
Invoked when state transfer has to be started.
REBALANCE_PHASE_CONFIRM - org.infinispan.topology.CacheTopologyControlCommand.Type
A member is confirming that it has finished a topology change during rebalance.
REBALANCE_START - org.infinispan.topology.CacheTopologyControlCommand.Type
 
rebalanceBuilder(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
 
rebalanceBuilder(ScatteredConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory
 
rebalanceError(String, Address, int, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
rebalanceError(String, Address, int, Throwable) - Method in interface org.infinispan.util.logging.Log
 
rebalanceError$str() - Method in class org.infinispan.util.logging.Log_$logger
 
rebalanceFinished(Collection<Address>, int) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
rebalanceFinished(Collection<Address>, int) - Method in interface org.infinispan.util.logging.events.Messages
 
rebalanceFinished$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
rebalancePhaseConfirmedOnNode(CacheTopology.Phase, String, Address, int) - Method in class org.infinispan.util.logging.Log_$logger
 
rebalancePhaseConfirmedOnNode(CacheTopology.Phase, String, Address, int) - Method in interface org.infinispan.util.logging.Log
 
rebalancePhaseConfirmedOnNode$str() - Method in class org.infinispan.util.logging.Log_$logger
 
rebalanceStartError(String, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
rebalanceStartError(String, Throwable) - Method in interface org.infinispan.util.logging.Log
 
rebalanceStartError$str() - Method in class org.infinispan.util.logging.Log_$logger
 
RebalanceType - Enum in org.infinispan.statetransfer
 
REBALANCING - org.infinispan.health.HealthStatus
Given entity is healthy but a rebalance is in progress.
REBALANCING_GET_STATUS - org.infinispan.topology.CacheTopologyControlCommand.Type
 
rebalancingEnabled() - Method in class org.infinispan.util.logging.Log_$logger
 
rebalancingEnabled() - Method in interface org.infinispan.util.logging.Log
 
rebalancingEnabled$str() - Method in class org.infinispan.util.logging.Log_$logger
 
RebalancingStatus - Enum in org.infinispan.topology
RebalancingStatus.
rebalancingSuspended() - Method in class org.infinispan.util.logging.Log_$logger
 
rebalancingSuspended() - Method in interface org.infinispan.util.logging.Log
 
rebalancingSuspended$str() - Method in class org.infinispan.util.logging.Log_$logger
 
recalculateMinTopologyIdIfNeeded(CacheTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
 
receiveClusterView(View) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
receivedClusterView(String, View) - Method in class org.infinispan.util.logging.Log_$logger
 
receivedClusterView(String, View) - Method in interface org.infinispan.util.logging.Log
 
receivedClusterView$str() - Method in class org.infinispan.util.logging.Log_$logger
 
receivedMergedView(String, View) - Method in class org.infinispan.util.logging.Log_$logger
 
receivedMergedView(String, View) - Method in interface org.infinispan.util.logging.Log
 
receivedMergedView$str() - Method in class org.infinispan.util.logging.Log_$logger
 
receivedXSiteClusterView(Collection<String>) - Method in class org.infinispan.util.logging.Log_$logger
 
receivedXSiteClusterView(Collection<String>) - Method in interface org.infinispan.util.logging.Log
 
receivedXSiteClusterView$str() - Method in class org.infinispan.util.logging.Log_$logger
 
receiveResponse(Object, Address, boolean, IntSet, R1) - Method in interface org.infinispan.stream.impl.ClusterStreamManager
Receives a response for a given request
receiveResponse(Object, Address, boolean, IntSet, R1) - Method in class org.infinispan.stream.impl.ClusterStreamManagerImpl
 
receiveResponse(Object, Address, boolean, IntSet, R1) - Method in class org.infinispan.stream.impl.tx.TxClusterStreamManager
 
receiveState(Address, int, Collection<StateChunk>) - Method in interface org.infinispan.conflict.impl.StateReceiver
 
receiveState(Address, int, Collection<StateChunk>) - Method in class org.infinispan.conflict.impl.StateReceiverImpl
 
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
 
recordEviction() - Method in class org.infinispan.stats.impl.StatsCollector
 
recordHits(int, long) - Method in class org.infinispan.stats.impl.StatsCollector
 
recordMisses(int, long) - Method in class org.infinispan.stats.impl.StatsCollector
 
recordRemoveHits(int, long) - Method in class org.infinispan.stats.impl.StatsCollector
 
recordRemoveMisses(int) - Method in class org.infinispan.stats.impl.StatsCollector
 
recordStores(int, long) - Method in class org.infinispan.stats.impl.StatsCollector
 
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.
RECOVERING_CLUSTER - org.infinispan.topology.ClusterTopologyManager.ClusterManagerStatus
 
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
 
RECOVERY - org.infinispan.configuration.parsing.Element
 
RECOVERY_INFO_CACHE_NAME - org.infinispan.configuration.parsing.Attribute
 
RECOVERY_INFO_CACHE_NAME - Static variable in class org.infinispan.configuration.cache.RecoveryConfiguration
 
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
Deprecated.
Since 9.0, no longer used.
RecoveryAwareDldGlobalTransaction() - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction
Deprecated.
 
RecoveryAwareDldGlobalTransaction(Address, boolean) - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction
Deprecated.
 
RecoveryAwareDldGlobalTransaction.Externalizer - Class in org.infinispan.transaction.xa.recovery
Deprecated.
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, long) - 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, long) - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
 
RecoveryAwareRemoteTransaction(GlobalTransaction, int, long) - 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(ByteString) - 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.util.logging.Log_$logger
 
recoveryIgnored() - Method in interface org.infinispan.util.logging.Log
 
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 - Variable in class org.infinispan.transaction.xa.XaTransactionTable
 
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
 
recoveryNotSupportedWithNonTxCache() - Method in class org.infinispan.util.logging.Log_$logger
 
recoveryNotSupportedWithNonTxCache() - Method in interface org.infinispan.util.logging.Log
 
recoveryNotSupportedWithNonTxCache$str() - Method in class org.infinispan.util.logging.Log_$logger
 
recoveryNotSupportedWithSynchronization() - Method in class org.infinispan.util.logging.Log_$logger
 
recoveryNotSupportedWithSynchronization() - Method in interface org.infinispan.util.logging.Log
 
recoveryNotSupportedWithSynchronization$str() - Method in class org.infinispan.util.logging.Log_$logger
 
reduce(double, DoubleBinaryOperator) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
reduce(double, DoubleBinaryOperator) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
reduce(double, DoubleBinaryOperator) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
reduce(double, SerializableDoubleBinaryOperator) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleStream.reduce(double, DoubleBinaryOperator) except that the DoubleBinaryOperator must also implement Serializable
reduce(double, SerializableDoubleBinaryOperator) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
reduce(int, IntBinaryOperator) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
reduce(int, IntBinaryOperator) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
reduce(int, IntBinaryOperator) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
reduce(int, SerializableIntBinaryOperator) - Method in interface org.infinispan.IntCacheStream
Same as IntStream.reduce(int, IntBinaryOperator) except that the IntBinaryOperator must also implement Serializable
reduce(int, SerializableIntBinaryOperator) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
reduce(long, LongBinaryOperator) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
reduce(long, LongBinaryOperator) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
reduce(long, LongBinaryOperator) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
reduce(long, SerializableLongBinaryOperator) - Method in interface org.infinispan.LongCacheStream
Same as LongStream.reduce(long, LongBinaryOperator) except that the LongBinaryOperator must also implement Serializable.
reduce(long, SerializableLongBinaryOperator) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
reduce(BinaryOperator<R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
reduce(BinaryOperator<R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
reduce(BinaryOperator<R>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
reduce(BinaryOperator<R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
reduce(BinaryOperator<T>) - Method in interface org.infinispan.functional.Traversable
A terminal operation that applies a binary folding operation to all elements of this traversable, and wraps the result in an optional.
reduce(DoubleBinaryOperator) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
reduce(DoubleBinaryOperator) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
reduce(DoubleBinaryOperator) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
reduce(IntBinaryOperator) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
reduce(IntBinaryOperator) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
reduce(IntBinaryOperator) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
reduce(LongBinaryOperator) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
reduce(LongBinaryOperator) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
reduce(LongBinaryOperator) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
reduce(SerializableBinaryOperator<R>) - Method in interface org.infinispan.CacheStream
Same as Stream.reduce(BinaryOperator) except that the BinaryOperator must also implement Serializable
reduce(SerializableDoubleBinaryOperator) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleStream.reduce(DoubleBinaryOperator) except that the DoubleBinaryOperator must also implement Serializable
reduce(SerializableDoubleBinaryOperator) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
reduce(SerializableIntBinaryOperator) - Method in interface org.infinispan.IntCacheStream
Same as IntStream.reduce(IntBinaryOperator) except that the IntBinaryOperator must also implement Serializable
reduce(SerializableIntBinaryOperator) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
reduce(SerializableLongBinaryOperator) - Method in interface org.infinispan.LongCacheStream
Same as LongStream.reduce(LongBinaryOperator) except that the LongBinaryOperator must also implement Serializable.
reduce(SerializableLongBinaryOperator) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
reduce(R, BinaryOperator<R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
reduce(R, BinaryOperator<R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
reduce(R, BinaryOperator<R>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
reduce(R, BinaryOperator<R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
reduce(R, SerializableBinaryOperator<R>) - Method in interface org.infinispan.CacheStream
Same as Stream.reduce(Object, BinaryOperator) except that the BinaryOperator must also implement Serializable
reduce(T, BinaryOperator<T>) - Method in interface org.infinispan.functional.Traversable
A terminal operation that applies a binary folding operation to a start value and all elements of this traversable.
reduce(U, BiFunction<U, ? super R, U>, BinaryOperator<U>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
reduce(U, BiFunction<U, ? super R, U>, BinaryOperator<U>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
reduce(U, BiFunction<U, ? super R, U>, BinaryOperator<U>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
reduce(U, BiFunction<U, ? super R, U>, BinaryOperator<U>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
reduce(U, BiFunction<U, ? super T, U>, BinaryOperator<U>) - Method in interface org.infinispan.functional.Traversable
A terminal operation that applies a binary folding operation to a start value and the result of each element having a mapping function applied.
reduce(U, SerializableBiFunction<U, ? super R, U>, SerializableBinaryOperator<U>) - Method in interface org.infinispan.CacheStream
Same as Stream.reduce(Object, BiFunction, BinaryOperator) except that the BinaryOperator must also implement Serializable
REF - org.infinispan.stream.impl.IntermediateType
 
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
 
REGISTER - org.infinispan.configuration.global.ShutdownHookBehavior
Forces the cache to register a shutdown hook even if an MBean server is detected.
registerAlias(String, String, Class<?>) - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
Register an alias to another component.
registerAlias(String, String, Class<?>) - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
 
registerComponent(Class<?>, T, boolean) - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
Register a component named componentType.getName().
registerComponent(Object, Class<?>) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
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
Deprecated.
 
registerComponent(Object, String, boolean) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
registerComponent(String, T, boolean) - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
Register a component named componentName.
registerComponent(String, T, boolean) - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
 
registerComponentInternal(Object, String, boolean) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
registerDefaultClassLoader(ClassLoader) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
Since 9.4, not used
registerEncoder(Encoder) - Method in interface org.infinispan.marshall.core.EncoderRegistry
 
registerEncoder(Encoder) - Method in class org.infinispan.marshall.core.EncoderRegistryImpl
 
registerInDoubtTransaction(RecoveryAwareRemoteTransaction) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
 
registerInDoubtTransaction(RecoveryAwareRemoteTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
registerInternalCache(String, Configuration) - Method in class org.infinispan.registry.impl.InternalCacheRegistryImpl
 
registerInternalCache(String, Configuration) - Method in interface org.infinispan.registry.InternalCacheRegistry
Registers an internal cache.
registerInternalCache(String, Configuration, EnumSet<InternalCacheRegistry.Flag>) - Method in class org.infinispan.registry.impl.InternalCacheRegistryImpl
 
registerInternalCache(String, Configuration, EnumSet<InternalCacheRegistry.Flag>) - Method in interface org.infinispan.registry.InternalCacheRegistry
Registers an internal cache with the specified flags.
registerL1WriteSynchronizer(Object, L1WriteSynchronizer) - Method in class org.infinispan.distribution.impl.L1ManagerImpl
 
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.
registerListener() - Method in class org.infinispan.remoting.inboundhandler.action.CompositeAction
 
registerListener() - Method in class org.infinispan.remoting.inboundhandler.action.DefaultReadyAction
 
registerListenerInvocations(boolean, boolean, boolean, IndexedFilter<?, ?, ?>, Map<Class<? extends Annotation>, List<DelegatingCacheEntryListenerInvocation<K, V>>>, DataConversion, DataConversion) - Method in interface org.infinispan.notifications.cachelistener.filter.FilterIndexingServiceProvider
 
registerLockedKey(Object) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
registerMBean(Object) - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
 
registerMBeans(Collection<ResourceDMBean>) - Method in class org.infinispan.jmx.ComponentsJmxRegistration
Performs the MBean registration.
registerNamedComponentRegistry(ComponentRegistry, String) - Method in class org.infinispan.factories.GlobalComponentRegistry
 
registerNonVolatileComponent(Object, Class<?>) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
registerNonVolatileComponent(Object, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
registerNullComponent(String) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
registers a special "null" component that has no dependencies.
registerSegment(int) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
registerSegment(int) - Method in interface org.infinispan.scattered.ScatteredVersionManager
registerStateProvider(GlobalStateProvider) - Method in interface org.infinispan.globalstate.GlobalStateManager
Registers a state provider within this state manager
registerStateProvider(GlobalStateProvider) - Method in class org.infinispan.globalstate.impl.GlobalStateManagerImpl
 
registerSynchronization(Synchronization) - Method in class org.infinispan.transaction.tm.DummyTransaction
Deprecated.
Register a Synchronization callback with this transaction.
registerTranscoder(Transcoder) - Method in interface org.infinispan.marshall.core.EncoderRegistry
 
registerTranscoder(Transcoder) - Method in class org.infinispan.marshall.core.EncoderRegistryImpl
 
registerVersionGenerator(NumericVersionGenerator) - Method in class org.infinispan.factories.ComponentRegistry
 
registerWrapper(Wrapper) - Method in interface org.infinispan.marshall.core.EncoderRegistry
 
registerWrapper(Wrapper) - Method in class org.infinispan.marshall.core.EncoderRegistryImpl
 
registerWriteIncoming(K) - Method in interface org.infinispan.expiration.ExpirationManager
Deprecated.
since 9.3 There is no reason for this method and is implementation specific
registerXSiteCommandReceiver(boolean) - Method in class org.infinispan.remoting.inboundhandler.AbstractDelegatingHandler
 
registerXSiteCommandReceiver(boolean) - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
 
registerXSiteCommandReceiver(boolean) - Method in interface org.infinispan.remoting.inboundhandler.PerCacheInboundInvocationHandler
 
registrar - Variable in class org.infinispan.jmx.AbstractJmxRegistration
 
registry - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
registry - Variable in class org.infinispan.stream.impl.local.AbstractLocalCacheStream
 
REGULAR_MEMBER - org.infinispan.topology.ClusterTopologyManager.ClusterManagerStatus
 
regularInvalidationFinished(Object[], int[], long[], boolean[], boolean) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
rehashAware - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
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() - Method in interface org.infinispan.container.entries.InternalCacheEntry
reincarnate() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
reincarnate() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
reincarnate() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
reincarnate() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
reincarnate() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
reincarnate() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
reincarnate(long) - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
reincarnate(long) - Method in interface org.infinispan.container.entries.InternalCacheEntry
"Reincarnates" an entry.
reincarnate(long) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
reincarnate(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
reincarnate(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
reincarnate(long) - Method in class org.infinispan.container.entries.MortalCacheEntry
 
reincarnate(long) - Method in class org.infinispan.container.entries.TransientCacheEntry
 
reincarnate(long) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
RELATIVE_TO - org.infinispan.configuration.parsing.Attribute
 
release(Object) - Method in class org.infinispan.util.concurrent.locks.impl.InfinispanLock
It tries to release the lock held by lockOwner.
release(Object, Object) - Method in interface org.infinispan.util.concurrent.locks.impl.LockContainer
 
release(Object, Object) - Method in class org.infinispan.util.concurrent.locks.impl.PerKeyLockContainer
 
release(Object, Object) - Method in class org.infinispan.util.concurrent.locks.impl.StripedLockContainer
 
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.
RELEASED - org.infinispan.util.concurrent.locks.LockState
The lock owner released the lock.
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) - 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.impl.TransactionTable
 
releaseSharedTopologyLock() - Method in interface org.infinispan.statetransfer.StateTransferLock
 
releaseSharedTopologyLock() - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
remapAddresses(UnaryOperator<Address>) - Method in interface org.infinispan.distribution.ch.ConsistentHash
Returns a new ConsistentHash with the addresses remapped according to the provided UnaryOperator.
remapAddresses(UnaryOperator<Address>) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
 
remapAddresses(UnaryOperator<Address>) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
remapAddresses(UnaryOperator<Address>) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
 
remapAddresses(UnaryOperator<Address>) - Method in class org.infinispan.distribution.group.impl.PartitionerConsistentHash
 
remapCapacityFactors(UnaryOperator<Address>) - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
remapMembers(UnaryOperator<Address>) - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
REMOTE_CACHE - org.infinispan.configuration.parsing.Attribute
 
REMOTE_CACHE - Static variable in class org.infinispan.configuration.cache.BackupForConfiguration
 
REMOTE_CALL_TIMEOUT - Static variable in class org.infinispan.configuration.cache.ClusterLoaderConfiguration
 
REMOTE_COMMAND_EXECUTOR - org.infinispan.configuration.parsing.Attribute
 
REMOTE_COMMAND_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
REMOTE_ITERATION - org.infinispan.context.Flag
Flag to identify that this iteration is done on a remote node and thus no additional wrappings are required
REMOTE_ITERATION - Static variable in class org.infinispan.context.impl.FlagBitSets
 
REMOTE_SITE - org.infinispan.configuration.parsing.Attribute
 
REMOTE_SITE - Static variable in class org.infinispan.configuration.cache.BackupForConfiguration
 
REMOTE_TIMEOUT - org.infinispan.configuration.parsing.Attribute
 
REMOTE_TIMEOUT - Static variable in class org.infinispan.configuration.cache.ClusteringConfiguration
 
remoteCache() - Method in class org.infinispan.configuration.cache.BackupForConfiguration
 
remoteCache(String) - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
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
 
RemoteClusterListener - Class in org.infinispan.notifications.cachelistener.cluster
A listener that installed locally on each node when a cluster listener is installed on a given node.
RemoteClusterListener(UUID, Address, DistributedExecutorService, CacheNotifier, CacheManagerNotifier, ClusterEventManager, boolean) - Constructor for class org.infinispan.notifications.cachelistener.cluster.RemoteClusterListener
 
remoteCommandsExecutor - Variable in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
 
remoteCommandsExecutor - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
remoteCommandsExecutor() - Method in class org.infinispan.configuration.global.GlobalConfiguration
Deprecated.
This method always returns null now. Look for a thread pool named as TransportConfiguration.remoteCommandThreadPool() instead.
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
 
remoteCommandThreadPool() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
remoteCommandThreadPool() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
remoteException(Address, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
remoteException(Address, Throwable) - Method in interface org.infinispan.util.logging.Log
 
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$str() - Method in class org.infinispan.util.logging.Log_$logger
 
remoteExecutionFailed(Address, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
remoteExecutionFailed(Address, Throwable) - Method in interface org.infinispan.util.logging.Log
 
remoteExecutionFailed$str() - Method in class org.infinispan.util.logging.Log_$logger
 
remoteExecutor - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
remoteGet(InvocationContext, C, Object, boolean) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
remoteGet(InvocationContext, C, Object, boolean) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
remoteGetAll(InvocationContext, C, Collection<?>, BaseDistributionInterceptor.RemoteGetAllHandler) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
RemoteGetResponseCollector - Class in org.infinispan.remoting.transport
Return the first response that is either successful or exceptional.
RemoteGetResponseCollector() - Constructor for class org.infinispan.remoting.transport.RemoteGetResponseCollector
 
remoteIterationPublisher(boolean, Supplier<Map.Entry<Address, IntSet>>, Set<K>, IntFunction<Set<K>>, boolean, boolean, Iterable<IntermediateOperation>) - Method in interface org.infinispan.stream.impl.ClusterStreamManager
 
remoteIterationPublisher(boolean, Supplier<Map.Entry<Address, IntSet>>, Set<K>, IntFunction<Set<K>>, boolean, boolean, Iterable<IntermediateOperation>) - Method in class org.infinispan.stream.impl.ClusterStreamManagerImpl
 
remoteIterationPublisher(boolean, Supplier<Map.Entry<Address, IntSet>>, Set<K>, IntFunction<Set<K>>, boolean, boolean, Iterable<IntermediateOperation>) - Method in class org.infinispan.stream.impl.PartitionAwareClusterStreamManager
 
remoteIterationPublisher(boolean, Supplier<Map.Entry<Address, IntSet>>, Set<K>, IntFunction<Set<K>>, boolean, boolean, Iterable<IntermediateOperation>) - Method in class org.infinispan.stream.impl.tx.TxClusterStreamManager
 
RemoteLockCommand - Interface in org.infinispan.util.concurrent.locks
Simple interface to extract all the keys that may need to be locked.
remoteLocksAcquired(Collection<Address>) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
RemoteMetadata - Class in org.infinispan.container.entries
This is a metadata type used by scattered cache during state transfer.
RemoteMetadata(Address, EntryVersion) - Constructor for class org.infinispan.container.entries.RemoteMetadata
 
RemoteMetadata.Externalizer - Class in org.infinispan.container.entries
 
remoteNodeSuspected(Address) - Static method in class org.infinispan.remoting.transport.ResponseCollectors
 
remoteNodeSuspected(Address) - Method in class org.infinispan.util.logging.Log_$logger
 
remoteNodeSuspected(Address) - Method in interface org.infinispan.util.logging.Log
 
remoteNodeSuspected$str() - Method in class org.infinispan.util.logging.Log_$logger
 
remoteNodeTimedOut(Address, long, TimeUnit) - Method in class org.infinispan.util.logging.Log_$logger
 
remoteNodeTimedOut(Address, long, TimeUnit) - Method in interface org.infinispan.util.logging.Log
 
remoteNodeTimedOut$str() - Method in class org.infinispan.util.logging.Log_$logger
 
remoteReadOnlyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
remoteReadOnlyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
remoteSite() - Method in class org.infinispan.configuration.cache.BackupForConfiguration
 
remoteSite(String) - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
remoteStreamOperation(boolean, boolean, ConsistentHash, IntSet, Set<K>, Map<Integer, Set<K>>, boolean, boolean, KeyTrackingTerminalOperation<Original, K, R>, ClusterStreamManager.ResultsCallback<Collection<R>>) - Method in interface org.infinispan.stream.impl.ClusterStreamManager
Key tracking remote operation that doesn't have rehash enabled.
remoteStreamOperation(boolean, boolean, ConsistentHash, IntSet, Set<K>, Map<Integer, Set<K>>, boolean, boolean, KeyTrackingTerminalOperation<Original, K, R>, ClusterStreamManager.ResultsCallback<Collection<R>>) - Method in class org.infinispan.stream.impl.ClusterStreamManagerImpl
 
remoteStreamOperation(boolean, boolean, ConsistentHash, IntSet, Set<K>, Map<Integer, Set<K>>, boolean, boolean, KeyTrackingTerminalOperation<Original, K, R>, ClusterStreamManager.ResultsCallback<Collection<R>>) - Method in class org.infinispan.stream.impl.PartitionAwareClusterStreamManager
 
remoteStreamOperation(boolean, boolean, ConsistentHash, IntSet, Set<K>, Map<Integer, Set<K>>, boolean, boolean, KeyTrackingTerminalOperation<Original, K, R>, ClusterStreamManager.ResultsCallback<Collection<R>>) - Method in class org.infinispan.stream.impl.tx.TxClusterStreamManager
 
remoteStreamOperation(boolean, boolean, ConsistentHash, IntSet, Set<K>, Map<Integer, Set<K>>, boolean, boolean, TerminalOperation<Original, R>, ClusterStreamManager.ResultsCallback<R>, Predicate<? super R>) - Method in interface org.infinispan.stream.impl.ClusterStreamManager
Performs the remote stream operation without rehash awareness.
remoteStreamOperation(boolean, boolean, ConsistentHash, IntSet, Set<K>, Map<Integer, Set<K>>, boolean, boolean, TerminalOperation<Original, R>, ClusterStreamManager.ResultsCallback<R>, Predicate<? super R>) - Method in class org.infinispan.stream.impl.ClusterStreamManagerImpl
 
remoteStreamOperation(boolean, boolean, ConsistentHash, IntSet, Set<K>, Map<Integer, Set<K>>, boolean, boolean, TerminalOperation<Original, R>, ClusterStreamManager.ResultsCallback<R>, Predicate<? super R>) - Method in class org.infinispan.stream.impl.PartitionAwareClusterStreamManager
 
remoteStreamOperation(boolean, boolean, ConsistentHash, IntSet, Set<K>, Map<Integer, Set<K>>, boolean, boolean, TerminalOperation<Original, R>, ClusterStreamManager.ResultsCallback<R>, Predicate<? super R>) - Method in class org.infinispan.stream.impl.tx.TxClusterStreamManager
 
remoteStreamOperationRehashAware(boolean, boolean, ConsistentHash, IntSet, Set<K>, Map<Integer, Set<K>>, boolean, boolean, KeyTrackingTerminalOperation<Original, K, ?>, ClusterStreamManager.ResultsCallback<Collection<K>>) - Method in interface org.infinispan.stream.impl.ClusterStreamManager
Key tracking remote operation that has rehash enabled
remoteStreamOperationRehashAware(boolean, boolean, ConsistentHash, IntSet, Set<K>, Map<Integer, Set<K>>, boolean, boolean, KeyTrackingTerminalOperation<Original, K, ?>, ClusterStreamManager.ResultsCallback<Collection<K>>) - Method in class org.infinispan.stream.impl.ClusterStreamManagerImpl
 
remoteStreamOperationRehashAware(boolean, boolean, ConsistentHash, IntSet, Set<K>, Map<Integer, Set<K>>, boolean, boolean, KeyTrackingTerminalOperation<Original, K, ?>, ClusterStreamManager.ResultsCallback<Collection<K>>) - Method in class org.infinispan.stream.impl.PartitionAwareClusterStreamManager
 
remoteStreamOperationRehashAware(boolean, boolean, ConsistentHash, IntSet, Set<K>, Map<Integer, Set<K>>, boolean, boolean, KeyTrackingTerminalOperation<Original, K, ?>, ClusterStreamManager.ResultsCallback<Collection<K>>) - Method in class org.infinispan.stream.impl.tx.TxClusterStreamManager
 
remoteStreamOperationRehashAware(boolean, boolean, ConsistentHash, IntSet, Set<K>, Map<Integer, Set<K>>, boolean, boolean, TerminalOperation<Original, R>, ClusterStreamManager.ResultsCallback<R>, Predicate<? super R>) - Method in interface org.infinispan.stream.impl.ClusterStreamManager
Performs the remote stream operation with rehash awareness.
remoteStreamOperationRehashAware(boolean, boolean, ConsistentHash, IntSet, Set<K>, Map<Integer, Set<K>>, boolean, boolean, TerminalOperation<Original, R>, ClusterStreamManager.ResultsCallback<R>, Predicate<? super R>) - Method in class org.infinispan.stream.impl.ClusterStreamManagerImpl
 
remoteStreamOperationRehashAware(boolean, boolean, ConsistentHash, IntSet, Set<K>, Map<Integer, Set<K>>, boolean, boolean, TerminalOperation<Original, R>, ClusterStreamManager.ResultsCallback<R>, Predicate<? super R>) - Method in class org.infinispan.stream.impl.PartitionAwareClusterStreamManager
 
remoteStreamOperationRehashAware(boolean, boolean, ConsistentHash, IntSet, Set<K>, Map<Integer, Set<K>>, boolean, boolean, TerminalOperation<Original, R>, ClusterStreamManager.ResultsCallback<R>, Predicate<? super R>) - Method in class org.infinispan.stream.impl.tx.TxClusterStreamManager
 
remoteTimeout() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
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.
remoteTimeout(long) - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
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.
remoteTimeout(long) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
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.
remoteTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
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.
RemoteTransaction - Class in org.infinispan.transaction.impl
Defines the state of a remotely originated transaction.
RemoteTransaction(WriteCommand[], GlobalTransaction, int, long) - Constructor for class org.infinispan.transaction.impl.RemoteTransaction
 
RemoteTransaction(GlobalTransaction, int, long) - Constructor for class org.infinispan.transaction.impl.RemoteTransaction
 
remoteTransactionAlreadyCompleted(GlobalTransaction) - Method in class org.infinispan.util.logging.Log_$logger
 
remoteTransactionAlreadyCompleted(GlobalTransaction) - Method in interface org.infinispan.util.logging.Log
 
remoteTransactionAlreadyCompleted$str() - Method in class org.infinispan.util.logging.Log_$logger
 
remoteTransactionAlreadyRolledBack(GlobalTransaction) - Method in class org.infinispan.util.logging.Log_$logger
 
remoteTransactionAlreadyRolledBack(GlobalTransaction) - Method in interface org.infinispan.util.logging.Log
 
remoteTransactionAlreadyRolledBack$str() - Method in class org.infinispan.util.logging.Log_$logger
 
remoteTransactionCommitted(GlobalTransaction, boolean) - Method in class org.infinispan.transaction.impl.TransactionTable
Removes the RemoteTransaction corresponding to the given tx.
remoteTransactionCommitted(GlobalTransaction, boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
 
remoteTransactionOriginatorNotInView(GlobalTransaction) - Method in class org.infinispan.util.logging.Log_$logger
 
remoteTransactionOriginatorNotInView(GlobalTransaction) - Method in interface org.infinispan.util.logging.Log
 
remoteTransactionOriginatorNotInView$str() - Method in class org.infinispan.util.logging.Log_$logger
 
remoteTransactionPrepared(GlobalTransaction) - Method in class org.infinispan.transaction.impl.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.impl.TransactionTable
 
remoteTransactionRollback(GlobalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
 
remoteTransactionStatusMissing(GlobalTransaction) - Method in class org.infinispan.util.logging.Log_$logger
 
remoteTransactionStatusMissing(GlobalTransaction) - Method in interface org.infinispan.util.logging.Log
 
remoteTransactionStatusMissing$str() - Method in class org.infinispan.util.logging.Log_$logger
 
remoteTransactionTimeout(GlobalTransaction, long) - Method in class org.infinispan.util.logging.Log_$logger
 
remoteTransactionTimeout(GlobalTransaction, long) - Method in interface org.infinispan.util.logging.Log
 
remoteTransactionTimeout$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(RemoteTransaction) - Constructor for class org.infinispan.context.impl.RemoteTxInvocationContext
 
remoteValueFound(InternalCacheEntry) - Method in class org.infinispan.distribution.impl.L1ManagerImpl
 
remoteValueFound(InternalCacheEntry) - Method in interface org.infinispan.distribution.RemoteValueRetrievedListener
Invoked when a remote value is found from a remote source
remoteValueNotFound(Object) - Method in class org.infinispan.distribution.impl.L1ManagerImpl
 
remoteValueNotFound(Object) - Method in interface org.infinispan.distribution.RemoteValueRetrievedListener
Invoked when a remote value is not found from the remote source for the given key
RemoteValueRetrievedListener - Interface in org.infinispan.distribution
Listener that is notified when a remote value is looked up
RemovableCloseableIterator<K,​C> - Class in org.infinispan.stream.impl
Deprecated.
Users should use RemovableCloseableIterator instead
RemovableCloseableIterator(CloseableIterator<C>, Cache<K, ?>, Function<? super C, K>) - Constructor for class org.infinispan.stream.impl.RemovableCloseableIterator
Deprecated.
 
RemovableFunction<T,​R> - Interface in org.infinispan.util.function
Deprecated.
since 9.2.1 this interface is no longer supported as we don't support remove operation on iterators produced from a Stream
RemovableIterator<K,​C> - Class in org.infinispan.stream.impl
Deprecated.
Users should use RemovableIterator instead
RemovableIterator(Iterator<C>, Cache<K, ?>, Function<? super C, K>) - Constructor for class org.infinispan.stream.impl.RemovableIterator
Deprecated.
 
remove() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator
 
remove() - Method in interface org.infinispan.functional.EntryView.WriteEntryView
Removes the value and any metadata parameters associated with it.
remove() - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
 
remove() - Method in class org.infinispan.util.DataContainerRemoveIterator
 
remove(int, Object) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
remove(int, Object) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
remove(int, Object) - Method in interface org.infinispan.container.impl.InternalDataContainer
Same as DataContainer.remove(Object) except that the segment of the key can provided to remove the entry without calculating the segment for the given key.
remove(int, Object) - Method in class org.infinispan.container.impl.InternalDataContainerAdapter
 
remove(Object) - Method in class org.infinispan.atomic.impl.AtomicMapProxyImpl
 
remove(Object) - Method in class org.infinispan.atomic.impl.FineGrainedAtomicMapProxyImpl
 
remove(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
remove(Object) - Method in class org.infinispan.cache.impl.CacheImpl
 
remove(Object) - Method in class org.infinispan.cache.impl.DecoratedCache
 
remove(Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
remove(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySetBase
 
remove(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.KeySet
 
remove(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
remove(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.Values
 
remove(Object) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
remove(Object) - Method in class org.infinispan.commands.read.AbstractCloseableIteratorCollection
 
remove(Object) - Method in interface org.infinispan.container.DataContainer
Removes an entry from the cache
remove(Object) - Method in class org.infinispan.container.impl.AbstractDelegatingDataContainer
 
remove(Object) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
remove(Object) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
remove(Object) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
remove(Object) - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingEntrySet
 
remove(Object) - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingKeySet
 
remove(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
remove(Object) - Method in class org.infinispan.stream.impl.local.ValueCacheCollection
 
remove(Object) - Method in class org.infinispan.util.CollectionMapper
 
remove(Object) - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
 
remove(Object) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
Deprecated.
 
remove(Object) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
 
remove(Object, Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
remove(Object, Object) - Method in class org.infinispan.cache.impl.CacheImpl
 
remove(Object, Object) - Method in class org.infinispan.cache.impl.DecoratedCache
 
remove(Object, Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
remove(Object, Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
remove(Object, Object) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
remove(Object, Object) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
remove(Object, Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
remove(T) - Method in class org.infinispan.util.DependencyGraph
Remove element from the graph
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 - org.infinispan.eviction.EvictionStrategy
Strategy where the cache will remove entries to make room for new ones while staying under the configured size
REMOVE - org.infinispan.persistence.modifications.Modification.Type
 
REMOVE_ALL - org.infinispan.conflict.MergePolicy
 
REMOVE_ALL - Static variable in class org.infinispan.conflict.MergePolicies
Deprecated.
 
REMOVE_DATA_ON_STOP - org.infinispan.context.Flag
Deprecated.
No longer in use.
REMOVE_DATA_ON_STOP - Static variable in class org.infinispan.context.impl.FlagBitSets
 
removeAll(Collection<?>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySetBase
 
removeAll(Collection<?>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.KeySet
 
removeAll(Collection<?>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.Values
 
removeAll(Collection<?>) - Method in class org.infinispan.commands.read.AbstractCloseableIteratorCollection
 
removeAll(Collection<?>) - Method in class org.infinispan.util.CollectionMapper
 
removeAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
 
removeAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
Deprecated.
 
removeAll(Collection<?>) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
 
removeAsync(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
removeAsync(Object) - Method in class org.infinispan.cache.impl.CacheImpl
 
removeAsync(Object) - Method in class org.infinispan.cache.impl.DecoratedCache
 
removeAsync(Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
removeAsync(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
removeAsync(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
removeAsync(Object, Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
removeAsync(Object, Object) - Method in class org.infinispan.cache.impl.CacheImpl
 
removeAsync(Object, Object) - Method in class org.infinispan.cache.impl.DecoratedCache
 
removeAsync(Object, Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
removeAsync(Object, Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
removeAsync(Object, Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
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.
removeBackupLock(Object) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
removeBackupLock(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
It cleans up the backup for key.
removeBackupLocks(Collection<?>) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
removeBackupLocks(Collection<?>) - Method in interface org.infinispan.transaction.xa.CacheTransaction
It cleans up the backup lock for the keys.
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.DefaultCacheManager
 
removeCache(String) - Method in class org.infinispan.manager.DefaultCacheManagerAdmin
 
removeCache(String) - Method in interface org.infinispan.manager.EmbeddedCacheManager
Deprecated.
obtain a CacheContainerAdmin instance using EmbeddedCacheManager.administration() and invoke the CacheContainerAdmin.removeCache(String) method
removeCache(String) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
removeCache(String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.GlobalConfigurationManager
Removes a cluster-wide cache and its configuration
removeCache(String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.GlobalConfigurationManagerImpl
 
removeCache(String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.ImmutableLocalConfigurationStorage
 
removeCache(String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.OverlayLocalConfigurationStorage
 
removeCache(String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
 
removeCache(String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.LocalConfigurationStorage
Removes the specified cache.
removeCache(EmbeddedCacheManager, String) - Static method in class org.infinispan.commands.RemoveCacheCommand
Deprecated.
 
removeCache(CacheEntryRemovedEvent<ScopedState, CacheState>) - Method in class org.infinispan.globalstate.impl.GlobalConfigurationStateListener
 
RemoveCacheCommand - Class in org.infinispan.commands
Deprecated.
Use CacheContainerAdmin.removeCache(String) instead
RemoveCacheCommand(ByteString, EmbeddedCacheManager) - Constructor for class org.infinispan.commands.RemoveCacheCommand
Deprecated.
 
RemoveCommand - Class in org.infinispan.commands.write
 
RemoveCommand() - Constructor for class org.infinispan.commands.write.RemoveCommand
 
RemoveCommand(Object, Object, CacheNotifier, int, long, CommandInvocationId) - Constructor for class org.infinispan.commands.write.RemoveCommand
 
removeConfiguration(String) - Method in class org.infinispan.configuration.ConfigurationManager
 
removeConsumer() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
REMOVED - org.infinispan.container.entries.ReadCommittedEntry.Flags
 
REMOVED - Static variable in interface org.infinispan.notifications.cachelistener.QueueingSegmentListener
 
removeDependency(T, T) - Method in class org.infinispan.util.DependencyGraph
Remove a dependency
removeEntry(Object) - Method in class org.infinispan.persistence.support.BatchModification
 
RemoveExpiredCommand - Class in org.infinispan.commands.write
Removes an entry that is expired from memory
RemoveExpiredCommand() - Constructor for class org.infinispan.commands.write.RemoveExpiredCommand
 
RemoveExpiredCommand(Object, Object, Long, boolean, CacheNotifier, int, long, CommandInvocationId, IncrementableEntryVersion, TimeService) - Constructor for class org.infinispan.commands.write.RemoveExpiredCommand
 
removeExtraBackupOwners(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
 
removeGroup(String) - Method in interface org.infinispan.AdvancedCache
It removes all the key which belongs to a group.
removeGroup(String) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
removeGroup(String) - Method in class org.infinispan.cache.impl.CacheImpl
 
removeGroup(String) - Method in class org.infinispan.cache.impl.DecoratedCache
 
removeGroup(String) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
removeGroup(String) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
removeIf(Predicate<? super R>) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
 
removeIfValueEqualsReturnBoolean() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
removeInterceptor(int) - Method in interface org.infinispan.AdvancedCache
Deprecated.
removeInterceptor(int) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
removeInterceptor(int) - Method in class org.infinispan.cache.impl.CacheImpl
 
removeInterceptor(int) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
removeInterceptor(int) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Removes the interceptor at the given position.
removeInterceptor(int) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
removeInterceptor(int) - Method in class org.infinispan.interceptors.impl.AsyncInterceptorChainImpl
 
removeInterceptor(int) - Method in class org.infinispan.interceptors.InterceptorChain
Deprecated.
Removes the interceptor at the given postion.
removeInterceptor(int) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
removeInterceptor(Class<? extends AsyncInterceptor>) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Removes all the occurrences of supplied interceptor type from the chain.
removeInterceptor(Class<? extends AsyncInterceptor>) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
removeInterceptor(Class<? extends AsyncInterceptor>) - Method in class org.infinispan.interceptors.impl.AsyncInterceptorChainImpl
 
removeInterceptor(Class<? extends CommandInterceptor>) - Method in interface org.infinispan.AdvancedCache
Deprecated.
removeInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
removeInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.cache.impl.CacheImpl
 
removeInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
removeInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
Deprecated.
Removes all the occurences of supplied interceptor type from the chain.
removeInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
removeInvalidationsFinished() - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
removeLifespanExpired(K, V, Long) - Method in interface org.infinispan.AdvancedCache
Attempts to remove the entry if it is expired.
removeLifespanExpired(K, V, Long) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
removeLifespanExpired(K, V, Long) - Method in class org.infinispan.cache.impl.CacheImpl
 
removeLifespanExpired(K, V, Long) - Method in class org.infinispan.cache.impl.DecoratedCache
 
removeLifespanExpired(K, V, Long) - Method in class org.infinispan.cache.impl.EncoderCache
 
removeLifespanExpired(K, V, Long) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
removeLifespanExpired(K, V, Long) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
removeListener() - Method in class org.infinispan.notifications.cachelistener.cluster.RemoteClusterListener
 
removeListener() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
removeListener(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
removeListener(Object) - Method in class org.infinispan.cache.impl.CacheImpl
 
removeListener(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
removeListener(Object) - Method in class org.infinispan.manager.DefaultCacheManager
 
removeListener(Object) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
removeListener(Object) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
removeListener(Object) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
 
removeListener(Object) - Method in interface org.infinispan.notifications.Listenable
Removes a listener from the component.
removeListener(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
RemoveListenerAction - Class in org.infinispan.security.actions
RemoveListenerAction
RemoveListenerAction(Listenable, Object) - Constructor for class org.infinispan.security.actions.RemoveListenerAction
 
removeListenerInvocation(Class<? extends Annotation>, Object) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
removeListenerInvocation(Class<? extends Annotation>, Object) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
 
removeLocalTransaction(LocalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
Removes the TransactionXaAdapter corresponding to the given tx.
removeLocalTransaction(LocalTransaction) - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
removeLookedUpEntries(Collection<?>) - Method in interface org.infinispan.context.EntryLookup
 
removeLookedUpEntry(Object) - Method in interface org.infinispan.context.EntryLookup
 
removeLookedUpEntry(Object) - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
removeLookedUpEntry(Object) - Method in class org.infinispan.context.impl.ClearInvocationContext
 
removeLookedUpEntry(Object) - Method in class org.infinispan.context.impl.ImmutableContext
 
removeLookedUpEntry(Object) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
removeLookedUpEntry(Object) - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
Deprecated.
 
removeLookedUpEntry(Object) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
removeLookedUpEntry(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
removeMap(Cache<Object, Object>, Object) - Static method in class org.infinispan.atomic.impl.FineGrainedAtomicMapProxyImpl
Warning: with pessimistic locking/optimistic locking without WSC, when the map is removed and a new key is added before the removal transaction commit, the map may be removed but the key left dangling.
removeMaxIdleExpired(K, V) - Method in interface org.infinispan.AdvancedCache
Attempts to remove the entry for the given key, if it has expired due to max idle.
removeMaxIdleExpired(K, V) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
removeMaxIdleExpired(K, V) - Method in class org.infinispan.cache.impl.CacheImpl
 
removeMaxIdleExpired(K, V) - Method in class org.infinispan.cache.impl.DecoratedCache
 
removeMaxIdleExpired(K, V) - Method in class org.infinispan.cache.impl.EncoderCache
 
removeMaxIdleExpired(K, V) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
removeMaxIdleExpired(K, V) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
removeOwner(int, Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
removePersistentAddressMapping(Address) - Method in interface org.infinispan.topology.PersistentUUIDManager
Removes any address mapping for the specified Address
removePersistentAddressMapping(Address) - Method in class org.infinispan.topology.PersistentUUIDManagerImpl
 
removePersistentAddressMapping(PersistentUUID) - Method in interface org.infinispan.topology.PersistentUUIDManager
Removes any address mapping for the specified PersistentUUID
removePersistentAddressMapping(PersistentUUID) - Method in class org.infinispan.topology.PersistentUUIDManagerImpl
 
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(Long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
removeRecoveryInformation(Collection<Address>, Xid, boolean, GlobalTransaction, boolean) - 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.
removeRecoveryInformation(Collection<Address>, Xid, boolean, GlobalTransaction, boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
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
 
removeRecoveryInformationFromCluster(Collection<Address>, long, boolean) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
removeRecoveryInformationFromCluster(Collection<Address>, long, boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
removeRemoteTransaction(Xid) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
 
removeRemoteTransaction(GlobalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
 
removeRemovalListener(Object) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
removeRemovalListener(Object) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
removeRemovalListener(Object) - Method in interface org.infinispan.container.impl.InternalDataContainer
Removes a previously registered listener via InternalDataContainer.addRemovalListener(Consumer).
removeRemovalListener(Object) - Method in class org.infinispan.container.impl.InternalDataContainerAdapter
 
removeRequest(long) - Method in class org.infinispan.remoting.transport.impl.RequestRepository
 
removeReturnBoolean() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
removeReturnPrevOrNull() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
removeSegments(IntSet) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
removeSegments(IntSet) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
removeSegments(IntSet) - Method in class org.infinispan.container.impl.DefaultDataContainer
 
removeSegments(IntSet) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
removeSegments(IntSet) - Method in interface org.infinispan.container.impl.InternalDataContainer
Removes and un-associates the given segments.
removeSegments(IntSet) - Method in class org.infinispan.container.impl.InternalDataContainerAdapter
 
removeSegments(IntSet) - Method in class org.infinispan.container.impl.L1SegmentedDataContainer
 
removeSegments(IntSet) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
removeSegments(IntSet) - Method in interface org.infinispan.persistence.manager.PersistenceManager
Notifies any underlying segmented stores that a given segment is no longer owned by this cache and allowing it to remove the given segments and release resources related to it.
removeSegments(IntSet) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
removeSegments(IntSet) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
Invoked when a node loses ownership of a segment.
removeSegments(IntSet) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
removeShutdownHook() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
removeShutdownHook() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
removeStaleData(IntSet) - Method in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
removeStaleData(IntSet) - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
removeTransfer(InboundTransferTask) - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
renameTo(File) - Method in class org.infinispan.io.GridFile
 
RenewBiasCommand - Class in org.infinispan.commands.remote
 
RenewBiasCommand() - Constructor for class org.infinispan.commands.remote.RenewBiasCommand
 
RenewBiasCommand(ByteString) - Constructor for class org.infinispan.commands.remote.RenewBiasCommand
 
RenewBiasCommand(ByteString, Object[]) - Constructor for class org.infinispan.commands.remote.RenewBiasCommand
 
renewRemoteBias(Object, Address) - Method in interface org.infinispan.scattered.BiasManager
Notify the component that the node is reading the biased entry and the bias should not be revoked unless necessary.
renewRemoteBias(Object, Address) - Method in class org.infinispan.scattered.impl.BiasManagerImpl
 
REPEATABLE_READ - org.infinispan.util.concurrent.IsolationLevel
 
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
 
REPL - org.infinispan.configuration.parsing.ParsedCacheMode
 
REPL_ASYNC - org.infinispan.configuration.cache.CacheMode
Data replicated asynchronously.
REPL_SYNC - org.infinispan.configuration.cache.CacheMode
Data replicated synchronously.
REPL_TIMEOUT - Static variable in class org.infinispan.configuration.cache.SyncConfiguration
Deprecated.
replace(String, String, BackupReceiver) - Method in class org.infinispan.xsite.BackupReceiverRepositoryImpl
 
replace(K, V) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
replace(K, V) - Method in class org.infinispan.cache.impl.CacheImpl
 
replace(K, V) - Method in class org.infinispan.cache.impl.CacheSupport
 
replace(K, V) - Method in class org.infinispan.cache.impl.DecoratedCache
 
replace(K, V) - Method in class org.infinispan.cache.impl.EncoderCache
 
replace(K, V) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
replace(K, V) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
replace(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
replace(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
replace(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheSupport
 
replace(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
 
replace(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
replace(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
replace(K, V, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
 
replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
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, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
replace(K, V, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
replace(K, V, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
 
replace(K, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
replace(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
replace(K, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
replace(K, V, V) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
replace(K, V, V) - Method in class org.infinispan.cache.impl.CacheImpl
 
replace(K, V, V) - Method in class org.infinispan.cache.impl.CacheSupport
 
replace(K, V, V) - Method in class org.infinispan.cache.impl.DecoratedCache
 
replace(K, V, V) - Method in class org.infinispan.cache.impl.EncoderCache
 
replace(K, V, V) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
replace(K, V, V) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheSupport
 
replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
 
replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
 
replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
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, V, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
replace(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
replace(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
 
replace(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
replace(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
replace(K, V, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
replace(WrappedBytes, InternalCacheEntry<WrappedBytes, WrappedBytes>) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
replace(WrappedBytes, InternalCacheEntry<WrappedBytes, WrappedBytes>, InternalCacheEntry<WrappedBytes, WrappedBytes>) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.EncoderCache
 
replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
replaceAsync(K, V) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
replaceAsync(K, V) - Method in class org.infinispan.cache.impl.CacheImpl
 
replaceAsync(K, V) - Method in class org.infinispan.cache.impl.CacheSupport
 
replaceAsync(K, V) - Method in class org.infinispan.cache.impl.DecoratedCache
 
replaceAsync(K, V) - Method in class org.infinispan.cache.impl.EncoderCache
 
replaceAsync(K, V) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
replaceAsync(K, V) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheSupport
 
replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
 
replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
 
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
replaceAsync(K, V, Metadata) - Method in interface org.infinispan.AdvancedCache
An overloaded form of #replaceAsync(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.
replaceAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
replaceAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
replaceAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
 
replaceAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
replaceAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
replaceAsync(K, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
replaceAsync(K, V, V) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
replaceAsync(K, V, V) - Method in class org.infinispan.cache.impl.CacheImpl
 
replaceAsync(K, V, V) - Method in class org.infinispan.cache.impl.CacheSupport
 
replaceAsync(K, V, V) - Method in class org.infinispan.cache.impl.DecoratedCache
 
replaceAsync(K, V, V) - Method in class org.infinispan.cache.impl.EncoderCache
 
replaceAsync(K, V, V) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
replaceAsync(K, V, V) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheSupport
 
replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
 
replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
 
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
replaceAsync(K, V, V, Metadata) - Method in interface org.infinispan.AdvancedCache
 
replaceAsync(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
replaceAsync(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
replaceAsync(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
 
replaceAsync(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
replaceAsync(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
replaceAsync(K, V, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
replaceBackupOwners(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
 
ReplaceCommand - Class in org.infinispan.commands.write
 
ReplaceCommand() - Constructor for class org.infinispan.commands.write.ReplaceCommand
 
ReplaceCommand(Object, Object, Object, CacheNotifier, Metadata, int, long, CommandInvocationId) - Constructor for class org.infinispan.commands.write.ReplaceCommand
 
replaceComponent(String, Object, boolean) - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
Replace an existing component.
replaceComponent(String, Object, boolean) - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
 
replaceEventLogger(EventLogger) - Method in interface org.infinispan.util.logging.events.EventLogManager
Replaces the event logger with the provided one.
replaceEventLogger(EventLogger) - Method in class org.infinispan.util.logging.events.impl.EventLogManagerImpl
 
replaceInterceptor(AsyncInterceptor, Class<? extends AsyncInterceptor>) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Replaces an existing interceptor of the given type in the interceptor chain with a new interceptor instance passed as parameter.
replaceInterceptor(AsyncInterceptor, Class<? extends AsyncInterceptor>) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
replaceInterceptor(AsyncInterceptor, Class<? extends AsyncInterceptor>) - Method in class org.infinispan.interceptors.impl.AsyncInterceptorChainImpl
 
replaceInterceptor(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
Deprecated.
Replaces an existing interceptor of the given type in the interceptor chain with a new interceptor instance passed as parameter.
replaceInternal(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
replaceInternal(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
replaceKey(Object, Object) - Method in class org.infinispan.commands.control.LockControlCommand
 
replaceKeys(Map<Object, Object>) - Method in class org.infinispan.commands.control.LockControlCommand
 
replacePrimaryOwners(DefaultConsistentHashFactory.Builder, int) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
 
replacePrimaryOwners(ScatteredConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory
 
replacePrimaryOwnerWithBackup(int, Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
replaceValue(Object, InternalCacheEntry) - Method in interface org.infinispan.context.InvocationContext
replaceVersionRead(Object, EntryVersion) - Method in interface org.infinispan.transaction.xa.CacheTransaction
Deprecated.
since 9.0
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
 
ReplicableCommandManagerFunction - Class in org.infinispan.manager.impl
Replicable Command that runs the given Function passing the EmbeddedCacheManager as an argument
ReplicableCommandManagerFunction() - Constructor for class org.infinispan.manager.impl.ReplicableCommandManagerFunction
 
ReplicableCommandManagerFunction(Function<? super EmbeddedCacheManager, ?>) - Constructor for class org.infinispan.manager.impl.ReplicableCommandManagerFunction
 
ReplicableCommandRunnable - Class in org.infinispan.manager.impl
Replicable Command that runs the given Runnable
ReplicableCommandRunnable() - Constructor for class org.infinispan.manager.impl.ReplicableCommandRunnable
 
ReplicableCommandRunnable(Runnable) - Constructor for class org.infinispan.manager.impl.ReplicableCommandRunnable
 
REPLICATED_CACHE - org.infinispan.configuration.parsing.Element
 
REPLICATED_CACHE_CONFIGURATION - org.infinispan.configuration.parsing.Element
 
ReplicatedConsistentHash - Class in org.infinispan.distribution.ch.impl
Special implementation of ConsistentHash for replicated caches.
ReplicatedConsistentHash(Hash, List<Address>, int[]) - Constructor for class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
ReplicatedConsistentHash.Externalizer - Class in org.infinispan.distribution.ch.impl
 
ReplicatedConsistentHashFactory - Class in org.infinispan.distribution.ch.impl
Factory for ReplicatedConsistentHash.
ReplicatedConsistentHashFactory() - Constructor for class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory
 
ReplicatedConsistentHashFactory.Externalizer - Class in org.infinispan.distribution.ch.impl
 
REPLICATION_MODE_ID - Static variable in class org.infinispan.functional.ParamIds
 
REPLICATION_QUEUE_EXECUTOR - org.infinispan.configuration.parsing.Attribute
Deprecated.
REPLICATION_TIMEOUT - Static variable in class org.infinispan.configuration.cache.BackupConfiguration
 
ReplicationLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.ReplicationLogic
 
replicationQueueThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfiguration
Deprecated.
Since 9.0, no longer used.
replicationQueueThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
Deprecated.
replicationQueueThreadPool() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
Deprecated.
Since 9.0, no longer used.
replicationTimeout() - Method in class org.infinispan.configuration.cache.BackupConfiguration
 
replicationTimeout(long) - 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.
replTimeout() - Method in class org.infinispan.configuration.cache.SyncConfiguration
Deprecated.
Since 9.0, please use ClusteringConfiguration.remoteTimeout() instead.
replTimeout(long) - Method in class org.infinispan.configuration.cache.SyncConfiguration
Deprecated.
Since 9.0, please use ClusteringConfiguration.remoteTimeout(long) instead.
replTimeout(long) - Method in class org.infinispan.configuration.cache.SyncConfigurationBuilder
Deprecated.
replTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.cache.SyncConfigurationBuilder
reply - Variable in class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
 
reply(Response) - Method in interface org.infinispan.remoting.inboundhandler.Reply
Sends back the return value to the sender.
Reply - Interface in org.infinispan.remoting.inboundhandler
Interface responsible to send back the return value to the sender.
REPLY_FLAGS - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
repository - Variable in class org.infinispan.remoting.transport.AbstractRequest
 
Request<T> - Interface in org.infinispan.remoting.transport.impl
A remote command invocation request.
requestedTopologyId - Variable in exception org.infinispan.statetransfer.OutdatedTopologyException
 
requestId - Variable in class org.infinispan.remoting.transport.AbstractRequest
 
requestId - Variable in class org.infinispan.stream.impl.ClusterStreamManagerImpl
 
requestKeys() - Method in class org.infinispan.statetransfer.InboundTransferTask
 
RequestRepository - Class in org.infinispan.remoting.transport.impl
 
RequestRepository() - Constructor for class org.infinispan.remoting.transport.impl.RequestRepository
 
requestSegments() - Method in class org.infinispan.statetransfer.InboundTransferTask
Send START_STATE_TRANSFER request to source node.
requestTimedOut(long, String) - Method in class org.infinispan.util.logging.Log_$logger
 
requestTimedOut(long, String) - Method in interface org.infinispan.util.logging.Log
 
requestTimedOut$str() - Method in class org.infinispan.util.logging.Log_$logger
 
requireAttributes(XMLStreamReader, boolean, String...) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Require all the named attributes, returning their values in order.
requireAttributes(XMLStreamReader, String...) - Static method in class org.infinispan.configuration.parsing.ParseUtils
 
requireNoAttributes(XMLStreamReader) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Checks that the current element has no attributes, throwing an XMLStreamException if one is found.
requireNoContent(XMLStreamReader) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Consumes the remainder of the current element, throwing an XMLStreamException if it contains any child elements.
requireNoNamespaceAttribute(XMLStreamReader, int) - Static method in class org.infinispan.configuration.parsing.ParseUtils
 
requireSingleAttribute(XMLStreamReader, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Require that the current element have only a single attribute with the given name.
reset() - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
reset() - Method in class org.infinispan.stats.impl.AbstractClusterStats
 
reset() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
reset() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
reset() - Method in class org.infinispan.stats.impl.StatsCollector
 
reset() - Method in class org.infinispan.stats.impl.StatsImpl
 
reset() - Method in interface org.infinispan.stats.Stats
Reset statistics
reset() - Method in class org.infinispan.transaction.impl.TotalOrderRemoteTransactionState
 
reset() - Method in class org.infinispan.xsite.OfflineStatus
 
resetCurrentValue() - Method in interface org.infinispan.container.entries.MVCCEntry
Reset the current value of the entry to the value before the commmand was executed the first time.
resetCurrentValue() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
resetCurrentValue() - Method in class org.infinispan.container.entries.RepeatableReadEntry
 
resetState() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
Deprecated.
 
resetStatistics() - Method in class org.infinispan.eviction.impl.ActivationManagerImpl
 
resetStatistics() - Method in class org.infinispan.eviction.impl.PassivationManagerImpl
 
resetStatistics() - Method in class org.infinispan.eviction.impl.PassivationManagerStub
 
resetStatistics() - Method in interface org.infinispan.eviction.PassivationManager
 
resetStatistics() - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
resetStatistics() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
resetStatistics() - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
resetStatistics() - Method in class org.infinispan.interceptors.impl.InvalidationInterceptor
 
resetStatistics() - Method in class org.infinispan.interceptors.impl.JmxStatsCommandInterceptor
Resets statistics gathered.
resetStatistics() - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
resetStatistics() - Method in interface org.infinispan.jmx.JmxStatisticsExposer
Resets an interceptor's cache statistics
resetStatistics() - Method in class org.infinispan.remoting.inboundhandler.AbstractDelegatingHandler
 
resetStatistics() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
 
resetStatistics() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
resetStatistics() - Method in class org.infinispan.stats.impl.AbstractClusterStats
 
resetStatistics() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
resetStatistics() - Method in class org.infinispan.stats.impl.StatsCollector
 
resetVolatileComponents() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
Removes any components not annotated as @SurvivesRestarts.
resize(long) - Method in interface org.infinispan.container.DataContainer
Resizes the capacity of the underlying container.
resize(long) - Method in class org.infinispan.container.impl.AbstractDelegatingDataContainer
 
resize(long) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
resize(long) - Method in class org.infinispan.container.impl.DefaultDataContainer
 
resolveConflicts() - Method in interface org.infinispan.conflict.ConflictManager
Utilises ConflictManager.getConflicts() to discover conflicts between Key replicas and utilises the configured EntryMergePolicy to determine which entry should take precedence.
resolveConflicts() - Method in class org.infinispan.conflict.impl.DefaultConflictManager
 
resolveConflicts(EntryMergePolicy<K, V>) - Method in interface org.infinispan.conflict.ConflictManager
Utilises ConflictManager.getConflicts() to discover conflicts between Key replicas and utilises the provided EntryMergePolicy to determine which entry should take precedence.
resolveConflicts(EntryMergePolicy<K, V>) - Method in class org.infinispan.conflict.impl.DefaultConflictManager
 
resolveConflicts(CacheTopology, Set<Address>) - Method in class org.infinispan.conflict.impl.DefaultConflictManager
 
resolveConflicts(CacheTopology, Set<Address>) - Method in interface org.infinispan.conflict.impl.InternalConflictManager
 
resolveConflictsOnMerge() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
 
resolveConflictsOnMerge() - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
 
resolveConflictsOnMerge() - Method in class org.infinispan.topology.ClusterCacheStatus
 
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
 
ResourceDMBean(Object, ManageableComponentMetadata, String) - Constructor for class org.infinispan.jmx.ResourceDMBean
 
response - Variable in class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
 
response - Variable in class org.infinispan.stream.impl.StreamResponseCommand
 
Response - Interface in org.infinispan.remoting.responses
A response to be sent back to a remote caller
responseCollector - Variable in class org.infinispan.remoting.transport.AbstractRequest
 
ResponseCollector<T> - Interface in org.infinispan.remoting.transport
A representation of a request's responses.
ResponseCollectors - Class in org.infinispan.remoting.transport
 
ResponseCollectors() - Constructor for class org.infinispan.remoting.transport.ResponseCollectors
 
responseFilter() - Method in class org.infinispan.remoting.rpc.RpcOptions
Deprecated.
Since 9.2, ignored by RpcManager.invokeCommand*().
responseFilter(ResponseFilter) - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
Deprecated.
Since 9.2, ignored by RpcManager.invokeCommand*().
ResponseFilter - Interface in org.infinispan.remoting.rpc
A mechanism of filtering RPC responses.
ResponseGenerator - Interface in org.infinispan.remoting.responses
A component that generates responses as is expected by different cache setups
ResponseGeneratorFactory - Class in org.infinispan.factories
Creates a ResponseGenerator
ResponseGeneratorFactory() - Constructor for class org.infinispan.factories.ResponseGeneratorFactory
 
responseMode() - Method in class org.infinispan.remoting.rpc.RpcOptions
Deprecated.
Since 9.2, ignored by RpcManager.invokeCommand*().
responseMode(ResponseMode) - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
Deprecated.
Since 9.2, ignored by RpcManager.invokeCommand*().
ResponseMode - Enum in org.infinispan.remoting.rpc
Represents different handling mechanisms when dealing with remote command responses.
RESTART_SEND - org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand.StateTransferControl
 
restartComponent(Lifecycle) - Method in class org.infinispan.util.concurrent.SynchronizedRestarter
 
restartConflictResolution(List<Address>) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
If CR is in progress, then this method cancels the current CR and starts a new CR phase with an updated topology based upon newMembers and the previously queued CR topology
restartConflictResolution(List<Address>) - Method in class org.infinispan.topology.ClusterCacheStatus
 
restartVersionRequests() - Method in class org.infinispan.conflict.impl.DefaultConflictManager
 
restartVersionRequests() - Method in interface org.infinispan.conflict.impl.InternalConflictManager
 
restoreCacheTopology(ScopedPersistentState) - Method in class org.infinispan.topology.ClusterCacheStatus
 
result - Variable in class org.infinispan.distexec.RunnableAdapter
 
result - Variable in class org.infinispan.interceptors.distribution.VersionedResult
 
resume(Transaction) - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Deprecated.
Resume the association of the calling thread with the given transaction.
resumeIfNeeded(Transaction) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
resumeIfNeeded(Transaction) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
resumeIfNeeded(Transaction) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
 
retainAll(Collection<?>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySetBase
 
retainAll(Collection<?>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.KeySet
 
retainAll(Collection<?>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.Values
 
retainAll(Collection<?>) - Method in class org.infinispan.commands.read.AbstractCloseableIteratorCollection
 
retainAll(Collection<?>) - Method in class org.infinispan.util.CollectionMapper
 
retainAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
 
retainAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
Deprecated.
 
retainAll(Collection<?>) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
 
rethrowException(Throwable) - Static method in class org.infinispan.util.concurrent.CompletableFutures
 
retriedCommand - Variable in class org.infinispan.commands.tx.PrepareCommand
 
retrievalEncounteredException(Throwable) - Method in class org.infinispan.interceptors.distribution.L1WriteSynchronizer
 
retrieveClusterListenerCallablesToInstall() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
retrieveClusterListenerCallablesToInstall() - Method in interface org.infinispan.notifications.cachelistener.cluster.ClusterCacheNotifier
This method is invoked so that this node can send the details required for a new node to be bootstrapped with the existing cluster listeners that are already installed.
retrievedEntries - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
retrieveDistributionInfo(LocalizedCacheTopology, ReplicableCommand, Object) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
retrieveLastAccess(Object, Object, int) - Method in interface org.infinispan.expiration.ExpirationManager
Deprecated.
since 9.3 this method is not intended for external use
retrieveLastAccess(Object, Object, int) - Method in class org.infinispan.expiration.impl.ClusterExpirationManager
 
retrieveLastAccess(Object, Object, int) - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
retrieveLastAccess(Object, Object, int) - Method in interface org.infinispan.expiration.impl.InternalExpirationManager
Retrieves the last access time for the given key in the data container if it is using max idle.
RetrieveLastAccessCommand - Class in org.infinispan.commands.remote.expiration
Command that when invoked will retrieve the last access time from an entry without updating it
RetrieveLastAccessCommand(ByteString) - Constructor for class org.infinispan.commands.remote.expiration.RetrieveLastAccessCommand
 
RetrieveLastAccessCommand(ByteString, Object, Object, int) - Constructor for class org.infinispan.commands.remote.expiration.RetrieveLastAccessCommand
 
retrievingTm(TransactionManager) - Method in class org.infinispan.util.logging.Log_$logger
 
retrievingTm(TransactionManager) - Method in interface org.infinispan.util.logging.Log
 
retrievingTm$str() - Method in class org.infinispan.util.logging.Log_$logger
 
retry(Throwable, RpcManager) - Method in class org.infinispan.remoting.transport.RetryOnFailureXSiteCommand.MaxRetriesPolicy
 
retry(Throwable, RpcManager) - Method in interface org.infinispan.remoting.transport.RetryOnFailureXSiteCommand.RetryPolicy
 
RetryingEntryWrappingInterceptor - Class in org.infinispan.interceptors.impl
Used in @{link org.infinispan.configuration.cache.CacheMode#SCATTERED_SYNC scattered cache} The commit is executed in ScatteredDistributionInterceptor before replicating the change from primary owner.
RetryingEntryWrappingInterceptor() - Constructor for class org.infinispan.interceptors.impl.RetryingEntryWrappingInterceptor
 
RetryOnFailureXSiteCommand - Class in org.infinispan.remoting.transport
Invokes a command in a remote site.
RetryOnFailureXSiteCommand.MaxRetriesPolicy - Class in org.infinispan.remoting.transport
 
RetryOnFailureXSiteCommand.RetryPolicy - Interface in org.infinispan.remoting.transport
 
retryWhenDone(CompletableFuture<Void>, int, InvocationContext, T, InvocationFinallyFunction) - Method in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor
 
returnReadOnlyFindIsPresent() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
returnReadOnlyFindOrNull() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
returnReadWriteFind() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
returnReadWriteGet() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
returnReadWriteView() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
RevokeBiasCommand - Class in org.infinispan.commands.remote
Informs node that it is not allowed to serve reads from the local record anymore.
RevokeBiasCommand() - Constructor for class org.infinispan.commands.remote.RevokeBiasCommand
 
RevokeBiasCommand(ByteString) - Constructor for class org.infinispan.commands.remote.RevokeBiasCommand
 
RevokeBiasCommand(ByteString, Address, long, int, Collection<Object>) - Constructor for class org.infinispan.commands.remote.RevokeBiasCommand
 
revokeLocalBias(Object) - Method in interface org.infinispan.scattered.BiasManager
Stop reading local data.
revokeLocalBias(Object) - Method in class org.infinispan.scattered.impl.BiasManagerImpl
 
revokeLocalBiasForSegments(IntSet) - Method in interface org.infinispan.scattered.BiasManager
Stop reading local data from this segment.
revokeLocalBiasForSegments(IntSet) - Method in class org.infinispan.scattered.impl.BiasManagerImpl
 
rewire() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
Rewires components.
rewire() - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
Rewire all the injections after a component was replaced with BasicComponentRegistry.replaceComponent(String, Object, boolean).
rewire() - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
 
rewireNamedRegistries() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
rnd - Static variable in class org.infinispan.affinity.impl.RndKeyGenerator
 
RndKeyGenerator - Class in org.infinispan.affinity.impl
Key provider that relies on Random's distribution to generate keys.
RndKeyGenerator() - Constructor for class org.infinispan.affinity.impl.RndKeyGenerator
 
role(String) - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
role(String) - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
 
role(String) - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
 
role(String) - Method in interface org.infinispan.configuration.global.GlobalRolesConfigurationChildBuilder
 
Role - Interface in org.infinispan.security
A role to permission mapping.
ROLE - org.infinispan.configuration.parsing.Element
 
roles() - Method in class org.infinispan.configuration.cache.AuthorizationConfiguration
 
roles() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
ROLES - org.infinispan.configuration.parsing.Attribute
 
ROLES - Static variable in class org.infinispan.configuration.cache.AuthorizationConfiguration
 
ROLES - Static variable in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
rollback() - Method in interface org.infinispan.container.entries.CacheEntry
Deprecated.
since 9.0
rollback() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Deprecated.
Rolls back the transaction associated with the calling thread.
rollback() - Method in class org.infinispan.transaction.tm.DummyTransaction
Deprecated.
Rolls back this transaction.
rollback() - Method in class org.infinispan.transaction.tm.DummyUserTransaction
Deprecated.
Rolls back this transaction.
rollback() - Method in class org.infinispan.transaction.tm.EmbeddedUserTransaction
 
rollback(Transaction) - Method in interface org.infinispan.persistence.spi.TransactionalCacheWriter
Rollback the provided transaction's changes to the underlying store.
rollback(Xid) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
Same comment as for TransactionXaAdapter.prepare(javax.transaction.xa.Xid) applies for commit.
rollback(LocalTransaction) - Method in class org.infinispan.transaction.impl.TransactionCoordinator
 
rollbackAllTxStores(Transaction, Predicate<? super StoreConfiguration>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
Perform the rollback operation for the provided transaction on all Tx stores.
rollbackAllTxStores(Transaction, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
rollbackAllTxStores(Transaction, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
RollbackCommand - Class in org.infinispan.commands.tx
Command corresponding to a transaction rollback.
RollbackCommand(ByteString) - Constructor for class org.infinispan.commands.tx.RollbackCommand
 
RollbackCommand(ByteString, GlobalTransaction) - Constructor for class org.infinispan.commands.tx.RollbackCommand
 
ROLLING_UPGRADE - org.infinispan.context.Flag
Flag to identity that data is being written as part of a Rolling Upgrade.
ROLLING_UPGRADE - Static variable in class org.infinispan.context.impl.FlagBitSets
 
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
 
root() - Method in annotation type org.infinispan.configuration.parsing.Namespace
The root element of this namespace.
ROOT - org.infinispan.configuration.parsing.Element
 
rpc - Variable in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
rpc - Variable in class org.infinispan.stream.impl.ClusterStreamManagerImpl
 
RpcException - Exception in org.infinispan.remoting
Thrown when an RPC problem occurred on the caller.
RpcException() - 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
 
RpcException(Throwable) - Constructor for exception org.infinispan.remoting.RpcException
 
rpcManager - Variable in class org.infinispan.cache.impl.CacheImpl
 
rpcManager - Variable in class org.infinispan.expiration.impl.ClusterExpirationManager
 
rpcManager - Variable in class org.infinispan.interceptors.impl.BaseRpcInterceptor
 
rpcManager - Variable in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
rpcManager - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
rpcManager - Variable in class org.infinispan.statetransfer.StateProviderImpl
 
rpcManager - Variable in class org.infinispan.transaction.impl.TransactionTable
 
RpcManager - Interface in org.infinispan.remoting.rpc
Provides a mechanism for communicating with other caches in the cluster, by formatting and passing requests down to the registered Transport.
RpcManagerFactory - Class in org.infinispan.factories
A factory for the RpcManager
RpcManagerFactory() - Constructor for class org.infinispan.factories.RpcManagerFactory
 
RpcManagerImpl - Class in org.infinispan.remoting.rpc
This component really is just a wrapper around a Transport implementation, and is used to set up the transport and provide lifecycle and dependency hooks into external transport implementations.
RpcManagerImpl() - Constructor for class org.infinispan.remoting.rpc.RpcManagerImpl
 
rpcOptions - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
rpcOptions - Variable in class org.infinispan.stream.impl.ClusterStreamManagerImpl
 
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, DeliverOrder) - Constructor for class org.infinispan.remoting.rpc.RpcOptions
RpcOptions(long, TimeUnit, ResponseFilter, ResponseMode, DeliverOrder) - Constructor for class org.infinispan.remoting.rpc.RpcOptions
Deprecated.
RpcOptions(DeliverOrder, long, TimeUnit) - Constructor for class org.infinispan.remoting.rpc.RpcOptions
 
RpcOptionsBuilder - Class in org.infinispan.remoting.rpc
Deprecated.
Since 9.2, please use RpcOptions directly.
RpcOptionsBuilder(long, TimeUnit, ResponseMode, DeliverOrder) - Constructor for class org.infinispan.remoting.rpc.RpcOptionsBuilder
Deprecated.
 
RpcOptionsBuilder(RpcOptions) - Constructor for class org.infinispan.remoting.rpc.RpcOptionsBuilder
Deprecated.
Constructor based on existing RpcOptions
run() - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor.LockTimeoutFuture
 
run() - Method in class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
 
run() - Method in class org.infinispan.security.actions.AddCacheManagerListenerAction
 
run() - Method in class org.infinispan.security.actions.DefineConfigurationAction
 
run() - Method in class org.infinispan.security.actions.GetCacheAction
 
run() - Method in class org.infinispan.security.actions.GetCacheAuthorizationManagerAction
 
run() - Method in class org.infinispan.security.actions.GetCacheAvailabilityAction
 
run() - Method in class org.infinispan.security.actions.GetCacheComponentRegistryAction
 
run() - Method in class org.infinispan.security.actions.GetCacheConfigurationAction
 
run() - Method in class org.infinispan.security.actions.GetCacheDistributionManagerAction
 
run() - Method in class org.infinispan.security.actions.GetCacheEntryAction
 
run() - Method in class org.infinispan.security.actions.GetCacheGlobalComponentRegistryAction
 
run() - Method in class org.infinispan.security.actions.GetCacheInterceptorChainAction
 
run() - Method in class org.infinispan.security.actions.GetCacheLockManagerAction
 
run() - Method in class org.infinispan.security.actions.GetCacheManagerAddress
 
run() - Method in class org.infinispan.security.actions.GetCacheManagerClusterAvailabilityAction
 
run() - Method in class org.infinispan.security.actions.GetCacheManagerClusterNameAction
 
run() - Method in class org.infinispan.security.actions.GetCacheManagerCoordinatorAddress
 
run() - Method in class org.infinispan.security.actions.GetCacheManagerIsCoordinatorAction
 
run() - Method in class org.infinispan.security.actions.GetCacheManagerStatusAction
 
run() - Method in class org.infinispan.security.actions.GetCacheRpcManagerAction
 
run() - Method in class org.infinispan.security.actions.GetCacheStatusAction
 
run() - Method in class org.infinispan.security.actions.GetDefaultExecutorServiceAction
 
run() - Method in class org.infinispan.security.actions.GetGlobalComponentRegistryAction
 
run() - Method in class org.infinispan.security.actions.GetSystemPropertyAction
 
run() - Method in class org.infinispan.security.actions.GetSystemPropertyAsBooleanAction
 
run() - Method in class org.infinispan.security.actions.GetSystemPropertyAsIntegerAction
 
run() - Method in class org.infinispan.security.actions.RemoveListenerAction
 
run() - Method in class org.infinispan.security.actions.SetCacheAvailabilityAction
 
run() - Method in class org.infinispan.security.actions.SetThreadContextClassLoaderAction
 
run() - Method in class org.infinispan.security.actions.UndefineConfigurationAction
 
run() - Method in class org.infinispan.statetransfer.OutboundTransferTask
 
run(int) - Method in interface org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl.ArgRunnable
 
runCommit(boolean) - Method in class org.infinispan.transaction.tm.DummyTransaction
Deprecated.
Runs the second phase of two-phase-commit protocol.
runL1UpdateIfPossible(InternalCacheEntry) - Method in class org.infinispan.interceptors.distribution.L1WriteSynchronizer
Attempts to the L1 update and set the value.
RunnableAdapter<T> - Class in org.infinispan.distexec
Runnable adapter for distributed executor service Any RunnableAdapter refactoring might break CDI
RunnableAdapter() - Constructor for class org.infinispan.distexec.RunnableAdapter
 
RunnableAdapter(Runnable, T) - Constructor for class org.infinispan.distexec.RunnableAdapter
 
running - Variable in class org.infinispan.transaction.impl.TransactionTable
 
running() - Method in interface org.infinispan.factories.impl.ComponentRef
 
RUNNING - org.infinispan.lifecycle.ComponentStatus
The start() method has been completed and the component is running.
runPrepare() - Method in class org.infinispan.transaction.tm.DummyTransaction
Deprecated.
 
rvrl - Variable in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 

S

SAME_MACHINE - org.infinispan.distexec.DistributedTaskExecutionPolicy
 
SAME_MACHINE - org.infinispan.manager.ClusterExecutionPolicy
The command can be executed only on the same machine from where it was initiated.
SAME_RACK - org.infinispan.distexec.DistributedTaskExecutionPolicy
 
SAME_RACK - org.infinispan.manager.ClusterExecutionPolicy
The command will be executed on a machine on the same rack.
SAME_SITE - org.infinispan.distexec.DistributedTaskExecutionPolicy
 
SAME_SITE - org.infinispan.manager.ClusterExecutionPolicy
The command will be executed on a machine on the same site.
sameCacheName(String) - Method in class org.infinispan.transaction.xa.recovery.RecoveryInfoKey
 
SCATTERED_CACHE - org.infinispan.configuration.parsing.Element
 
SCATTERED_CACHE_CONFIGURATION - org.infinispan.configuration.parsing.Element
 
SCATTERED_SYNC - org.infinispan.configuration.cache.CacheMode
Synchronous scattered cache
scatteredCacheIsNonTransactional() - Method in class org.infinispan.util.logging.Log_$logger
 
scatteredCacheIsNonTransactional() - Method in interface org.infinispan.util.logging.Log
 
scatteredCacheIsNonTransactional$str() - Method in class org.infinispan.util.logging.Log_$logger
 
scatteredCacheNeedsSingleOwner() - Method in class org.infinispan.util.logging.Log_$logger
 
scatteredCacheNeedsSingleOwner() - Method in interface org.infinispan.util.logging.Log
 
scatteredCacheNeedsSingleOwner$str() - Method in class org.infinispan.util.logging.Log_$logger
 
ScatteredCacheWriterInterceptor - Class in org.infinispan.interceptors.impl
Similar to DistCacheWriterInterceptor but as commands are not forwarded from primary owner so we just write to the store all the time (with non-shared interceptors).
ScatteredCacheWriterInterceptor() - Constructor for class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor
 
ScatteredCacheWriterInterceptor.LockTimeoutFuture - Class in org.infinispan.interceptors.impl
 
ScatteredConsistentHash - Class in org.infinispan.distribution.ch.impl
CH used by scattered caches.
ScatteredConsistentHash(Hash, int, List<Address>, Map<Address, Float>, Address[], boolean) - Constructor for class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
 
ScatteredConsistentHash.Externalizer - Class in org.infinispan.distribution.ch.impl
 
ScatteredConsistentHashFactory - Class in org.infinispan.distribution.ch.impl
ScatteredConsistentHashFactory() - Constructor for class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory
 
ScatteredConsistentHashFactory.Builder - Class in org.infinispan.distribution.ch.impl
 
ScatteredConsistentHashFactory.Externalizer - Class in org.infinispan.distribution.ch.impl
 
ScatteredDistributionInterceptor - Class in org.infinispan.interceptors.distribution
This interceptor mixes several functions: A) replicates changes to other nodes B) commits the entry C) schedules invalidation On primary owner, the commit is executed before the change is replicated to other node.
ScatteredDistributionInterceptor() - Constructor for class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
ScatteredDistributionInterceptor.PrimaryResponseGenerator - Class in org.infinispan.interceptors.distribution
 
ScatteredDistributionInterceptor.PrimaryResponseHandler - Class in org.infinispan.interceptors.distribution
 
ScatteredLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.ScatteredLogic
 
scatteredLostDataCheck(ConsistentHash, List<Address>) - Static method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
ScatteredPartitionHandlingManagerImpl - Class in org.infinispan.scattered.impl
 
ScatteredPartitionHandlingManagerImpl() - Constructor for class org.infinispan.scattered.impl.ScatteredPartitionHandlingManagerImpl
 
ScatteredStateConsumerImpl - Class in org.infinispan.scattered.impl
 
ScatteredStateConsumerImpl() - Constructor for class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
ScatteredStateConsumerImpl.KeyAndVersion - Class in org.infinispan.scattered.impl
 
ScatteredStateProvider - Interface in org.infinispan.scattered
 
ScatteredStateProviderImpl - Class in org.infinispan.scattered.impl
 
ScatteredStateProviderImpl() - Constructor for class org.infinispan.scattered.impl.ScatteredStateProviderImpl
 
ScatteredVersionManager<K> - Interface in org.infinispan.scattered
Manages versions of entries and states of segments.
ScatteredVersionManager.SegmentState - Enum in org.infinispan.scattered
 
ScatteredVersionManagerImpl<K> - Class in org.infinispan.scattered.impl
 
ScatteredVersionManagerImpl() - Constructor for class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
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
 
SCHEDULED_THREAD_POOL - org.infinispan.configuration.parsing.Element
 
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.
scheduleKeyInvalidation(Object, EntryVersion, boolean) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
scheduleKeyInvalidation(K, EntryVersion, boolean) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
scheduleKeyInvalidation(K, EntryVersion, boolean) - Method in interface org.infinispan.scattered.ScatteredVersionManager
Notifies the manager that an operation on given key with version previously retrieved from ScatteredVersionManager.incrementVersion(int) has finished.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
Schema - Class in org.infinispan.configuration.parsing
Schema.
Schema(int, int) - Constructor for class org.infinispan.configuration.parsing.Schema
 
scheme() - Method in class org.infinispan.configuration.cache.VersioningConfiguration
Deprecated.
 
scheme(VersioningScheme) - Method in class org.infinispan.configuration.cache.VersioningConfigurationBuilder
Deprecated.
 
SCHEME - Static variable in class org.infinispan.configuration.cache.VersioningConfiguration
Deprecated.
 
scope - Variable in class org.infinispan.util.logging.events.impl.DecoratedEventLogger
 
scope(String) - Method in interface org.infinispan.util.logging.events.EventLogger
Sets the scope of this event log, e.g.
scope(String) - Method in class org.infinispan.util.logging.events.impl.BasicEventLogger
 
scope(String) - Method in class org.infinispan.util.logging.events.impl.DecoratedEventLogger
 
scope(Address) - Method in interface org.infinispan.util.logging.events.EventLogger
Sets a node address as the scope of this event log
scope(Address) - Method in class org.infinispan.util.logging.events.impl.DecoratedEventLogger
 
Scope - Annotation Type in org.infinispan.factories.scopes
Defines the scope of a component in a cache system.
ScopeDetector - Class in org.infinispan.factories.scopes
Retrieves the declared scope of a component
ScopeDetector() - Constructor for class org.infinispan.factories.scopes.ScopeDetector
 
ScopedPersistentState - Interface in org.infinispan.globalstate
ScopedPersistentState represents state which needs to be persisted, scoped by name (e.g.
ScopedPersistentStateImpl - Class in org.infinispan.globalstate.impl
ScopedPersistentStateImpl.
ScopedPersistentStateImpl(String) - Constructor for class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
 
ScopedState - Class in org.infinispan.globalstate
Key for scoped entries in the ClusterConfigurationManager state cache
ScopedState(String, String) - Constructor for class org.infinispan.globalstate.ScopedState
 
ScopedState.Externalizer - Class in org.infinispan.globalstate
 
ScopeFilter - Class in org.infinispan.globalstate
 
ScopeFilter(String) - Constructor for class org.infinispan.globalstate.ScopeFilter
 
ScopeFilter.Externalizer - Class in org.infinispan.globalstate
 
Scopes - Enum in org.infinispan.factories.scopes
The different scopes that can be declared for a component in the cache system.
SECONDS - org.infinispan.jmx.annotations.Units
 
SecureCache<K,​V> - Interface in org.infinispan.security
SecureCache.
SecureCacheImpl<K,​V> - Class in org.infinispan.security.impl
SecureCacheImpl.
SecureCacheImpl(AdvancedCache<K, V>) - Constructor for class org.infinispan.security.impl.SecureCacheImpl
 
security() - Method in class org.infinispan.configuration.cache.Configuration
 
security() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
security() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
security() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
security() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
security() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
Security-related configuration
Security - Class in org.infinispan.security
Security.
Security() - Constructor for class org.infinispan.security.Security
 
SECURITY - org.infinispan.configuration.parsing.Element
 
SECURITY - org.infinispan.util.logging.events.EventLogCategory
 
SecurityAwareScheduledExecutorFactory - Interface in org.infinispan.executors
 
securityCacheTimeout() - Method in class org.infinispan.configuration.global.GlobalSecurityConfiguration
 
securityCacheTimeout(long) - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
 
securityCacheTimeout(long) - Method in interface org.infinispan.configuration.global.GlobalSecurityConfigurationChildBuilder
securityCacheTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
 
securityCacheTimeout(long, TimeUnit) - Method in interface org.infinispan.configuration.global.GlobalSecurityConfigurationChildBuilder
Defines the timeout for which to cache user access roles.
SecurityConfiguration - Class in org.infinispan.configuration.cache
SecurityConfiguration.
SecurityConfigurationBuilder - Class in org.infinispan.configuration.cache
SecurityConfigurationBuilder.
SecurityConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.SecurityConfigurationBuilder
 
SecurityConfigurationChildBuilder - Interface in org.infinispan.configuration.cache
 
segment - Variable in class org.infinispan.commands.read.AbstractDataCommand
 
SEGMENTATION_FEATURE - Static variable in class org.infinispan.factories.DataContainerFactory
 
segmentAwareEntrySet - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
 
segmentAwareKeySet - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
 
SegmentAwareOperation - Interface in org.infinispan.stream.impl
Terminal stream operation that is aware of segments being lost.
segmentCompleted(Set<Integer>) - Method in interface org.infinispan.BaseCacheStream.SegmentCompletionListener
Deprecated.
This method requires boxing for each segment. Please use BaseCacheStream.SegmentCompletionListener.accept(Supplier) instead
segmentCompletionListener - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in interface org.infinispan.BaseCacheStream
Allows registration of a segment completion listener that is notified when a segment has completed processing.
segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in interface org.infinispan.CacheStream
Allows registration of a segment completion listener that is notified when a segment has completed processing.
segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in interface org.infinispan.DoubleCacheStream
Allows registration of a segment completion listener that is notified when a segment has completed processing.
segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in interface org.infinispan.IntCacheStream
Allows registration of a segment completion listener that is notified when a segment has completed processing.
segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in interface org.infinispan.LockedStream
This method is not supported when using a LockedStream
segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in interface org.infinispan.LongCacheStream
Allows registration of a segment completion listener that is notified when a segment has completed processing.
segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
segmented() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
segmented() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
Whether or not this store is configured to be segmented.
segmented(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
segmented(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
 
segmented(boolean) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
If true this store should either be non shared (segmenting can be done automatically for non shared stores) or the shared store must implement the SegmentedAdvancedLoadWriteStore interface.
SEGMENTED - org.infinispan.configuration.parsing.Attribute
 
SEGMENTED - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
SegmentedAdvancedLoadWriteStore<K,​V> - Interface in org.infinispan.persistence.spi
An interface implementing both AdvancedCacheWriter and AdvancedCacheLoader as well as overrides of those methods that can be optimized when a segment is already known for the key or a subset of segments are to be used instead of the entire store.
SegmentedBoundedOffHeapDataContainer - Class in org.infinispan.container.offheap
 
SegmentedBoundedOffHeapDataContainer(int, int, long, EvictionType) - Constructor for class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
SegmentedEntryStreamSupplier<K,​V> - Class in org.infinispan.stream.impl.local
StreamSupplier that allows for creating streams where they utilize a InternalDataContainer so that the stream only looks at entries in those given segments.
SegmentedEntryStreamSupplier(Cache<K, V>, ToIntFunction<Object>, InternalDataContainer<K, V>) - Constructor for class org.infinispan.stream.impl.local.SegmentedEntryStreamSupplier
 
SegmentedKeyStreamSupplier<K,​V> - Class in org.infinispan.stream.impl.local
StreamSupplier that allows for creating streams where they utilize a InternalDataContainer so that the stream only looks at keys in those given segments.
SegmentedKeyStreamSupplier(Cache<K, V>, ToIntFunction<Object>, InternalDataContainer<K, V>) - Constructor for class org.infinispan.stream.impl.local.SegmentedKeyStreamSupplier
 
segmentId - Variable in class org.infinispan.commands.triangle.BackupWriteCommand
 
segmentId() - Method in class org.infinispan.distribution.DistributionInfo
 
segmentOwners - Variable in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
SegmentRetryingOperation<Original,​E,​T,​S extends BaseStream<T,​S>,​S2 extends S> - Class in org.infinispan.stream.impl.termop
A terminal based operation that runs the provided function to evaluate the operation.
SegmentRetryingOperation(Iterable<IntermediateOperation>, Supplier<Stream<Original>>, Function<? super S2, ? extends E>) - Constructor for class org.infinispan.stream.impl.termop.SegmentRetryingOperation
 
SEGMENTS - org.infinispan.configuration.parsing.Attribute
 
segmentSize - Variable in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
segmentSize - Variable in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
SegmentSpecificCommand - Interface in org.infinispan.commands
Interface to be implemented when the command can define a single segment for its operation.
segmentsToFilter - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
segmentsToFilter - Variable in class org.infinispan.stream.impl.local.AbstractLocalCacheStream
 
selectExecutionNode(List<Address>) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
selectExecutionNode(DistributedTask<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
self() - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
 
self() - Method in class org.infinispan.configuration.cache.CustomStoreConfigurationBuilder
 
self() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
 
SemaphoreCompletionService<T> - Class in org.infinispan.executors
Executes tasks in the given executor, but never has more than maxConcurrentTasks tasks running at the same time.
SemaphoreCompletionService(Executor, int) - Constructor for class org.infinispan.executors.SemaphoreCompletionService
 
sendDataResonse(C) - Method in interface org.infinispan.stream.impl.KeyTrackingTerminalOperation.IntermediateCollector
Called back when a response is sent back to the invoker
sendEvents() - Method in interface org.infinispan.notifications.cachelistener.cluster.ClusterEventManager
Sends all previously added events on this thread
sendEvents() - Method in class org.infinispan.notifications.cachelistener.cluster.impl.BatchingClusterEventManagerImpl
 
sendEvents() - Method in class org.infinispan.notifications.cachelistener.cluster.impl.ClusterEventManagerStub
 
sendNotification(Object, Object, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
sendTo(Address, ReplicableCommand, DeliverOrder) - Method in interface org.infinispan.remoting.rpc.RpcManager
Asynchronously sends the ReplicableCommand to the destination using the specified DeliverOrder.
sendTo(Address, ReplicableCommand, DeliverOrder) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
sendTo(Address, ReplicableCommand, DeliverOrder) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
sendTo(Address, ReplicableCommand, DeliverOrder) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
sendTo(Address, ReplicableCommand, DeliverOrder) - Method in interface org.infinispan.remoting.transport.Transport
Asynchronously sends the ReplicableCommand to the destination using the specified DeliverOrder.
sendToAll(ReplicableCommand, DeliverOrder) - Method in interface org.infinispan.remoting.rpc.RpcManager
Asynchronously sends the ReplicableCommand to the entire cluster.
sendToAll(ReplicableCommand, DeliverOrder) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
sendToAll(ReplicableCommand, DeliverOrder) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
sendToAll(ReplicableCommand, DeliverOrder) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
sendToAll(ReplicableCommand, DeliverOrder) - Method in interface org.infinispan.remoting.transport.Transport
Asynchronously sends the ReplicableCommand to the entire cluster.
sendToMany(Collection<Address>, ReplicableCommand, DeliverOrder) - Method in interface org.infinispan.remoting.rpc.RpcManager
Asynchronously sends the ReplicableCommand to the set of destination using the specified DeliverOrder.
sendToMany(Collection<Address>, ReplicableCommand, DeliverOrder) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
sendToMany(Collection<Address>, ReplicableCommand, DeliverOrder) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
sendToMany(Collection<Address>, ReplicableCommand, DeliverOrder) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
sendToMany(Collection<Address>, ReplicableCommand, DeliverOrder) - Method in interface org.infinispan.remoting.transport.Transport
Asynchronously sends the ReplicableCommand to the set of destination using the specified DeliverOrder.
sendToTargets(DistributedExecutorService) - Method in class org.infinispan.notifications.cachelistener.cluster.impl.BatchingClusterEventManagerImpl.UnicastEventContext
 
sequence(List<CompletableFuture<T>>) - Static method in class org.infinispan.util.concurrent.CompletableFutures
 
sequential() - Method in interface org.infinispan.CacheStream
sequential() - Method in interface org.infinispan.DoubleCacheStream
sequential() - Method in interface org.infinispan.IntCacheStream
sequential() - Method in interface org.infinispan.LongCacheStream
sequential() - Method in class org.infinispan.stream.impl.AbstractCacheStream
 
sequential() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
sequential() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
sequential() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
sequential() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
sequential() - Method in class org.infinispan.stream.impl.local.AbstractLocalCacheStream
 
sequential() - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
sequential() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
sequentialDistribution() - Method in interface org.infinispan.BaseCacheStream
This would disable sending requests to all other remote nodes compared to one at a time.
sequentialDistribution() - Method in interface org.infinispan.CacheStream
This would disable sending requests to all other remote nodes compared to one at a time.
sequentialDistribution() - Method in interface org.infinispan.DoubleCacheStream
This would disable sending requests to all other remote nodes compared to one at a time.
sequentialDistribution() - Method in interface org.infinispan.IntCacheStream
This would disable sending requests to all other remote nodes compared to one at a time.
sequentialDistribution() - Method in interface org.infinispan.LockedStream
This would disable sending requests to all other remote nodes compared to one at a time.
sequentialDistribution() - Method in interface org.infinispan.LongCacheStream
This would disable sending requests to all other remote nodes compared to one at a time.
sequentialDistribution() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
sequentialDistribution() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
sequentialDistribution() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
sequentialDistribution() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
sequentialDistribution() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
sequentialDistribution() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
sequentialDistribution() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
sequentialDistribution() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
sequentialDistribution() - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
sequentialDistribution() - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
sequentialDistribution() - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
sequentialDistribution() - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
sequentialDistribution() - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
sequentialDistribution() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
sequentialInterceptorClass() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
SERIALIZABLE - org.infinispan.util.concurrent.IsolationLevel
 
SerializableBiConsumer<T,​U> - Interface in org.infinispan.util.function
This is a functional interface that is the same as a BiConsumer except that it must also be Serializable
SerializableBiFunction<T,​U,​R> - Interface in org.infinispan.util.function
This is a functional interface that is the same as a BiFunction except that it must also be Serializable
SerializableBinaryOperator<T> - Interface in org.infinispan.util.function
This is a functional interface that is the same as a BinaryOperator except that it must also be Serializable
SerializableCallable<V> - Interface in org.infinispan.util.function
This is a functional interface that is the same as a Callable except that it must also be Serializable
serializableCollector(SerializableSupplier<Collector<T, ?, R>>) - Static method in class org.infinispan.stream.CacheCollectors
Creates a collector that is serializable and will upon usage create a collector using the serializable supplier provided by the user.
SerializableComparator<T> - Interface in org.infinispan.util.function
This is a functional interface that is the same as a Comparator except that it must also be Serializable
SerializableConsumer<T> - Interface in org.infinispan.util.function
This is a functional interface that is the same as a Consumer except that it must also be Serializable
SerializableDoubleBinaryOperator - Interface in org.infinispan.util.function
This is a functional interface that is the same as a DoubleBinaryOperator except that it must also be Serializable
SerializableDoubleConsumer - Interface in org.infinispan.util.function
This is a functional interface that is the same as a DoubleConsumer except that it must also be Serializable
SerializableDoubleFunction<R> - Interface in org.infinispan.util.function
This is a functional interface that is the same as a DoubleFunction except that it must also be Serializable
SerializableDoublePredicate - Interface in org.infinispan.util.function
This is a functional interface that is the same as a DoublePredicate except that it must also be Serializable
SerializableDoubleToIntFunction - Interface in org.infinispan.util.function
This is a functional interface that is the same as a DoubleToIntFunction except that it must also be Serializable
SerializableDoubleToLongFunction - Interface in org.infinispan.util.function
This is a functional interface that is the same as a DoubleToLongFunction except that it must also be Serializable
SerializableDoubleUnaryOperator - Interface in org.infinispan.util.function
This is a functional interface that is the same as a DoubleUnaryOperator except that it must also be Serializable
SerializableFunction<T,​R> - Interface in org.infinispan.util.function
This is a functional interface that is the same as a Function except that it must also be Serializable
SerializableIntBinaryOperator - Interface in org.infinispan.util.function
This is a functional interface that is the same as a IntBinaryOperator except that it must also be Serializable
SerializableIntConsumer - Interface in org.infinispan.util.function
This is a functional interface that is the same as a IntConsumer except that it must also be Serializable
SerializableIntFunction<R> - Interface in org.infinispan.util.function
This is a functional interface that is the same as a IntFunction except that it must also be Serializable
SerializableIntPredicate - Interface in org.infinispan.util.function
This is a functional interface that is the same as a IntPredicate except that it must also be Serializable
SerializableIntToDoubleFunction - Interface in org.infinispan.util.function
This is a functional interface that is the same as a IntToDoubleFunction except that it must also be Serializable
SerializableIntToLongFunction - Interface in org.infinispan.util.function
This is a functional interface that is the same as a IntToLongFunction except that it must also be Serializable
SerializableIntUnaryOperator - Interface in org.infinispan.util.function
This is a functional interface that is the same as a IntUnaryOperator except that it must also be Serializable
SerializableLongBinaryOperator - Interface in org.infinispan.util.function
This is a functional interface that is the same as a LongBinaryOperator except that it must also be Serializable
SerializableLongConsumer - Interface in org.infinispan.util.function
This is a functional interface that is the same as a LongConsumer except that it must also be Serializable
SerializableLongFunction<R> - Interface in org.infinispan.util.function
This is a functional interface that is the same as a LongFunction except that it must also be Serializable
SerializableLongPredicate - Interface in org.infinispan.util.function
This is a functional interface that is the same as a LongPredicate except that it must also be Serializable
SerializableLongToDoubleFunction - Interface in org.infinispan.util.function
This is a functional interface that is the same as a LongToDoubleFunction except that it must also be Serializable
SerializableLongToIntFunction - Interface in org.infinispan.util.function
This is a functional interface that is the same as a LongToIntFunction except that it must also be Serializable
SerializableLongUnaryOperator - Interface in org.infinispan.util.function
This is a functional interface that is the same as a LongUnaryOperator except that it must also be Serializable
SerializableObjDoubleConsumer<T> - Interface in org.infinispan.util.function
This is a functional interface that is the same as a ObjDoubleConsumer except that it must also be Serializable
SerializableObjIntConsumer<T> - Interface in org.infinispan.util.function
This is a functional interface that is the same as a ObjIntConsumer except that it must also be Serializable
SerializableObjLongConsumer<T> - Interface in org.infinispan.util.function
This is a functional interface that is the same as a ObjLongConsumer except that it must also be Serializable
SerializablePredicate<T> - Interface in org.infinispan.util.function
This is a functional interface that is the same as a Predicate except that it must also be Serializable
SerializableRunnable - Interface in org.infinispan.util.function
This is a functional interface that is the same as a Runnable except that it must also be Serializable
SerializableSupplier<T> - Interface in org.infinispan.util.function
This is a functional interface that is the same as a Supplier except that it must also be Serializable
SerializableToDoubleFunction<T> - Interface in org.infinispan.util.function
This is a functional interface that is the same as a ToDoubleFunction except that it must also be Serializable
SerializableToIntFunction<T> - Interface in org.infinispan.util.function
This is a functional interface that is the same as a ToIntFunction except that it must also be Serializable
SerializableToLongFunction<T> - Interface in org.infinispan.util.function
This is a functional interface that is the same as a ToLongFunction except that it must also be Serializable
SerializableXid - Class in org.infinispan.transaction.xa.recovery
Deprecated.
use XidImpl instead.
SerializableXid(byte[], byte[], int) - Constructor for class org.infinispan.transaction.xa.recovery.SerializableXid
Deprecated.
 
SerializableXid(Xid) - Constructor for class org.infinispan.transaction.xa.recovery.SerializableXid
Deprecated.
 
SerializableXid.XidExternalizer - Class in org.infinispan.transaction.xa.recovery
Deprecated.
 
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
Global serialization (i.e.
SERIALIZATION - org.infinispan.configuration.parsing.Element
 
SerializationConfiguration - Class in org.infinispan.configuration.global
 
SerializationConfigurationBuilder - Class in org.infinispan.configuration.global
Configures serialization and marshalling settings.
serialize(OutputStream, String, Configuration) - Method in class org.infinispan.configuration.parsing.ParserRegistry
Serializes a single configuration to an OutputStream
serialize(OutputStream, GlobalConfiguration, Map<String, Configuration>) - Method in class org.infinispan.configuration.parsing.ParserRegistry
Serializes a full configuration to an OutputStream
serialize(String, Configuration) - Method in class org.infinispan.configuration.parsing.ParserRegistry
Serializes a single configuration to a String
serialize(XMLExtendedStreamWriter, GlobalConfiguration, Map<String, Configuration>) - Method in class org.infinispan.configuration.parsing.ParserRegistry
Serializes a full configuration to an XMLExtendedStreamWriter
serialize(XMLExtendedStreamWriter, PrivateGlobalConfiguration) - Method in class org.infinispan.configuration.internal.PrivateGlobalConfigurationSerializer
 
serialize(XMLExtendedStreamWriter, ConfigurationHolder) - Method in class org.infinispan.configuration.serializing.Serializer
 
serialize(XMLExtendedStreamWriter, T) - Method in interface org.infinispan.configuration.serializing.ConfigurationSerializer
 
SerializedWith - Annotation Type in org.infinispan.configuration.serializing
SerializedWith, specifies the ConfigurationSerializer to use to serialize the annotated class
Serializer - Class in org.infinispan.configuration.serializing
Serializes an Infinispan configuration to an XMLExtendedStreamWriter
Serializer() - Constructor for class org.infinispan.configuration.serializing.Serializer
 
SerializeUtils - Class in org.infinispan.configuration.serializing
 
serverMode(boolean) - Method in class org.infinispan.configuration.internal.PrivateGlobalConfigurationBuilder
 
set - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
 
set(K, V) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
Don't remove.
set(K, V) - Method in class org.infinispan.cache.impl.CacheSupport
This is intentionally a non-public method meant as an integration point for bytecode manipulation.
set(K, V) - Method in class org.infinispan.cache.impl.EncoderCache
 
set(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntryChange
 
set(V, MetaParam.Writable...) - Method in interface org.infinispan.functional.EntryView.WriteEntryView
Set this value along with optional metadata parameters.
set(V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.ValueAndMetadata
 
set(V, Metadata) - Method in interface org.infinispan.functional.EntryView.WriteEntryView
Set this value along with metadata object.
setAddress(Address) - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
setAnnotation(Class<? extends Annotation>) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
setArguments(Map<?, ?>) - Method in class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
setArguments(Map<?, ?>) - Method in class org.infinispan.commands.functional.WriteOnlyManyEntriesCommand
 
setAttribute(Attribute) - Method in class org.infinispan.jmx.ResourceDMBean
 
setAttributes(AttributeList) - Method in class org.infinispan.jmx.ResourceDMBean
 
setAttributes(AttributeSet, Map<?, ?>, boolean, boolean) - Static method in class org.infinispan.configuration.parsing.XmlConfigHelper
 
setAvailability(AvailabilityMode) - Method in interface org.infinispan.AdvancedCache
Manually change the availability of the cache.
setAvailability(AvailabilityMode) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
setAvailability(AvailabilityMode) - Method in class org.infinispan.cache.impl.CacheImpl
 
setAvailability(AvailabilityMode) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
setAvailability(AvailabilityMode) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
setAvailabilityMode(AvailabilityMode) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
setAvailabilityMode(AvailabilityMode) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
setAvailabilityMode(AvailabilityMode) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
 
setAvailabilityMode(AvailabilityMode) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
setAvailable(boolean) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
setBatchIncrease(int) - Method in class org.infinispan.stream.impl.spliterators.IteratorAsSpliterator.Builder
Sets the batch increase size.
setCacheAvailability(String) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
setCacheAvailability(String) - Method in class org.infinispan.cache.impl.CacheImpl
 
setCacheAvailability(String, AvailabilityMode) - Method in interface org.infinispan.topology.LocalTopologyManager
Updates the availability state of a cache (for the entire cluster).
setCacheAvailability(String, AvailabilityMode) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
setCacheAvailability(String, AvailabilityMode) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
SetCacheAvailabilityAction - Class in org.infinispan.security.actions
SetCacheAvailabilityAction.
SetCacheAvailabilityAction(AdvancedCache<?, ?>, AvailabilityMode) - Constructor for class org.infinispan.security.actions.SetCacheAvailabilityAction
 
setCacheManager(EmbeddedCacheManager) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
setCacheName(String) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
setCacheRebalancingEnabled(String, boolean) - Method in interface org.infinispan.topology.LocalTopologyManager
Enable or disable rebalancing for the specified cache.
setCacheRebalancingEnabled(String, boolean) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
setCacheRebalancingEnabled(String, boolean) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
setCacheTopology(CacheTopology) - Method in interface org.infinispan.distribution.DistributionManager
Deprecated.
Internal only.
setCacheTopology(CacheTopology) - Method in class org.infinispan.distribution.impl.DistributionManagerImpl
 
setCancellation(ScheduledFuture<?>) - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor.LockTimeoutFuture
 
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.ClearCacheEntry
 
setChanged(boolean) - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
setChanged(boolean) - Method in interface org.infinispan.container.entries.MVCCEntry
 
setChanged(boolean) - Method in class org.infinispan.container.entries.NullCacheEntry
 
setChanged(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setCharacteristics(int) - Method in class org.infinispan.stream.impl.spliterators.IteratorAsSpliterator.Builder
Sets the characteristics the subsequent spliterator will have.
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
Deprecated.
Not in use any more.
setClassLoader(ClassLoader) - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
Deprecated.
 
setClassLoader(ClassLoader) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
setClearOnStop(boolean) - Method in interface org.infinispan.persistence.manager.PersistenceManager
 
setClearOnStop(boolean) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
setClearOnStop(boolean) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
setClustered(boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
setCoinToss(long) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
Deprecated.
Sets the random number that defines the coin toss.
setCommandAckCollector(CommandAckCollector) - Method in class org.infinispan.commands.write.BackupAckCommand
 
setCommandAckCollector(CommandAckCollector) - Method in class org.infinispan.commands.write.BackupMultiKeyAckCommand
 
setCommandAckCollector(CommandAckCollector) - Method in class org.infinispan.commands.write.ExceptionAckCommand
 
setCommandRetried(boolean) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
setCommitted() - Method in interface org.infinispan.container.entries.MVCCEntry
Mark this context-entry as already committed to the DataContainer.
setCommitted() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setCompletionFailed(boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareLocalTransaction
 
setComponent(String) - Method in class org.infinispan.factories.threads.DefaultThreadFactory
 
setComponentClass(Class<?>) - Method in class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
 
setComputeCommand(ComputeCommand) - Method in class org.infinispan.commands.triangle.SingleKeyBackupWriteCommand
 
setComputeIfAbsentCommand(ComputeIfAbsentCommand) - Method in class org.infinispan.commands.triangle.SingleKeyBackupWriteCommand
 
setComputeIfPresent(boolean) - Method in class org.infinispan.commands.write.ComputeCommand
 
setContext(PrincipalRoleMapperContext) - Method in class org.infinispan.security.impl.ClusterRoleMapper
 
setContext(PrincipalRoleMapperContext) - Method in class org.infinispan.security.impl.CommonNameRoleMapper
 
setContext(PrincipalRoleMapperContext) - Method in class org.infinispan.security.impl.IdentityRoleMapper
 
setContext(PrincipalRoleMapperContext) - Method in interface org.infinispan.security.PrincipalRoleMapper
Sets the context for this PrincipalRoleMapper
setConverter(CacheEventConverter<? super K, ? super V, ?>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
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.ClearCacheEntry
 
setCreated(boolean) - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
setCreated(boolean) - Method in class org.infinispan.container.entries.NullCacheEntry
 
setCreated(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setCreated(boolean) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
setCreated(long) - Method in interface org.infinispan.container.entries.CacheEntry
 
setCreated(long) - Method in class org.infinispan.container.entries.MortalCacheValue
 
setCreated(long) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setCurrentState(boolean) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
setDefaultNamespace(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
setEnlisted(boolean) - Method in class org.infinispan.transaction.synchronization.SyncLocalTransaction
 
setEntries(Map<? extends K, ? extends V>) - Method in class org.infinispan.notifications.cachelistener.event.impl.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.notifications.cachelistener.cluster.ClusterEventCallable
 
setEnvironment(Cache<K, V>, Set<K>) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerRemoveCallable
 
setEnvironment(Cache<K, V>, Set<K>) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerReplicateCallable
 
setEnvironment(Cache<K, V>, Set<K>) - Method in class org.infinispan.notifications.cachelistener.cluster.MultiClusterEventCallable
 
setEstimateRemaining(long) - Method in class org.infinispan.stream.impl.spliterators.IteratorAsSpliterator.Builder
Sets how many estimated elements are remaining for this iterator This defaults to Long.MAX_VALUE.
setEvent(E) - Method in class org.infinispan.notifications.cachelistener.EventWrapper
 
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.ClearCacheEntry
 
setEvicted(boolean) - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
setEvicted(boolean) - Method in class org.infinispan.container.entries.NullCacheEntry
 
setEvicted(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setEvictionSize(long) - Method in class org.infinispan.cache.impl.CacheConfigurationMBean
 
setException(Exception) - Method in class org.infinispan.remoting.responses.ExceptionResponse
 
setExecutable(boolean) - Method in class org.infinispan.io.GridFile
 
setExecutable(boolean, boolean) - Method in class org.infinispan.io.GridFile
 
setExpired(boolean) - Method in interface org.infinispan.container.entries.MVCCEntry
Marks this entry as being expired.
setExpired(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setField(Field) - Method in class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
 
setFilter(CacheEventFilter<? super K, ? super V>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
setFilterAnnotations(Set<Class<? extends Annotation>>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
setFirstInChain(CommandInterceptor) - Method in class org.infinispan.interceptors.InterceptorChain
Deprecated.
Mainly used by unit tests to replace the interceptor chain with the starting point passed in.
setFirstTopologyAsMember(int) - Method in class org.infinispan.remoting.inboundhandler.AbstractDelegatingHandler
 
setFirstTopologyAsMember(int) - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
 
setFirstTopologyAsMember(int) - Method in interface org.infinispan.remoting.inboundhandler.PerCacheInboundInvocationHandler
 
setFlag(ReadCommittedEntry.Flags) - Method in class org.infinispan.container.entries.ReadCommittedEntry
Utility method that sets the value of the given flag to true.
setFlags(Set<Flag>) - Method in interface org.infinispan.commands.FlagAffectedCommand
Deprecated.
Since 9.0, please use FlagAffectedCommand.setFlagsBitSet(long) instead.
setFlagsBitSet(long) - Method in class org.infinispan.commands.AbstractFlagAffectedCommand
 
setFlagsBitSet(long) - Method in class org.infinispan.commands.control.LockControlCommand
 
setFlagsBitSet(long) - Method in interface org.infinispan.commands.FlagAffectedCommand
Set the flags, replacing any existing flags.
setFlagsBitSet(long) - Method in class org.infinispan.commands.functional.AbstractWriteManyCommand
 
setFlagsBitSet(long) - Method in class org.infinispan.commands.read.AbstractDataCommand
 
setFlagsBitSet(long) - Method in class org.infinispan.commands.remote.BaseClusteredReadCommand
 
setForwarded(boolean) - Method in class org.infinispan.commands.functional.AbstractWriteManyCommand
 
setForwarded(boolean) - Method in class org.infinispan.commands.functional.ReadWriteManyCommand
 
setForwarded(boolean) - Method in class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
setForwarded(boolean) - Method in class org.infinispan.commands.write.PutMapCommand
 
setFromRemoteSite(boolean) - Method in class org.infinispan.transaction.impl.LocalTransaction
 
setGlobalTransaction(GlobalTransaction) - Method in class org.infinispan.commands.control.LockControlCommand
 
setGroupManager(GroupManager) - Method in class org.infinispan.commands.remote.GetKeysInGroupCommand
 
setGroupOwner(boolean) - Method in class org.infinispan.commands.remote.GetKeysInGroupCommand
 
setId(long) - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
setIdentifier(UUID) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
setIncludeCurrentState(boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
setInitialCacheTopologyId(String, int) - Method in interface org.infinispan.topology.ClusterTopologyManager
Sets the id of the initial topology in given cache.
setInitialCacheTopologyId(String, int) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
setInitialTopologyId(int) - Method in class org.infinispan.topology.ClusterCacheStatus
 
setInternalCacheValueConsumer() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
setInternalId(long) - Method in interface org.infinispan.transaction.xa.recovery.RecoverableTransactionIdentifier
 
setInternalId(long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction
Deprecated.
 
setInternalId(long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction
 
setJmxDomain(String) - Method in class org.infinispan.jmx.ComponentsJmxRegistration
 
setKeepAliveTime(long) - Method in class org.infinispan.executors.ManageableExecutorService
 
setKey(Object) - Method in class org.infinispan.commands.read.AbstractDataCommand
 
setKey(K) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
setKeyDataConversion(DataConversion) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
setKeyInvalidationListener(StateConsumerImpl.KeyInvalidationListener) - Method in class org.infinispan.statetransfer.StateConsumerImpl
 
setKeys(Object[]) - Method in class org.infinispan.commands.write.InvalidateL1Command
 
setKeys(Collection<?>) - Method in class org.infinispan.commands.functional.ReadOnlyManyCommand
 
setKeys(Collection<?>) - Method in class org.infinispan.commands.functional.ReadWriteManyCommand
 
setKeys(Collection<?>) - Method in class org.infinispan.commands.functional.WriteOnlyManyCommand
 
setKeys(Collection<?>) - Method in class org.infinispan.commands.read.GetAllCommand
 
setLastModified(long) - Method in class org.infinispan.io.GridFile
 
setLastUsed(long) - Method in interface org.infinispan.container.entries.CacheEntry
 
setLastUsed(long) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
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 interface org.infinispan.container.entries.CacheEntry
Deprecated.
since 8.1
setLoaded(boolean) - Method in interface org.infinispan.container.entries.MVCCEntry
 
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.impl.EventImpl
 
setLockIntention(Collection<Object>) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
Deprecated.
 
setLockOwner(Object) - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
setLockOwner(Object) - Method in class org.infinispan.context.impl.ClearInvocationContext
 
setLockOwner(Object) - Method in class org.infinispan.context.impl.ImmutableContext
 
setLockOwner(Object) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
setLockOwner(Object) - Method in interface org.infinispan.context.InvocationContext
Sets the object to be used by lock owner.
setLockOwner(Object) - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
Deprecated.
 
setLocksHeldAtOrigin(Collection<?>) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
Deprecated.
 
setLookedUpEntriesTopology(int) - Method in class org.infinispan.transaction.impl.RemoteTransaction
 
setMap(Map<Object, Object>) - Method in class org.infinispan.commands.write.PutMapCommand
 
SetMapper<E,​R> - Class in org.infinispan.util
A set that maps another one to a new one of a possibly different type.
SetMapper(Set<E>, Function<? super E, ? extends R>) - Constructor for class org.infinispan.util.SetMapper
 
setMarshaller(StreamingMarshaller) - Method in interface org.infinispan.persistence.keymappers.MarshallingTwoWayKey2StringMapper
 
setMarshaller(StreamingMarshaller) - Method in class org.infinispan.persistence.keymappers.WrappedByteArrayOrPrimitiveMapper
 
setMaxBatchSize(int) - Method in class org.infinispan.stream.impl.spliterators.IteratorAsSpliterator.Builder
Sets the max batch size for a thread to use - This defaults to 51200
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
 
setMaximumPoolSize(int) - Method in class org.infinispan.executors.ManageableExecutorService
 
setMergeView(boolean) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
setMetadata(Metadata) - Method in interface org.infinispan.commands.MetadataAwareCommand
Sets metadata for this command.
setMetadata(Metadata) - Method in class org.infinispan.commands.write.ComputeCommand
 
setMetadata(Metadata) - Method in class org.infinispan.commands.write.ComputeIfAbsentCommand
 
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.RemoveCommand
 
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.ClearCacheEntry
 
setMetadata(Metadata) - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
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.NullCacheEntry
 
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
 
setMetadata(Metadata) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
setMethod(Method) - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMethodMetadata
 
setMethod(Method) - Method in class org.infinispan.factories.components.ComponentMetadata.PrioritizedMethodMetadata
 
setMethod(Method) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
setModifications(List<WriteCommand>) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
setModificationTime(long) - Method in class org.infinispan.io.GridFile.Metadata
 
setNamespaceContext(NamespaceContext) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
setNewMembers(List<Address>) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
setNewTopologyId(int) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
setNewValue(Object) - Method in class org.infinispan.commands.write.ReplaceCommand
 
setNext(long, long) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
Called to update the next pointer index when a collision occurs requiring a linked list within the entries themselves
setNext(long, long) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
 
setNext(CommandInterceptor) - Method in class org.infinispan.interceptors.base.CommandInterceptor
Deprecated.
Does nothing since 9.0.
setNextInterceptor(AsyncInterceptor) - Method in interface org.infinispan.interceptors.AsyncInterceptor
Sets up the interceptor.
setNextInterceptor(AsyncInterceptor) - Method in class org.infinispan.interceptors.base.CommandInterceptor
Deprecated.
 
setNextInterceptor(AsyncInterceptor) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
Used internally to set up the interceptor.
setNode(String) - Method in class org.infinispan.factories.threads.DefaultThreadFactory
 
setObservation(Listener.Observation) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
setOldMembers(List<Address>) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
setOldMetadata(Metadata) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
setOldValue(Object) - Method in class org.infinispan.commands.write.ReplaceCommand
 
setOldValue(V) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
setOnlyPrimary(boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
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 interface org.infinispan.commands.ReplicableCommand
Sets the sender's Address.
setOrigin(Address) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
setOriginLocal(boolean) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
setOriginSite(String) - Method in class org.infinispan.xsite.XSiteReplicateCommand
 
setOwnedSegments(IntSet) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
setOwnedSegments(IntSet) - Method in interface org.infinispan.scattered.ScatteredVersionManager
setParameterClasses(Class<?>[]) - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMethodMetadata
 
setParams(Params) - Method in class org.infinispan.commands.functional.AbstractWriteManyCommand
 
setParserContext(Class<? extends ConfigurationParser>, ParserContext) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
setPre(boolean) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
setPrefix(String, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
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
 
setPrevValueAndMetadata(Object, Metadata) - Method in class org.infinispan.commands.functional.ReadWriteKeyValueCommand
 
setProperty(String, float) - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
 
setProperty(String, float) - Method in interface org.infinispan.globalstate.ScopedPersistentState
Sets a float state property.
setProperty(String, int) - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
 
setProperty(String, int) - Method in interface org.infinispan.globalstate.ScopedPersistentState
Sets an integer state property.
setProperty(String, Object) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
Defines a single value.
setProperty(String, String) - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
 
setProperty(String, String) - Method in interface org.infinispan.globalstate.ScopedPersistentState
Sets a state property.
setPutIfAbsent(boolean) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
setPutKeyValueCommand(PutKeyValueCommand) - Method in class org.infinispan.commands.triangle.SingleKeyBackupWriteCommand
 
setPutMapCommand(PutMapCommand, Collection<Object>) - Method in class org.infinispan.commands.triangle.PutMapBackupWriteCommand
 
setRead() - Method in interface org.infinispan.container.entries.MVCCEntry
Mark that this entry was loaded from the cache (as opposed to generated by the application using write-only command), mostly for purposes of the write skew check.
setRead() - Method in class org.infinispan.container.entries.RepeatableReadEntry
 
setReadable(boolean) - Method in class org.infinispan.io.GridFile
 
setReadable(boolean, boolean) - Method in class org.infinispan.io.GridFile
 
setReadConsistentHashAtEnd(ConsistentHash) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
setReadConsistentHashAtStart(ConsistentHash) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
setReadOnly() - Method in class org.infinispan.io.GridFile
 
setReadWrite(ReadWriteManyCommand<K, V, R>, Collection<Object>) - Method in class org.infinispan.commands.triangle.MultiKeyFunctionalBackupWriteCommand
 
setReadWrite(ReadWriteManyEntriesCommand<K, V, T, R>, Collection<Object>) - Method in class org.infinispan.commands.triangle.MultiEntriesFunctionalBackupWriteCommand
 
setReadWriteKeyCommand(ReadWriteKeyCommand) - Method in class org.infinispan.commands.triangle.SingleKeyFunctionalBackupWriteCommand
 
setReadWriteKeyValueCommand(ReadWriteKeyValueCommand) - Method in class org.infinispan.commands.triangle.SingleKeyFunctionalBackupWriteCommand
 
setRebalanced(boolean) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
setRebalanceEnabled(boolean) - Method in class org.infinispan.topology.ClusterCacheStatus
 
setRebalancingEnabled(boolean) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
setRebalancingEnabled(boolean) - Method in class org.infinispan.cache.impl.CacheImpl
 
setRebalancingEnabled(boolean) - Method in interface org.infinispan.topology.ClusterTopologyManager
Globally enables or disables whether automatic rebalancing should occur.
setRebalancingEnabled(boolean) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
setRebalancingEnabled(boolean) - Method in interface org.infinispan.topology.LocalTopologyManager
Enable or disable rebalancing in the entire cluster.
setRebalancingEnabled(boolean) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
setRebalancingEnabled(boolean) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
setRebalancingEnabled(String, boolean) - Method in interface org.infinispan.topology.ClusterTopologyManager
Enables or disables rebalancing for the specified cache
setRebalancingEnabled(String, boolean) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
setRemote(boolean) - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
setRemoteLockIntention(Collection<?>) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
Deprecated.
 
setRemoveCommand(RemoveCommand, boolean) - Method in class org.infinispan.commands.triangle.SingleKeyBackupWriteCommand
 
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.ClearCacheEntry
 
setRemoved(boolean) - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
setRemoved(boolean) - Method in class org.infinispan.container.entries.NullCacheEntry
 
setRemoved(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setReplaceCommand(ReplaceCommand) - Method in class org.infinispan.commands.triangle.SingleKeyBackupWriteCommand
 
setReplayEntryWrapping(boolean) - Method in class org.infinispan.commands.tx.PrepareCommand
 
setRetriedCommand(boolean) - Method in class org.infinispan.commands.tx.PrepareCommand
 
setRollbackOnly() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Deprecated.
Mark the transaction associated with the calling thread for rollback only.
setRollbackOnly() - Method in class org.infinispan.transaction.tm.DummyTransaction
Deprecated.
Mark the transaction so that the only possible outcome is a rollback.
setRollbackOnly() - Method in class org.infinispan.transaction.tm.DummyUserTransaction
Deprecated.
Mark the transaction so that the only possible outcome is a rollback.
setRollbackOnly() - Method in class org.infinispan.transaction.tm.EmbeddedUserTransaction
 
setSchema(Schema) - Method in interface org.infinispan.configuration.parsing.XMLExtendedStreamReader
Sets the current schema
setSegmentId(int) - Method in class org.infinispan.commands.triangle.BackupWriteCommand
 
setSequence(long) - Method in class org.infinispan.commands.triangle.BackupWriteCommand
 
setSiteName(String) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
 
setSkipLookup(boolean) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
setSkipLookup(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
setSkipLookup(boolean) - Method in class org.infinispan.container.entries.ClearCacheEntry
 
setSkipLookup(boolean) - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
setSkipLookup(boolean) - Method in class org.infinispan.container.entries.NullCacheEntry
 
setSkipLookup(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setSkipLookup(boolean) - Method in class org.infinispan.container.entries.RepeatableReadEntry
 
setSkipRemoteGetsAndInvokeNextForDataCommand(InvocationContext, DataWriteCommand) - Method in class org.infinispan.interceptors.impl.BiasedEntryWrappingInterceptor
 
setSkipRemoteGetsAndInvokeNextForDataCommand(InvocationContext, DataWriteCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
Locks the value for the keys accessed by the command to avoid being override from a remote get.
setSkipRemoteGetsAndInvokeNextForDataCommand(InvocationContext, DataWriteCommand) - Method in class org.infinispan.interceptors.impl.RetryingEntryWrappingInterceptor
 
setSkipRemoteGetsAndInvokeNextForManyEntriesCommand(InvocationContext, WriteCommand) - Method in class org.infinispan.interceptors.impl.BiasedEntryWrappingInterceptor
 
setSkipRemoteGetsAndInvokeNextForManyEntriesCommand(InvocationContext, WriteCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
Locks the value for the keys accessed by the command to avoid being override from a remote get.
setSkipRemoteGetsAndInvokeNextForManyEntriesCommand(InvocationContext, WriteCommand) - Method in class org.infinispan.interceptors.impl.RetryingEntryWrappingInterceptor
 
setStaleStatsThreshold(long) - Method in class org.infinispan.stats.impl.AbstractClusterStats
 
setStateTransferFlag(Flag) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
setStateTransferFlag(Flag) - Method in class org.infinispan.transaction.impl.LocalTransaction
 
setStateTransferFlag(Flag) - Method in class org.infinispan.transaction.impl.RemoteTransaction
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.eviction.impl.PassivationManagerImpl
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.eviction.impl.PassivationManagerStub
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.interceptors.impl.InvalidationInterceptor
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.interceptors.impl.JmxStatsCommandInterceptor
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
setStatisticsEnabled(boolean) - Method in interface org.infinispan.jmx.JmxStatisticsExposer
Enables an interceptor's cache statistics If true, the interceptor will capture statistics and make them available through the mbean.
setStatisticsEnabled(boolean) - Method in class org.infinispan.remoting.inboundhandler.AbstractDelegatingHandler
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
 
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 class org.infinispan.stats.impl.AbstractClusterStats
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.stats.impl.StatsCollector
 
setStatisticsEnabled(boolean) - Method in class org.infinispan.stats.impl.StatsImpl
 
setStatisticsEnabled(boolean) - Method in interface org.infinispan.stats.Stats
Enables or disables statistics at runtime.
setStatusOk(boolean) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
 
setSubgroupsMerged(List<List<Address>>) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
setSubject(Subject) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
setSupplier(Supplier<Stream<Original>>) - Method in interface org.infinispan.stream.impl.KeyTrackingTerminalOperation
This method is to be invoked only locally after a key tracking operation has been serialized to a new node
setSupplier(Supplier<Stream<Original>>) - Method in interface org.infinispan.stream.impl.TerminalOperation
Sets the local supplier for the stream.
setSupplier(Supplier<Stream<Original>>) - Method in class org.infinispan.stream.impl.termop.BaseTerminalOperation
 
setSync(boolean) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
setTakeOfflineAfterFailures(String, int) - Method in class org.infinispan.xsite.XSiteAdminOperations
 
setTakeOfflineMinTimeToWait(String, long) - Method in class org.infinispan.xsite.XSiteAdminOperations
 
setTarget(Object) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
SetThreadContextClassLoaderAction - Class in org.infinispan.security.actions
SetThreadContextClassLoaderAction.
SetThreadContextClassLoaderAction(Class<?>) - Constructor for class org.infinispan.security.actions.SetThreadContextClassLoaderAction
 
SetThreadContextClassLoaderAction(ClassLoader) - Constructor for class org.infinispan.security.actions.SetThreadContextClassLoaderAction
 
setThreadLocal(InvocationContext) - Method in interface org.infinispan.context.InvocationContextContainer
Deprecated.
Associate the InvocationContext parameter with the calling thread.
setTimeout(ScheduledExecutorService, long, TimeUnit) - Method in class org.infinispan.remoting.transport.AbstractRequest
Schedule a timeout task on the given executor, and complete the request with a TimeoutException when the task runs.
setTimeout(ScheduledExecutorService, long, TimeUnit) - Method in class org.infinispan.remoting.transport.jgroups.StaggeredRequest
 
setTimeService(TimeService) - Method in class org.infinispan.util.concurrent.locks.impl.InfinispanLock
Tests purpose only!
setTopologyId(int) - Method in class org.infinispan.commands.AbstractTopologyAffectedCommand
 
setTopologyId(int) - Method in class org.infinispan.commands.functional.AbstractWriteManyCommand
 
setTopologyId(int) - Method in class org.infinispan.commands.read.AbstractDataCommand
 
setTopologyId(int) - Method in class org.infinispan.commands.remote.BaseClusteredReadCommand
 
setTopologyId(int) - Method in class org.infinispan.commands.remote.expiration.RetrieveLastAccessCommand
 
setTopologyId(int) - Method in class org.infinispan.commands.remote.expiration.UpdateLastAccessCommand
 
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
 
setTopologyId(int) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
setTopologyId(int) - Method in interface org.infinispan.scattered.ScatteredVersionManager
Set current topology id.
setTopologyId(int) - Method in class org.infinispan.statetransfer.StateRequestCommand
 
setTopologyId(int) - Method in class org.infinispan.statetransfer.StateResponseCommand
 
setTopologyId(int) - Method in class org.infinispan.stream.impl.StreamIteratorNextCommand
 
setTopologyId(int) - Method in class org.infinispan.stream.impl.StreamRequestCommand
 
setTopologyId(int) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
 
setTransaction(Transaction) - Static method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Deprecated.
Just used for unit tests
setTransactionId(GlobalTransaction) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
setTransactionSuccessful(boolean) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
setTransactionSynchronizedBlock(TotalOrderLatch) - Method in class org.infinispan.transaction.impl.TotalOrderRemoteTransactionState
Sets the TotalOrderLatch to be associated to this transaction
setTransactionTimeout(int) - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Deprecated.
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
Deprecated.
Change the transaction timeout for transactions started by the calling thread with the DummyUserTransaction.begin() method.
setTransactionTimeout(int) - Method in class org.infinispan.transaction.tm.EmbeddedUserTransaction
 
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.impl.EventImpl
 
setUnionConsistentHash(ConsistentHash) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
setUnlock(boolean) - Method in class org.infinispan.commands.control.LockControlCommand
 
setUnregisterCacheMBean(boolean) - Method in class org.infinispan.jmx.CacheJmxRegistration
 
setUnspecifiedElementNamespace(String) - Method in interface org.infinispan.configuration.serializing.XMLExtendedStreamWriter
 
setUnspecifiedElementNamespace(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
setUpdatedEntryVersions(EntryVersionsMap) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
setUpdatedEntryVersions(EntryVersionsMap) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
setUpdatedVersions(EntryVersionsMap) - Method in class org.infinispan.commands.tx.VersionedCommitCommand
 
setUseXaXid(boolean) - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
Deprecated.
 
setValid(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
Deprecated.
since 9.2
setValue(Object) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
setValue(Object) - Method in class org.infinispan.commands.write.RemoveCommand
 
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.NullCacheEntry
 
setValue(Object) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
setValue(Object) - Method in class org.infinispan.container.entries.RepeatableReadEntry
 
setValue(Object) - Method in class org.infinispan.container.entries.TransientCacheEntry
 
setValue(Object) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
setValue(V) - Method in interface org.infinispan.container.entries.CacheEntry
Sets the value of the entry, returning the previous value
setValue(V) - Method in class org.infinispan.container.entries.ClearCacheEntry
 
setValue(V) - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
setValue(V) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
setValue(V) - Method in class org.infinispan.util.EntryWrapper
 
setValueConsumer() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
setValueDataConversion(DataConversion) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
setValueIfAbsentReturnBoolean() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
setValueIfAbsentReturnPrevOrNull() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
setValueIfEqualsReturnBoolean(V, MetaParam.Writable...) - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
SetValueIfEqualsReturnBooleanExternalizer() - Constructor for class org.infinispan.marshall.core.MarshallableFunctionExternalizers.SetValueIfEqualsReturnBooleanExternalizer
 
setValueIfPresentReturnBoolean() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
setValueIfPresentReturnPrevOrNull() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
setValueMatcher(ValueMatcher) - Method in class org.infinispan.commands.functional.AbstractWriteKeyCommand
 
setValueMatcher(ValueMatcher) - Method in class org.infinispan.commands.functional.AbstractWriteManyCommand
 
setValueMatcher(ValueMatcher) - Method in class org.infinispan.commands.write.ApplyDeltaCommand
Deprecated.
 
setValueMatcher(ValueMatcher) - Method in class org.infinispan.commands.write.ClearCommand
 
setValueMatcher(ValueMatcher) - Method in class org.infinispan.commands.write.ComputeCommand
 
setValueMatcher(ValueMatcher) - Method in class org.infinispan.commands.write.ComputeIfAbsentCommand
 
setValueMatcher(ValueMatcher) - Method in class org.infinispan.commands.write.InvalidateCommand
 
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
 
setValueMetasConsumer(MetaParam.Writable...) - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
setValueMetasIfAbsentReturnBoolean(MetaParam.Writable...) - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
setValueMetasIfAbsentReturnPrevOrNull(MetaParam.Writable...) - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
setValueMetasIfPresentReturnBoolean(MetaParam.Writable...) - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
setValueMetasIfPresentReturnPrevOrNull(MetaParam.Writable...) - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
setValueMetasReturnPrevOrNull(MetaParam.Writable...) - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
setValueMetasReturnView(MetaParam.Writable...) - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
setValueReturnPrevOrNull() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
setValueReturnView() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
 
setValues(Object, Map<?, ?>, boolean, boolean) - Static method in class org.infinispan.configuration.parsing.XmlConfigHelper
 
setValuesTransferTopology(int) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
setValuesTransferTopology(int) - Method in interface org.infinispan.scattered.ScatteredVersionManager
 
setVersion(EntryVersion) - Method in interface org.infinispan.container.entries.versioned.Versioned
Sets the version on this entry.
setVersion(EntryVersion) - Method in class org.infinispan.container.entries.VersionedRepeatableReadEntry
 
setVersionsSeen(EntryVersionsMap) - Method in class org.infinispan.commands.tx.VersionedPrepareCommand
 
setViewId(int) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
setWritable(boolean) - Method in class org.infinispan.io.GridFile
 
setWritable(boolean, boolean) - Method in class org.infinispan.io.GridFile
 
setWrite(boolean) - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
setWriteConsistentHashAtEnd(ConsistentHash) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
setWriteConsistentHashAtStart(ConsistentHash) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
setWriteOnly(WriteOnlyManyCommand<K, V>, Collection<Object>) - Method in class org.infinispan.commands.triangle.MultiKeyFunctionalBackupWriteCommand
 
setWriteOnly(WriteOnlyManyEntriesCommand<K, V, T>, Collection<Object>) - Method in class org.infinispan.commands.triangle.MultiEntriesFunctionalBackupWriteCommand
 
setWriteOnlyKeyCommand(WriteOnlyKeyCommand) - Method in class org.infinispan.commands.triangle.SingleKeyFunctionalBackupWriteCommand
 
setWriteOnlyKeyValueCommand(WriteOnlyKeyValueCommand) - Method in class org.infinispan.commands.triangle.SingleKeyFunctionalBackupWriteCommand
 
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
Deprecated.
 
setXid(Xid) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction
 
shared - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
Deprecated.
shared() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
shared() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
 
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(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.
SHARED - org.infinispan.configuration.parsing.Attribute
 
SHARED - org.infinispan.persistence.manager.PersistenceManager.AccessMode
The operation is performed only in shared configured CacheWriter or CacheLoader
SHARED - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
SHARED_PERSISTENT_LOCATION - org.infinispan.configuration.parsing.Element
 
SHARED_PERSISTENT_LOCATION - Static variable in class org.infinispan.configuration.global.GlobalStateConfiguration
 
sharedPersistentLocation() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
Returns the filesystem path where shared persistent state data which needs to survive container restarts should be stored.
sharedPersistentLocation(String) - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
Defines the filesystem path where shared persistent state data which needs to survive container restarts should be stored.
shortened(String) - Static method in class org.infinispan.factories.KnownComponentNames
 
shouldClose() - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelLookup
 
shouldCommitDuringPrepare(PrepareCommand, TxInvocationContext) - Method in class org.infinispan.interceptors.impl.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(boolean) - Method in enum org.infinispan.notifications.Listener.Observation
 
shouldInvoke(InvocationContext) - Method in interface org.infinispan.commands.VisitableCommand
Deprecated.
Since 9.0, no longer used.
shouldInvoke(CacheEntryEvent<K, V>, boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
shouldInvoke(Event<K, V>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
shouldInvokeRemoteTxCommand(TxInvocationContext) - Method in class org.infinispan.interceptors.impl.BaseRpcInterceptor
 
shouldInvokeRemoteTxCommand(TxInvocationContext) - Method in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
 
shouldRevoke() - Method in interface org.infinispan.scattered.BiasManager.Revocation
 
shouldStopSegments - Variable in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
shouldTotalOrderRollbackBeInvokedRemotely(TxInvocationContext) - Static method in class org.infinispan.interceptors.impl.BaseRpcInterceptor
 
shouldWrite(long) - Method in interface org.infinispan.persistence.spi.FlagAffectedStore
 
show(CommandInvocationId) - Static method in class org.infinispan.commands.CommandInvocationId
 
showInDoubtTransactions() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
showUnrecognizedAttributes(Map<Object, Object>) - Static method in class org.infinispan.configuration.parsing.XmlConfigHelper
 
shutdown() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
shutdown() - Method in class org.infinispan.cache.impl.CacheImpl
 
shutdown() - Method in interface org.infinispan.Cache
Performs a controlled, clustered shutdown of the cache.
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 configuration
shutdown() - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
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
 
SHUTDOWN - org.infinispan.configuration.parsing.Element
 
SHUTDOWN_HOOK - org.infinispan.configuration.parsing.Attribute
 
SHUTDOWN_PERFORM - org.infinispan.topology.CacheTopologyControlCommand.Type
 
SHUTDOWN_REQUEST - org.infinispan.topology.CacheTopologyControlCommand.Type
 
SHUTDOWN_TIMEOUT - org.infinispan.configuration.parsing.Attribute
Deprecated.
shutdownCache() - Method in class org.infinispan.topology.ClusterCacheStatus
 
ShutdownConfiguration - Class in org.infinispan.configuration.global
 
ShutdownConfigurationBuilder - Class in org.infinispan.configuration.global
 
shutdownHandlingCommand(ReplicableCommand) - Method in class org.infinispan.util.logging.Log_$logger
 
shutdownHandlingCommand(ReplicableCommand) - Method in interface org.infinispan.util.logging.Log
 
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.distexec.DefaultExecutorService
Deprecated.
 
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.executors.LimitedExecutor
Stops the executor and cancels any queued tasks.
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
Deprecated.
shutdownTimeout(long) - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
Deprecated.
shutdownTimeout(long) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
Deprecated.
shutdownTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
Deprecated.
SIMPLE - org.infinispan.configuration.cache.VersioningScheme
 
SIMPLE_CACHE - org.infinispan.configuration.parsing.Attribute
 
SIMPLE_CACHE - Static variable in class org.infinispan.configuration.cache.Configuration
 
SimpleAsyncInvocationStage - Class in org.infinispan.interceptors.impl
Invocation stage representing a computation that may or may not be done yet.
SimpleAsyncInvocationStage(Throwable) - Constructor for class org.infinispan.interceptors.impl.SimpleAsyncInvocationStage
 
SimpleAsyncInvocationStage(CompletionStage<?>) - Constructor for class org.infinispan.interceptors.impl.SimpleAsyncInvocationStage
 
simpleCache() - Method in class org.infinispan.configuration.cache.Configuration
 
simpleCache() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
simpleCache() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
simpleCache(boolean) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
simpleCache(boolean) - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
SimpleCacheImpl<K,​V> - Class in org.infinispan.cache.impl
Simple local cache without interceptor stack.
SimpleCacheImpl(String) - Constructor for class org.infinispan.cache.impl.SimpleCacheImpl
 
SimpleCacheImpl(String, DataConversion, DataConversion) - Constructor for class org.infinispan.cache.impl.SimpleCacheImpl
 
SimpleCacheImpl.CacheEntryChange<K,​V> - Class in org.infinispan.cache.impl
 
SimpleCacheImpl.CacheEntrySet - Class in org.infinispan.cache.impl
 
SimpleCacheImpl.EntrySet - Class in org.infinispan.cache.impl
 
SimpleCacheImpl.EntrySetBase<T extends Map.Entry<K,​V>> - Class in org.infinispan.cache.impl
 
SimpleCacheImpl.KeySet - Class in org.infinispan.cache.impl
 
SimpleCacheImpl.ValueAndMetadata<V> - Class in org.infinispan.cache.impl
 
SimpleCacheImpl.Values - Class in org.infinispan.cache.impl
 
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
 
since() - Method in annotation type org.infinispan.configuration.parsing.Namespace
The first version of the schema where this is supported.
since(int, int) - Method in class org.infinispan.configuration.parsing.Schema
 
singleChar() - Method in enum org.infinispan.scattered.ScatteredVersionManager.SegmentState
 
SingleFileStore<K,​V> - Class in org.infinispan.persistence.file
A filesystem-based implementation of a AdvancedLoadWriteStore.
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(AttributeSet, AsyncStoreConfiguration, SingletonStoreConfiguration) - 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
 
SingleFileStoreConfigurationBuilder(PersistenceConfigurationBuilder, AttributeSet) - Constructor for class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
 
SingleKeyBackupWriteCommand - Class in org.infinispan.commands.triangle
A single key BackupWriteCommand for single key non-functional commands.
SingleKeyBackupWriteCommand() - Constructor for class org.infinispan.commands.triangle.SingleKeyBackupWriteCommand
 
SingleKeyBackupWriteCommand(ByteString) - Constructor for class org.infinispan.commands.triangle.SingleKeyBackupWriteCommand
 
SingleKeyFunctionalBackupWriteCommand - Class in org.infinispan.commands.triangle
A single key BackupWriteCommand for single key functional commands.
SingleKeyFunctionalBackupWriteCommand() - Constructor for class org.infinispan.commands.triangle.SingleKeyFunctionalBackupWriteCommand
 
SingleKeyFunctionalBackupWriteCommand(ByteString) - Constructor for class org.infinispan.commands.triangle.SingleKeyFunctionalBackupWriteCommand
 
SingleKeyNonTxInvocationContext - Class in org.infinispan.context
Deprecated.
Since 9.0, this class is going to be moved to an internal package.
SingleKeyNonTxInvocationContext(Address) - Constructor for class org.infinispan.context.SingleKeyNonTxInvocationContext
Deprecated.
 
singleNodeSubmission() - Method in interface org.infinispan.manager.ClusterExecutor
When a command is submitted it will only be submitted to one node of the available nodes, there is no strict requirements as to which node is chosen and is implementation specific.
singleNodeSubmission(int) - Method in interface org.infinispan.manager.ClusterExecutor
When a command is submitted it will only be submitted to one node of the available nodes, there is no strict requirements as to which node is chosen and is implementation specific.
singleNodeSubmissionExecutor(Predicate<? super Address>, EmbeddedCacheManager, JGroupsTransport, long, TimeUnit, Executor, ScheduledExecutorService, int) - Static method in class org.infinispan.manager.impl.ClusterExecutors
 
SingleResponseCollector - Class in org.infinispan.remoting.transport.impl
Response collector for a single response.
SingleResponseCollector() - Constructor for class org.infinispan.remoting.transport.impl.SingleResponseCollector
 
SingleRpcCommand - Class in org.infinispan.commands.remote
Aggregates a single command for replication.
SingleRpcCommand(ByteString) - Constructor for class org.infinispan.commands.remote.SingleRpcCommand
 
SingleRpcCommand(ByteString, ReplicableCommand) - Constructor for class org.infinispan.commands.remote.SingleRpcCommand
 
SingleRunOperation<Original,​E,​R,​S extends BaseStream<R,​S>,​S2 extends S> - Class in org.infinispan.stream.impl.termop
Runs the provided function once only and returns the result.
SingleRunOperation(Iterable<IntermediateOperation>, Supplier<Stream<Original>>, Function<? super S2, ? extends E>) - Constructor for class org.infinispan.stream.impl.termop.SingleRunOperation
 
SingleSegmentKeyPartitioner - Class in org.infinispan.distribution.ch.impl
KeyPartitioner that always returns 0 for a given segment.
SingleSiteRequest<T> - Class in org.infinispan.remoting.transport.jgroups
Request implementation that waits for a response from a single target site.
SingleTargetRequest<T> - Class in org.infinispan.remoting.transport.impl
Request implementation that waits for a response from a single target node.
SingleTargetRequest(ResponseCollector<T>, long, RequestRepository, Address) - Constructor for class org.infinispan.remoting.transport.impl.SingleTargetRequest
 
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
Deprecated.
Singleton writers will be removed in 10.0. If it is desirable that all nodes don't write to the underlying store then a shared store should be used instead, as this only performs store writes at a key's primary owner.
SINGLETON - org.infinispan.configuration.parsing.Attribute
Deprecated.
SINGLETON_STORE - org.infinispan.configuration.parsing.Element
Deprecated.
SingletonCacheWriter - Class in org.infinispan.persistence.support
Deprecated.
this writer will be removed in 10.0. If it is desirable that all nodes don't write to the underlying store then a shared store should be used instead, as this only performs store writes at a key's primary owner.
SingletonCacheWriter(CacheWriter, SingletonStoreConfiguration) - Constructor for class org.infinispan.persistence.support.SingletonCacheWriter
Deprecated.
 
SingletonCacheWriter.PushStateException - Exception in org.infinispan.persistence.support
Deprecated.
Exception representing any issues that arise from pushing the in-memory state to the cache loader.
SingletonCacheWriter.SingletonStoreListener - Class in org.infinispan.persistence.support
Deprecated.
Cache listener that reacts to cluster topology changes to find out whether a new coordinator is elected.
SingletonMapResponseCollector - Class in org.infinispan.remoting.transport.impl
singletonStore - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
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() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
Deprecated.
Singleton writers will be removed in 10.0. If it is desirable that all nodes don't write to the underlying store then a shared store should be used instead, as this only performs store writes at a key's primary owner.
singletonStoreCannotBeShared(String) - Method in class org.infinispan.util.logging.Log_$logger
 
singletonStoreCannotBeShared(String) - Method in interface org.infinispan.util.logging.Log
 
singletonStoreCannotBeShared$str() - Method in class org.infinispan.util.logging.Log_$logger
 
SingletonStoreConfiguration - Class in org.infinispan.configuration.cache
Deprecated.
Singleton writers will be removed in 10.0. If it is desirable that all nodes don't write to the underlying store then a shared store should be used instead, as this only performs store writes at a key's primary owner.
SingletonStoreConfigurationBuilder<S> - Class in org.infinispan.configuration.cache
Deprecated.
Singleton writers will be removed in 10.0. If it is desirable that all nodes don't write to the underlying store then a shared store should be used instead, as this only performs store writes at a key's primary owner.
SingletonStoreListener() - Constructor for class org.infinispan.persistence.support.SingletonCacheWriter.SingletonStoreListener
Deprecated.
 
singleWriteOnRemotePrimary(Address, DataWriteCommand) - Method in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor
 
singleWriteOnRemotePrimary(Address, DataWriteCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
This method is called by a non-owner sending write request to the primary owner
singleWriteResponse(InvocationContext, DataWriteCommand, Object) - Method in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor
 
singleWriteResponse(InvocationContext, DataWriteCommand, Object) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
This method is called by primary owner responding to the originator after write has been completed
SingleXSiteRpcCommand - Class in org.infinispan.xsite
RPC command to replicate cache operations (such as put, remove, replace, etc.) to the backup site.
SingleXSiteRpcCommand() - Constructor for class org.infinispan.xsite.SingleXSiteRpcCommand
 
SingleXSiteRpcCommand(ByteString) - Constructor for class org.infinispan.xsite.SingleXSiteRpcCommand
 
SingleXSiteRpcCommand(ByteString, VisitableCommand) - Constructor for class org.infinispan.xsite.SingleXSiteRpcCommand
 
site() - Method in class org.infinispan.configuration.cache.BackupConfiguration
Returns the name of the site where this cache backups its data.
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
Cross-site replication configuration
site(String) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
SITE - org.infinispan.configuration.parsing.Attribute
 
SITE - org.infinispan.configuration.parsing.Element
 
SITE - org.infinispan.distribution.topologyaware.TopologyLevel
 
SITE - Static variable in class org.infinispan.configuration.cache.BackupConfiguration
 
SITE_ID - Static variable in class org.infinispan.configuration.global.TransportConfiguration
 
SITE_STATUS - org.infinispan.xsite.XSiteAdminCommand.AdminOperation
 
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.
SiteMasterPickerImpl - Class in org.infinispan.remoting.transport.jgroups
A SiteMasterPicker implementation that picks the first route.
SiteMasterPickerImpl() - Constructor for class org.infinispan.remoting.transport.jgroups.SiteMasterPickerImpl
 
siteMustBeInBackups(String) - Method in class org.infinispan.util.logging.Log_$logger
 
siteMustBeInBackups(String) - Method in interface org.infinispan.util.logging.Log
 
siteMustBeInBackups$str() - Method in class org.infinispan.util.logging.Log_$logger
 
siteOffline() - Method in interface org.infinispan.xsite.notification.SiteStatusListener
 
siteOffline(String) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
siteOffline(String) - Method in interface org.infinispan.util.logging.events.Messages
 
siteOffline$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
siteOnline() - Method in interface org.infinispan.xsite.notification.SiteStatusListener
 
siteOnline(String) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
siteOnline(String) - Method in interface org.infinispan.util.logging.events.Messages
 
siteOnline$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
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
 
SITES - org.infinispan.configuration.parsing.Element
 
SitesConfiguration - Class in org.infinispan.configuration.cache
 
SitesConfiguration(AttributeSet, List<BackupConfiguration>, BackupForConfiguration) - 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
 
SiteStatus - Interface in org.infinispan.xsite.status
A site status.
SiteStatusListener - Interface in org.infinispan.xsite.notification
A simple interface that is invoked by OfflineStatus when a particular site changes its status to online/offline.
sitesUnreachable(String) - Method in class org.infinispan.remoting.transport.jgroups.SingleSiteRequest
 
size() - Method in class org.infinispan.atomic.impl.AtomicMapProxyImpl
 
size() - Method in class org.infinispan.atomic.impl.FineGrainedAtomicMapProxyImpl
 
size() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
size() - Method in class org.infinispan.cache.impl.CacheImpl
 
size() - Method in class org.infinispan.cache.impl.DecoratedCache
 
size() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySetBase
 
size() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.KeySet
 
size() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
size() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.Values
 
size() - Method in interface org.infinispan.Cache
Returns a count of all elements in this cache and cache loader across the entire cluster.
size() - Method in class org.infinispan.commands.read.AbstractCloseableIteratorCollection
 
size() - Method in class org.infinispan.configuration.cache.EvictionConfiguration
Deprecated.
size() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
Size of the eviction, -1 if disabled
size() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
The configured eviction size, please see MemoryConfigurationBuilder.size(long).
size() - Method in interface org.infinispan.container.DataContainer
 
size() - Method in class org.infinispan.container.impl.AbstractDelegatingDataContainer
 
size() - Method in class org.infinispan.container.impl.AbstractInternalDataContainer.Values
Deprecated.
 
size() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
size() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
Returns the size of the read only set.
size() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
Returns the size of the read only map.
size() - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Returns the number of interceptors in the chain.
size() - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
size() - Method in class org.infinispan.interceptors.impl.AsyncInterceptorChainImpl
 
size() - Method in class org.infinispan.interceptors.InterceptorChain
Deprecated.
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.persistence.async.AdvancedAsyncCacheLoader
 
size() - Method in class org.infinispan.persistence.file.SingleFileStore
 
size() - Method in interface org.infinispan.persistence.manager.PersistenceManager
 
size() - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader
Returns the number of elements in the store.
size() - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
size() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
size() - Method in class org.infinispan.util.CollectionMapper
 
size() - Method in interface org.infinispan.util.concurrent.locks.impl.LockContainer
 
size() - Method in class org.infinispan.util.concurrent.locks.impl.PerKeyLockContainer
 
size() - Method in class org.infinispan.util.concurrent.locks.impl.StripedLockContainer
 
size() - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
 
size() - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
Deprecated.
 
size(long) - Method in class org.infinispan.configuration.cache.EvictionConfiguration
Deprecated.
size(long) - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
Deprecated.
Defines the maximum size before eviction occurs.
size(long) - Method in class org.infinispan.configuration.cache.MemoryConfiguration
 
size(long) - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
Defines the maximum size before eviction occurs.
size(Predicate<? super StoreConfiguration>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
Returns the count of how many entries are persisted.
size(Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
size(Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
size(IntSet) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
size(IntSet) - Method in interface org.infinispan.container.impl.InternalDataContainer
Returns how many entries are present in the data container that map to the given segments without counting entries that are currently expired.
size(IntSet) - Method in interface org.infinispan.persistence.manager.PersistenceManager
Returns the count of how many entries are persisted within the given segments.
size(IntSet) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
size(IntSet) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
size(IntSet) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
Returns the number of elements in the store that map to the given segments that aren't expired.
size(IntSet) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
SIZE - org.infinispan.configuration.parsing.Attribute
 
SIZE - Static variable in class org.infinispan.configuration.cache.EvictionConfiguration
Deprecated.
 
SIZE - Static variable in class org.infinispan.configuration.cache.MemoryConfiguration
 
SizeCalculatorFactory - Class in org.infinispan.factories
Factory for creating size calculator used to estimate size of objects
SizeCalculatorFactory() - Constructor for class org.infinispan.factories.SizeCalculatorFactory
 
SizeCommand - Class in org.infinispan.commands.read
Command to calculate the size of the cache
SizeCommand(Cache<Object, ?>, long) - Constructor for class org.infinispan.commands.read.SizeCommand
 
sizeIncludingExpired() - Method in interface org.infinispan.container.DataContainer
 
sizeIncludingExpired() - Method in class org.infinispan.container.impl.AbstractDelegatingDataContainer
 
sizeIncludingExpired() - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
sizeIncludingExpired() - Method in class org.infinispan.container.impl.DefaultDataContainer
 
sizeIncludingExpired() - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
sizeIncludingExpired() - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
sizeIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
sizeIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
sizeIncludingExpired(IntSet) - Method in interface org.infinispan.container.impl.InternalDataContainer
Returns how many entries are present in the data container that map to the given segments including any entries that may be expired
skip(long) - Method in interface org.infinispan.CacheStream
skip(long) - Method in interface org.infinispan.DoubleCacheStream
skip(long) - Method in interface org.infinispan.IntCacheStream
skip(long) - Method in class org.infinispan.io.GridInputStream
 
skip(long) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
skip(long) - Method in interface org.infinispan.LongCacheStream
skip(long) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
skip(long) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
skip(long) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
skip(long) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
skip(long) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
skip(long) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
skip(long) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
skip(long) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
skip(long) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
skip(long) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
skip(long) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
skip(long) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
skip(long) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
SKIP - org.infinispan.functional.Param.LockingMode
 
SKIP - org.infinispan.functional.Param.PersistenceMode
 
SKIP - org.infinispan.functional.Param.StatisticsMode
Statistics from this command are not recorded
SKIP_CACHE_LOAD - org.infinispan.context.Flag
Skips loading an entry from any configured CacheLoaders.
SKIP_CACHE_LOAD - Static variable in class org.infinispan.context.impl.FlagBitSets
 
SKIP_CACHE_STATUS_CHECK - org.infinispan.context.Flag
Deprecated.
This flag is no longer in use.
SKIP_CACHE_STORE - org.infinispan.context.Flag
Skips storing an entry to any configured CacheLoaders.
SKIP_CACHE_STORE - Static variable in class org.infinispan.context.impl.FlagBitSets
 
SKIP_INDEX_CLEANUP - org.infinispan.context.Flag
Any time a new indexed entry is inserted, a delete statement is issued on the indexes to remove previous values.
SKIP_INDEX_CLEANUP - Static variable in class org.infinispan.context.impl.FlagBitSets
 
SKIP_INDEXING - org.infinispan.context.Flag
Used by the Query module only, it will prevent the indexes to be updated as a result of the current operations.
SKIP_INDEXING - Static variable in class org.infinispan.context.impl.FlagBitSets
 
SKIP_LISTENER_NOTIFICATION - org.infinispan.context.Flag
This flag skips listener notifications as a result of a cache operation.
SKIP_LISTENER_NOTIFICATION - Static variable in class org.infinispan.context.impl.FlagBitSets
 
SKIP_LOAD - org.infinispan.functional.Param.PersistenceMode
 
SKIP_LOCKING - org.infinispan.context.Flag
Bypasses lock acquisition for this invocation altogether.
SKIP_LOCKING - Static variable in class org.infinispan.context.impl.FlagBitSets
 
SKIP_LOOKUP - org.infinispan.container.entries.ReadCommittedEntry.Flags
 
SKIP_OWNERSHIP_CHECK - org.infinispan.context.Flag
Ignore current consistent hash and read from data container/commit the change no matter what (if the flag is set).
SKIP_OWNERSHIP_CHECK - Static variable in class org.infinispan.context.impl.FlagBitSets
 
SKIP_OWNERSHIP_FLAGS - Static variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
SKIP_PERSIST - org.infinispan.functional.Param.PersistenceMode
 
SKIP_REMOTE_LOOKUP - org.infinispan.context.Flag
When used with distributed cache mode, will prevent retrieving a remote value either when executing a Map.get(Object) or Map.containsKey(Object), or to return the overwritten value for BasicCache.put(Object, Object) or BasicCache.remove(Object).
SKIP_REMOTE_LOOKUP - Static variable in class org.infinispan.context.impl.FlagBitSets
 
SKIP_SHARED_CACHE_STORE - org.infinispan.context.Flag
If this flag is enabled, if a cache store is shared, then storage to the store is skipped.
SKIP_SHARED_CACHE_STORE - Static variable in class org.infinispan.context.impl.FlagBitSets
 
SKIP_SIZE_OPTIMIZATION - org.infinispan.context.Flag
Flag that can be used to skip any size optimizations - forcing iteration of entries to count.
SKIP_SIZE_OPTIMIZATION - Static variable in class org.infinispan.context.impl.FlagBitSets
 
SKIP_STATISTICS - org.infinispan.context.Flag
This flag skips statistics updates as a result of a cache operation.
SKIP_STATISTICS - Static variable in class org.infinispan.context.impl.FlagBitSets
 
SKIP_XSITE_BACKUP - org.infinispan.context.Flag
If cross-site replication is enabled, this would skip the replication to any remote site.
SKIP_XSITE_BACKUP - Static variable in class org.infinispan.context.impl.FlagBitSets
 
skipBytes(int) - Method in class org.infinispan.io.UnclosableObjectInputStream
 
SkipDoubleOperation - Class in org.infinispan.stream.impl.intops.primitive.d
Performs skip operation on a DoubleStream
SkipDoubleOperation(long) - Constructor for class org.infinispan.stream.impl.intops.primitive.d.SkipDoubleOperation
 
SkipIntOperation - Class in org.infinispan.stream.impl.intops.primitive.i
Performs skip operation on a IntStream
SkipIntOperation(long) - Constructor for class org.infinispan.stream.impl.intops.primitive.i.SkipIntOperation
 
skipL1Lookup(FlagAffectedCommand, Object) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
skipL1Lookup(FlagAffectedCommand, Object) - Method in class org.infinispan.interceptors.distribution.L1TxInterceptor
 
skipLoadForWriteCommand(WriteCommand, Object, InvocationContext) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
skipLoadForWriteCommand(WriteCommand, Object, InvocationContext) - Method in class org.infinispan.interceptors.impl.ClusteredCacheLoaderInterceptor
 
SkipLongOperation - Class in org.infinispan.stream.impl.intops.primitive.l
Performs skip operation on a LongStream
SkipLongOperation(long) - Constructor for class org.infinispan.stream.impl.intops.primitive.l.SkipLongOperation
 
skipLookup() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
skipLookup() - Method in interface org.infinispan.container.entries.CacheEntry
 
skipLookup() - Method in class org.infinispan.container.entries.ClearCacheEntry
 
skipLookup() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
skipLookup() - Method in class org.infinispan.container.entries.NullCacheEntry
 
skipLookup() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
skipLookup() - Method in class org.infinispan.container.entries.RepeatableReadEntry
 
SkipOperation<S> - Class in org.infinispan.stream.impl.intops.object
Performs skip operation on a regular Stream
SkipOperation(long) - Constructor for class org.infinispan.stream.impl.intops.object.SkipOperation
 
skipPassivationOnStop(boolean) - Method in class org.infinispan.eviction.impl.PassivationManagerImpl
 
skipPassivationOnStop(boolean) - Method in class org.infinispan.eviction.impl.PassivationManagerStub
 
skipPassivationOnStop(boolean) - Method in interface org.infinispan.eviction.PassivationManager
Skips the passivation when the cache is stopped.
skipReplicationQueue() - Method in class org.infinispan.remoting.rpc.RpcOptions
Deprecated.
Since 9.0, always returns false.
skipReplicationQueue(boolean) - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
Deprecated.
Since 9.0, it no longer does anything.
skipSharedStores(InvocationContext, Object, FlagAffectedCommand) - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
skipSharedStores(InvocationContext, Object, FlagAffectedCommand) - Method in class org.infinispan.interceptors.impl.DistCacheWriterInterceptor
 
skipSharedStores(InvocationContext, Object, FlagAffectedCommand) - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor
 
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
 
skipXSiteBackup(FlagAffectedCommand) - Method in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
 
snapshot(R) - Static method in class org.infinispan.functional.impl.EntryViews
For convenience, a lambda might decide to return the entry view it received as parameter, because that makes easy to return both value and meta parameters back to the client.
sort(List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
sorted() - Method in interface org.infinispan.CacheStream
sorted() - Method in interface org.infinispan.DoubleCacheStream
sorted() - Method in interface org.infinispan.IntCacheStream
sorted() - Method in interface org.infinispan.LongCacheStream
sorted() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
sorted() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
sorted() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
sorted() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
sorted() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
sorted() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
sorted() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
sorted() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
sorted() - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
sorted() - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
sorted() - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
sorted() - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
sorted() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
sorted(Comparator<? super R>) - Method in interface org.infinispan.CacheStream
sorted(Comparator<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
sorted(Comparator<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
sorted(Comparator<? super R>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
sorted(Comparator<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
sorted(SerializableComparator<? super R>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.sorted(Comparator) except that the Comparator must also implement Serializable
SortedComparatorOperation<S> - Class in org.infinispan.stream.impl.intops.object
Performs sorted operation with a comparator on a regular Stream
SortedComparatorOperation(Comparator<? super S>) - Constructor for class org.infinispan.stream.impl.intops.object.SortedComparatorOperation
 
SortedDoubleOperation - Class in org.infinispan.stream.impl.intops.primitive.d
Performs sorted operation on a DoubleStream
SortedIntOperation - Class in org.infinispan.stream.impl.intops.primitive.i
Performs sorted operation on a IntStream
SortedLongOperation - Class in org.infinispan.stream.impl.intops.primitive.l
Performs sorted operation on a LongStream
sortedMembers - Variable in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
SortedOperation<S> - Class in org.infinispan.stream.impl.intops.object
Performs sorted operation on a regular Stream
SourceMigrator - Interface in org.infinispan.upgrade
Performs migration operations on the source server or cluster of servers
SPIN_DURATION - org.infinispan.configuration.parsing.Attribute
Deprecated.
SPIN_DURATION - Static variable in class org.infinispan.configuration.cache.DeadlockDetectionConfiguration
Deprecated.
spinDuration() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfiguration
Deprecated.
Since 9.0, always returns -1.
spinDuration(long) - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
Deprecated.
Since 9.0, deadlock detection is always disabled.
spinDuration(long, TimeUnit) - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
Deprecated.
Since 9.0, deadlock detection is always disabled.
spliterator() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntrySet
 
spliterator() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySet
 
spliterator() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.KeySet
 
spliterator() - Method in interface org.infinispan.CacheStream
spliterator() - Method in class org.infinispan.commands.read.AbstractCloseableIteratorCollection
 
spliterator() - Method in interface org.infinispan.container.DataContainer
spliterator() - Method in class org.infinispan.container.impl.AbstractDelegatingDataContainer
 
spliterator() - Method in class org.infinispan.container.impl.AbstractInternalDataContainer.Values
Deprecated.
 
spliterator() - Method in class org.infinispan.container.impl.DefaultDataContainer
 
spliterator() - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
spliterator() - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
spliterator() - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingEntrySet
 
spliterator() - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingKeySet
 
spliterator() - Method in interface org.infinispan.LockedStream
This method is not supported when using a LockedStream
spliterator() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
spliterator() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
spliterator() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
spliterator() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
spliterator() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
spliterator() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
spliterator() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
spliterator() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
spliterator() - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
spliterator() - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
spliterator() - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
spliterator() - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
spliterator() - Method in class org.infinispan.stream.impl.local.ValueCacheCollection
 
spliterator() - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
spliterator() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
spliterator() - Method in class org.infinispan.util.AbstractDelegatingCloseableIteratorCollection
 
spliterator() - Method in class org.infinispan.util.AbstractDelegatingCloseableIteratorSet
 
spliterator() - Method in class org.infinispan.util.CacheCollectionMapper
Deprecated.
 
spliterator() - Method in class org.infinispan.util.CacheSetMapper
 
spliterator() - Method in class org.infinispan.util.CollectionMapper
 
spliterator() - Method in class org.infinispan.util.WriteableCacheCollectionMapper
 
spliterator(IntSet) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
spliterator(IntSet) - Method in class org.infinispan.container.impl.DefaultDataContainer
 
spliterator(IntSet) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
spliterator(IntSet) - Method in interface org.infinispan.container.impl.InternalDataContainer
Same as DataContainer.spliterator() except that only entries that map to the provided segments are returned via this spliterator.
spliterator(IntSet) - Method in class org.infinispan.container.impl.InternalDataContainerAdapter
 
spliterator(IntSet) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
spliteratorIncludingExpired() - Method in interface org.infinispan.container.DataContainer
Same as DataContainer.spliterator() except that is also returns expired entries.
spliteratorIncludingExpired() - Method in class org.infinispan.container.impl.AbstractDelegatingDataContainer
 
spliteratorIncludingExpired() - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
spliteratorIncludingExpired() - Method in class org.infinispan.container.impl.DefaultDataContainer
 
spliteratorIncludingExpired() - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
spliteratorIncludingExpired() - Method in class org.infinispan.container.impl.L1SegmentedDataContainer
 
spliteratorIncludingExpired() - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
spliteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
spliteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
spliteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.DefaultDataContainer
 
spliteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
spliteratorIncludingExpired(IntSet) - Method in interface org.infinispan.container.impl.InternalDataContainer
Same as DataContainer.spliteratorIncludingExpired() except that only entries that map to the provided segments are returned via this spliterator.
spliteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.InternalDataContainerAdapter
 
spliteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.L1SegmentedDataContainer
 
spliteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
STABLE_TOPOLOGY_UPDATE - org.infinispan.topology.CacheTopologyControlCommand.Type
 
STACK - org.infinispan.configuration.parsing.Attribute
 
STACK_FILE - org.infinispan.configuration.parsing.Element
 
StaggeredRequest<T> - Class in org.infinispan.remoting.transport.jgroups
 
staleEntriesWithoutFetchPersistentStateOrPurgeOnStartup() - Method in class org.infinispan.util.logging.Log_$logger
 
staleEntriesWithoutFetchPersistentStateOrPurgeOnStartup() - Method in interface org.infinispan.util.logging.Log
 
staleEntriesWithoutFetchPersistentStateOrPurgeOnStartup$str() - Method in class org.infinispan.util.logging.Log_$logger
 
start() - Method in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
 
start() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
start() - Method in class org.infinispan.cache.impl.CacheImpl
 
start() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
start() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
start() - Method in class org.infinispan.conflict.impl.DefaultConflictManager
 
start() - Method in class org.infinispan.conflict.impl.StateReceiverImpl
 
start() - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
start() - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
start() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
start() - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
start() - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
 
start() - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
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.TransactionalInvocationContextFactory
Deprecated.
 
start() - Method in class org.infinispan.distribution.group.impl.GroupManagerImpl
 
start() - Method in class org.infinispan.distribution.impl.L1ManagerImpl
 
start() - Method in class org.infinispan.eviction.impl.ActivationManagerImpl
 
start() - Method in class org.infinispan.eviction.impl.PassivationManagerImpl
 
start() - Method in class org.infinispan.expiration.impl.ClusterExpirationManager
 
start() - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
start() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
This starts the components in the registry, connecting to channels, starting service threads, etc.
start() - Method in class org.infinispan.factories.ComponentRegistry
 
start() - Method in class org.infinispan.globalstate.impl.GlobalConfigurationManagerImpl
 
start() - Method in class org.infinispan.globalstate.impl.GlobalStateManagerImpl
 
start() - Method in class org.infinispan.interceptors.base.BaseCustomInterceptor
Deprecated.
 
start() - Method in class org.infinispan.interceptors.BaseCustomAsyncInterceptor
 
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.TriangleDistributionInterceptor
 
start() - Method in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor
 
start() - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
start() - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
start() - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
start() - Method in class org.infinispan.interceptors.impl.DistCacheWriterInterceptor
 
start() - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
start() - Method in class org.infinispan.interceptors.impl.GroupingInterceptor
 
start() - Method in class org.infinispan.interceptors.impl.IsMarshallableInterceptor
 
start() - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
start() - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor
 
start() - Method in class org.infinispan.interceptors.impl.TransactionalExceptionEvictionInterceptor
 
start() - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
start() - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
start() - Method in class org.infinispan.interceptors.totalorder.TotalOrderDistributionInterceptor
 
start() - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedDistributionInterceptor
 
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 class org.infinispan.manager.DefaultCacheManager
 
start() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
start() - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
start() - Method in class org.infinispan.marshall.core.JBossMarshaller
 
start() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
start() - Method in class org.infinispan.notifications.cachelistener.cluster.impl.BatchingClusterEventManagerImpl
 
start() - Method in interface org.infinispan.notifications.cachelistener.filter.FilterIndexingServiceProvider
Start the provider.
start() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
 
start() - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
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.cluster.ClusterLoader
 
start() - Method in class org.infinispan.persistence.file.SingleFileStore
 
start() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
start() - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
start() - Method in class org.infinispan.persistence.manager.PreloadManager
 
start() - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
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
Deprecated.
 
start() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
 
start() - Method in class org.infinispan.remoting.inboundhandler.NonTotalOrderPerCacheInboundInvocationHandler
 
start() - Method in class org.infinispan.remoting.inboundhandler.NonTotalOrderTxPerCacheInboundInvocationHandler
 
start() - Method in class org.infinispan.remoting.inboundhandler.TrianglePerCacheInboundInvocationHandler
 
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.scattered.impl.BiasManagerImpl
 
start() - Method in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
start() - Method in class org.infinispan.scattered.impl.ScatteredStateProviderImpl
 
start() - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
start() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
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.stats.impl.ClusterCacheStatsImpl
 
start() - Method in class org.infinispan.stats.impl.StatsCollector
 
start() - Method in class org.infinispan.stream.impl.ClusterStreamManagerImpl
 
start() - Method in class org.infinispan.stream.impl.IteratorHandler
 
start() - Method in class org.infinispan.stream.impl.LocalStreamManagerImpl
 
start() - Method in class org.infinispan.stream.impl.PartitionAwareClusterStreamManager
 
start() - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
start() - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
start() - Method in class org.infinispan.transaction.impl.TransactionCoordinator
 
start() - Method in class org.infinispan.transaction.impl.TransactionTable
 
start() - Method in class org.infinispan.transaction.xa.TransactionFactory
 
start() - Method in class org.infinispan.util.concurrent.CommandAckCollector
 
start() - Method in class org.infinispan.xsite.BackupReceiverRepositoryImpl
 
start() - Method in class org.infinispan.xsite.BackupSenderImpl
 
start(Xid, int) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
start(Address, Supplier<Stream<Original>>, Iterable<IntermediateOperation>, Object) - Method in class org.infinispan.stream.impl.IteratorHandler
Starts an iteration process from the given stream that converts the stream to a subsequent stream using the given intermediate operations and then creates a managed iterator for the caller to subsequently retrieve.
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 component registry when the registry starts.
START - org.infinispan.configuration.parsing.Attribute
 
START_CONSISTENCY_CHECK - org.infinispan.statetransfer.StateRequestCommand.Type
 
START_KEYS_TRANSFER - org.infinispan.statetransfer.StateRequestCommand.Type
 
START_RECEIVE - org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand.StateTransferControl
 
START_SEND - org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand.StateTransferControl
 
START_STATE_TRANSFER - org.infinispan.statetransfer.StateRequestCommand.Type
 
startAllowed() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
startAtomic() - Method in class org.infinispan.batch.AutoBatchSupport
 
startBatch() - Method in class org.infinispan.batch.BatchContainer
Starts a batch
startBatch() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
startBatch() - Method in class org.infinispan.cache.impl.CacheImpl
 
startBatch() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
startBatch() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
startBatch(boolean) - Method in class org.infinispan.batch.BatchContainer
 
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.DefaultCacheManager
 
startCaches(String...) - Method in interface org.infinispan.manager.EmbeddedCacheManager
Starts a set of caches in parallel.
startCaches(String...) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
startDefaultExternalMarshaller(GlobalConfiguration) - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
startDelegate() - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
startFlush() - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
startingConflictResolution(String, CacheTopology) - Method in class org.infinispan.util.logging.Log_$logger
 
startingConflictResolution(String, CacheTopology) - Method in interface org.infinispan.util.logging.Log
 
startingConflictResolution$str() - Method in class org.infinispan.util.logging.Log_$logger
 
startingJGroupsChannel(String) - Method in class org.infinispan.util.logging.Log_$logger
 
startingJGroupsChannel(String) - Method in interface org.infinispan.util.logging.Log
 
startingJGroupsChannel$str() - Method in class org.infinispan.util.logging.Log_$logger
 
startingRebalancePhase(String, CacheTopology) - Method in class org.infinispan.util.logging.Log_$logger
 
startingRebalancePhase(String, CacheTopology) - Method in interface org.infinispan.util.logging.Log
 
startingRebalancePhase$str() - Method in class org.infinispan.util.logging.Log_$logger
 
startingUp() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
startIterator(Object, Address, IntSet, Set<K>, Set<K>, boolean, boolean, Iterable<IntermediateOperation>, long) - Method in interface org.infinispan.stream.impl.LocalStreamManager
Signals that a new iterator is created using the given arguments.
startIterator(Object, Address, IntSet, Set<K>, Set<K>, boolean, boolean, Iterable<IntermediateOperation>, long) - Method in class org.infinispan.stream.impl.LocalStreamManagerImpl
 
startKeysTransfer(IntSet, Address) - Method in class org.infinispan.scattered.impl.ScatteredStateProviderImpl
 
startKeysTransfer(IntSet, Address) - Method in interface org.infinispan.scattered.ScatteredStateProvider
 
startKeyTransfer(IntSet) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
startKeyTransfer(IntSet) - Method in interface org.infinispan.scattered.ScatteredVersionManager
startObjectInput(InputStream, boolean) - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
startObjectOutput(OutputStream, boolean, int) - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
startOutboundTransfer(Address, int, IntSet, boolean) - Method in interface org.infinispan.statetransfer.StateProvider
Start to send cache entries that belong to the given set of segments.
startOutboundTransfer(Address, int, IntSet, boolean) - Method in class org.infinispan.statetransfer.StateProviderImpl
 
startPushState(String) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
It notifies all nodes from local site to start transfer the state to the remote site.
startPushState(String) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
startQueuedRebalance() - Method in class org.infinispan.topology.ClusterCacheStatus
 
startRevokingRemoteBias(Object, Address) - Method in interface org.infinispan.scattered.BiasManager
Check if there are any nodes that have local bias, and starting replacing them with the provided address.
startRevokingRemoteBias(Object, Address) - Method in class org.infinispan.scattered.impl.BiasManagerImpl
 
startStateTransfer(String) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateConsumer
It notifies the start of state transfer from other site.
startStateTransfer(String) - Method in class org.infinispan.xsite.statetransfer.XSiteStateConsumerImpl
 
startStateTransfer(String, Address, int) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateProvider
It notifies this node to start sending state to the remote site.
startStateTransfer(String, Address, int) - Method in class org.infinispan.xsite.statetransfer.XSiteStateProviderImpl
 
startTrack(Flag) - Method in class org.infinispan.statetransfer.CommitManager
It starts tracking keys committed.
startXidMapping() - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
state - Variable in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
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(boolean, ConcurrentMap<Object, Modification>, State) - Constructor for class org.infinispan.persistence.async.State
 
STATE_CAPACITY_FACTOR - Static variable in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
STATE_CAPACITY_FACTORS - Static variable in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
STATE_CONSISTENT_HASH - Static variable in class org.infinispan.distribution.ch.impl.ConsistentHashPersistenceConstants
 
STATE_HASH_FUNCTION - Static variable in class org.infinispan.distribution.ch.impl.ConsistentHashPersistenceConstants
 
STATE_MEMBER - Static variable in class org.infinispan.distribution.ch.impl.ConsistentHashPersistenceConstants
 
STATE_MEMBERS - Static variable in class org.infinispan.distribution.ch.impl.ConsistentHashPersistenceConstants
 
STATE_NUM_SEGMENTS - Static variable in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
STATE_TRANSFER - org.infinispan.configuration.parsing.Element
 
STATE_TRANSFER_EXECUTOR - org.infinispan.configuration.parsing.Attribute
 
STATE_TRANSFER_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
STATE_TRANSFER_FLAGS - Static variable in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
STATE_TRANSFER_FLAGS - Static variable in class org.infinispan.statetransfer.StateConsumerImpl
 
StateChangingEntry - Interface in org.infinispan.container.entries
Deprecated.
since 9.0
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
 
StateReceiver<K,​V> - Interface in org.infinispan.conflict.impl
 
StateReceiverImpl<K,​V> - Class in org.infinispan.conflict.impl
 
StateReceiverImpl() - Constructor for class org.infinispan.conflict.impl.StateReceiverImpl
 
StateRequestCommand - Class in org.infinispan.statetransfer
This command is used by a StateConsumer to request transactions and cache entries from a StateProvider.
StateRequestCommand(ByteString) - Constructor for class org.infinispan.statetransfer.StateRequestCommand
 
StateRequestCommand(ByteString, StateRequestCommand.Type, Address, int, IntSet) - Constructor for class org.infinispan.statetransfer.StateRequestCommand
 
StateRequestCommand.Type - Enum in org.infinispan.statetransfer
 
stateRequestExecutor - Variable in class org.infinispan.statetransfer.StateConsumerImpl
Push RPCs on a background thread
StateResponseCommand - Class in org.infinispan.statetransfer
This command is used by a StateProvider to push cache entries to a StateConsumer.
StateResponseCommand(ByteString) - Constructor for class org.infinispan.statetransfer.StateResponseCommand
 
StateResponseCommand(ByteString, Address, int, Collection<StateChunk>, boolean, boolean) - Constructor for class org.infinispan.statetransfer.StateResponseCommand
 
stateTransfer() - Method in class org.infinispan.configuration.cache.BackupConfiguration
 
stateTransfer() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
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.
stateTransferExecutor - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
stateTransferFuture - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
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, retry the command, but only on the originator (which replicates it to the new owners). If the cache is configured with asynchronous replication, owners cannot signal to the originator that they saw a new topology, so instead each owner forwards the command to all the other owners in the new topology.
StateTransferInterceptor() - Constructor for class org.infinispan.statetransfer.StateTransferInterceptor
 
stateTransferLock - Variable in class org.infinispan.commands.write.InvalidateVersionsCommand
 
stateTransferLock - Variable in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
stateTransferLock - Variable in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor
 
stateTransferLock - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
stateTransferLock - Variable in class org.infinispan.statetransfer.StateProviderImpl
 
stateTransferLock - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
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 - 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
 
stateTransferThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
stateTransferThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
stateTransferThreadPool() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
Configuration for the state-transfer thread pool
stateTransferTopologyId - Variable in class org.infinispan.statetransfer.StateConsumerImpl
Indicates if there is a state transfer in progress.
STATISTICS - org.infinispan.configuration.parsing.Attribute
 
STATISTICS_AVAILABLE - org.infinispan.configuration.parsing.Attribute
 
statisticsEnabledNotAvailable() - Method in class org.infinispan.util.logging.Log_$logger
 
statisticsEnabledNotAvailable() - Method in interface org.infinispan.util.logging.Log
 
statisticsEnabledNotAvailable$str() - Method in class org.infinispan.util.logging.Log_$logger
 
stats - Variable in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Builder
 
Stats - Interface in org.infinispan.stats
Stats.
STATS_MODE_ID - Static variable in class org.infinispan.functional.ParamIds
 
StatsCollectingCache<K,​V> - Class in org.infinispan.cache.impl
Wraps existing AdvancedCache to collect statistics
StatsCollectingCache(String) - Constructor for class org.infinispan.cache.impl.StatsCollectingCache
 
StatsCollectingCache(String, DataConversion, DataConversion) - Constructor for class org.infinispan.cache.impl.StatsCollectingCache
 
StatsCollector - Class in org.infinispan.stats.impl
 
StatsCollector() - Constructor for class org.infinispan.stats.impl.StatsCollector
 
StatsCollector.Factory - Class in org.infinispan.stats.impl
 
StatsEnvelope<T> - Class in org.infinispan.functional.impl
Responses for functional commands that allow to record statistics.
StatsEnvelope.Externalizer - Class in org.infinispan.functional.impl
 
StatsImpl - Class in org.infinispan.stats.impl
StatsImpl.
StatsImpl(AsyncInterceptorChain) - Constructor for class org.infinispan.stats.impl.StatsImpl
 
StatsImpl(Stats) - Constructor for class org.infinispan.stats.impl.StatsImpl
 
status() - Method in interface org.infinispan.xsite.BackupSender
Returns a Map having as entries the site names and as value Boolean.TRUE if the site is online and Boolean.FALSE if it is offline.
status() - Method in class org.infinispan.xsite.BackupSenderImpl
 
status() - Method in class org.infinispan.xsite.XSiteAdminOperations
 
STATUS - org.infinispan.xsite.XSiteAdminCommand.AdminOperation
 
STATUS_CANCELED - Static variable in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
 
STATUS_ERROR - Static variable in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
 
STATUS_OK - Static variable in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
 
STATUS_REQUEST - org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand.StateTransferControl
 
STATUS_SENDING - Static variable in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
 
stop() - Method in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
 
stop() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
stop() - Method in class org.infinispan.cache.impl.CacheImpl
 
stop() - Method in class org.infinispan.cache.impl.DecoratedCache
 
stop() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
stop() - Method in interface org.infinispan.Cache
Stops a cache.
stop() - Method in class org.infinispan.conflict.impl.DefaultConflictManager
 
stop() - Method in class org.infinispan.conflict.impl.StateReceiverImpl
 
stop() - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
stop() - Method in class org.infinispan.container.impl.L1SegmentedDataContainer
 
stop() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
stop() - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
stop() - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
stop() - Method in class org.infinispan.distribution.impl.L1ManagerImpl
 
stop() - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
stop() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
Stops the component and sets its status to ComponentStatus.TERMINATED once it is done.
stop() - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
 
stop() - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
 
stop() - Method in class org.infinispan.factories.NamedExecutorsFactory
 
stop() - Method in class org.infinispan.globalstate.impl.GlobalStateManagerImpl
 
stop() - Method in class org.infinispan.interceptors.base.BaseCustomInterceptor
Deprecated.
 
stop() - Method in class org.infinispan.interceptors.BaseCustomAsyncInterceptor
 
stop() - Method in class org.infinispan.interceptors.impl.TransactionalExceptionEvictionInterceptor
 
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 class org.infinispan.manager.DefaultCacheManager
 
stop() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
stop() - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
stop() - Method in class org.infinispan.marshall.core.JBossMarshaller
 
stop() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
stop() - Method in interface org.infinispan.notifications.cachelistener.filter.FilterIndexingServiceProvider
Stop the provider.
stop() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
Removes all listeners from the notifier
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.cluster.ClusterLoader
 
stop() - Method in class org.infinispan.persistence.file.SingleFileStore
 
stop() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
stop() - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
stop() - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader.TaskContext
Deprecated.
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.ComposedSegmentedLoadWriteStore
 
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
Deprecated.
 
stop() - Method in class org.infinispan.persistence.TaskContextImpl
 
stop() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
 
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 class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
stop() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
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 class org.infinispan.statetransfer.StateTransferLockImpl
 
stop() - Method in interface org.infinispan.statetransfer.StateTransferManager
 
stop() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
stop() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
stop() - Method in class org.infinispan.stream.impl.IteratorHandler
 
stop() - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
stop() - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
stop() - Method in class org.infinispan.xsite.BackupReceiverRepositoryImpl
 
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 component registry when the registry stops.
STOP_TIMEOUT - org.infinispan.configuration.parsing.Attribute
 
stopAllowed() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
stopApplyingState(int) - Method in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
stopApplyingState(int) - Method in interface org.infinispan.statetransfer.StateConsumer
Stops applying incoming state.
stopApplyingState(int) - Method in class org.infinispan.statetransfer.StateConsumerImpl
Stops applying incoming state.
stopDefaultExternalMarshaller() - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
stopDelegate() - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
 
stopOrderIgnored() - Method in class org.infinispan.util.logging.Log_$logger
 
stopOrderIgnored() - Method in interface org.infinispan.util.logging.Log
 
stopOrderIgnored$str() - Method in class org.infinispan.util.logging.Log_$logger
 
STOPPING - org.infinispan.lifecycle.ComponentStatus
The stop() method has been called but has not yet completed.
STOPPING - org.infinispan.topology.ClusterTopologyManager.ClusterManagerStatus
 
stopTrack(Flag) - Method in class org.infinispan.statetransfer.CommitManager
It stops tracking keys committed.
STORAGE_TYPE - Static variable in class org.infinispan.configuration.cache.MemoryConfiguration
 
storageType() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
Storage type to use for the data container
storageType() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
The underlying storage type for this configuration
storageType(StorageType) - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
Set the StorageType to determine how the data is stored in the data container.
StorageType - Enum in org.infinispan.configuration.cache
Enumeration defining the various storage types for the data container.
store(TxInvocationContext) - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
Store - Class in org.infinispan.persistence.modifications
Store(Object, MarshalledEntry) - Constructor for class org.infinispan.persistence.modifications.Store
 
STORE - org.infinispan.configuration.parsing.Element
 
STORE - org.infinispan.persistence.modifications.Modification.Type
 
STORE_AS_BINARY - org.infinispan.configuration.parsing.Element
 
STORE_KEYS_AS_BINARY - org.infinispan.configuration.parsing.Attribute
 
STORE_KEYS_AS_BINARY - Static variable in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
Deprecated.
 
STORE_VALUES_AS_BINARY - org.infinispan.configuration.parsing.Attribute
 
STORE_VALUES_AS_BINARY - Static variable in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
Deprecated.
 
storeAsBinary() - Method in class org.infinispan.configuration.cache.Configuration
Deprecated.
storeAsBinary() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
Deprecated.
storeAsBinary() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
StoreAsBinaryConfiguration - Class in org.infinispan.configuration.cache
Deprecated.
StoreAsBinaryConfigurationBuilder - Class in org.infinispan.configuration.cache
Deprecated.
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
 
storeKeysAsBinary() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
Deprecated.
when store as binary is enabled, keys are always stored as binary
storeKeysAsBinary(boolean) - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
Deprecated.
No longer supported, keys and values are both enabled if store as binary is
storeNotSegmented(Class<?>) - Method in class org.infinispan.util.logging.Log_$logger
 
storeNotSegmented(Class<?>) - Method in interface org.infinispan.util.logging.Log
 
storeNotSegmented$str() - Method in class org.infinispan.util.logging.Log_$logger
 
stores() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
 
stores() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
storeStartupAttemptsExceeded(String, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
storeStartupAttemptsExceeded(String, Throwable) - Method in interface org.infinispan.util.logging.Log
 
storeStartupAttemptsExceeded$str() - Method in class org.infinispan.util.logging.Log_$logger
 
StoreUnavailableException - Exception in org.infinispan.persistence.spi
An exception thrown by the PersistenceManager if one or more stores are unavailable when a cache operation is attempted.
StoreUnavailableException() - Constructor for exception org.infinispan.persistence.spi.StoreUnavailableException
 
StoreUnavailableException(String) - Constructor for exception org.infinispan.persistence.spi.StoreUnavailableException
 
StoreUnavailableException(String, Throwable) - Constructor for exception org.infinispan.persistence.spi.StoreUnavailableException
 
StoreUnavailableException(Throwable) - Constructor for exception org.infinispan.persistence.spi.StoreUnavailableException
 
storeValuesAsBinary() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
Deprecated.
when store as binary is enabled, values are always stored as binary
storeValuesAsBinary(boolean) - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
Deprecated.
No longer supported, keys and values are both enabled if store as binary is
strategy() - Method in class org.infinispan.configuration.cache.BackupConfiguration
How does the backup happen: sync or async.
strategy() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
strategy() - Method in class org.infinispan.configuration.cache.EvictionConfiguration
Deprecated.
strategy(BackupConfiguration.BackupStrategy) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
Sets the strategy used for backing up data: sync or async.
strategy(EvictionStrategy) - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
Deprecated.
Eviction strategy.
STRATEGY - org.infinispan.configuration.parsing.Attribute
 
STRATEGY - Static variable in class org.infinispan.configuration.cache.BackupConfiguration
 
STRATEGY - Static variable in class org.infinispan.configuration.cache.EvictionConfiguration
Deprecated.
 
stream() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntrySet
 
stream() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySet
 
stream() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.KeySet
 
stream() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.Values
 
stream() - Method in interface org.infinispan.CacheCollection
 
stream() - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingEntrySet
 
stream() - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingKeySet
 
stream() - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.TxBackingEntrySet
 
stream() - Method in class org.infinispan.stream.impl.interceptor.AbstractDelegatingEntryCacheSet
 
stream() - Method in class org.infinispan.stream.impl.interceptor.AbstractDelegatingKeyCacheSet
 
stream() - Method in class org.infinispan.stream.impl.local.ValueCacheCollection
 
stream() - Method in class org.infinispan.util.AbstractDelegatingCacheCollection
 
stream() - Method in class org.infinispan.util.CacheCollectionMapper
Deprecated.
 
stream() - Method in class org.infinispan.util.CacheSetMapper
 
stream() - Method in class org.infinispan.util.CollectionMapper
 
stream() - Method in class org.infinispan.util.WriteableCacheCollectionMapper
 
StreamIteratorCloseCommand - Class in org.infinispan.stream.impl
Stream iterator command that unregisters an iterator so it doesn't consume memory unnecessarily
StreamIteratorCloseCommand(ByteString) - Constructor for class org.infinispan.stream.impl.StreamIteratorCloseCommand
 
StreamIteratorCloseCommand(ByteString, Address, Object) - Constructor for class org.infinispan.stream.impl.StreamIteratorCloseCommand
 
StreamIteratorNextCommand - Class in org.infinispan.stream.impl
Stream request command that is sent to remote nodes handle execution of remote intermediate and terminal operations.
StreamIteratorNextCommand(ByteString) - Constructor for class org.infinispan.stream.impl.StreamIteratorNextCommand
 
StreamIteratorNextCommand(ByteString, Object, long) - Constructor for class org.infinispan.stream.impl.StreamIteratorNextCommand
 
StreamIteratorRequestCommand<K> - Class in org.infinispan.stream.impl
Stream request command that is sent to remote nodes handle execution of remote intermediate and terminal operations.
StreamIteratorRequestCommand(ByteString) - Constructor for class org.infinispan.stream.impl.StreamIteratorRequestCommand
 
StreamIteratorRequestCommand(ByteString, Address, Object, boolean, IntSet, Set<K>, Set<K>, boolean, boolean, Iterable<IntermediateOperation>, long) - Constructor for class org.infinispan.stream.impl.StreamIteratorRequestCommand
 
StreamManagerFactory - Class in org.infinispan.factories
Factory that allows creation of a LocalStreamManager or ClusterStreamManager based on the provided configuration.
StreamManagerFactory() - Constructor for class org.infinispan.factories.StreamManagerFactory
 
StreamMarshalling - Class in org.infinispan.stream
Static factory class containing methods that will provide marshallable instances for very common use cases.
StreamMarshalling.StreamMarshallingExternalizer - Class in org.infinispan.stream
 
StreamMarshallingExternalizer() - Constructor for class org.infinispan.stream.StreamMarshalling.StreamMarshallingExternalizer
 
streamOperation(Object, Address, boolean, IntSet, Set<K>, Set<K>, boolean, boolean, KeyTrackingTerminalOperation<Original, K, R>) - Method in interface org.infinispan.stream.impl.LocalStreamManager
Stream operation for a key aware operation without rehash enabled
streamOperation(Object, Address, boolean, IntSet, Set<K>, Set<K>, boolean, boolean, KeyTrackingTerminalOperation<Original, K, R>) - Method in class org.infinispan.stream.impl.LocalStreamManagerImpl
 
streamOperation(Object, Address, boolean, IntSet, Set<K>, Set<K>, boolean, boolean, TerminalOperation<Original, R>) - Method in interface org.infinispan.stream.impl.LocalStreamManager
Stream operation for a non key aware operation without rehash enabled.
streamOperation(Object, Address, boolean, IntSet, Set<K>, Set<K>, boolean, boolean, TerminalOperation<Original, R>) - Method in class org.infinispan.stream.impl.LocalStreamManagerImpl
 
streamOperationRehashAware(Object, Address, boolean, IntSet, Set<K>, Set<K>, boolean, boolean, KeyTrackingTerminalOperation<Original, K, ?>) - Method in interface org.infinispan.stream.impl.LocalStreamManager
Stream operation for a key aware operation with rehash enabled
streamOperationRehashAware(Object, Address, boolean, IntSet, Set<K>, Set<K>, boolean, boolean, KeyTrackingTerminalOperation<Original, K, ?>) - Method in class org.infinispan.stream.impl.LocalStreamManagerImpl
 
streamOperationRehashAware(Object, Address, boolean, IntSet, Set<K>, Set<K>, boolean, boolean, TerminalOperation<Original, R>) - Method in interface org.infinispan.stream.impl.LocalStreamManager
Stream operation for a non key aware operation with rehash enabled.
streamOperationRehashAware(Object, Address, boolean, IntSet, Set<K>, Set<K>, boolean, boolean, TerminalOperation<Original, R>) - Method in class org.infinispan.stream.impl.LocalStreamManagerImpl
 
StreamRequestCommand<K> - Class in org.infinispan.stream.impl
Stream request command that is sent to remote nodes handle execution of remote intermediate and terminal operations.
StreamRequestCommand(ByteString) - Constructor for class org.infinispan.stream.impl.StreamRequestCommand
 
StreamRequestCommand(ByteString, Address, Object, boolean, StreamRequestCommand.Type, IntSet, Set<K>, Set<K>, boolean, boolean, Object) - Constructor for class org.infinispan.stream.impl.StreamRequestCommand
 
StreamRequestCommand.Type - Enum in org.infinispan.stream.impl
 
StreamResponseCommand<R> - Class in org.infinispan.stream.impl
Stream response command used to handle returning intermediate or final responses from the remote node
StreamResponseCommand() - Constructor for class org.infinispan.stream.impl.StreamResponseCommand
 
StreamResponseCommand(ByteString) - Constructor for class org.infinispan.stream.impl.StreamResponseCommand
 
StreamResponseCommand(ByteString, Address, Object, boolean, IntSet, R) - Constructor for class org.infinispan.stream.impl.StreamResponseCommand
 
StreamResponseCommand(ByteString, Address, Object, boolean, R) - Constructor for class org.infinispan.stream.impl.StreamResponseCommand
 
Streams - Class in org.infinispan.util.stream
A collection of stream related utility methods.
Streams() - Constructor for class org.infinispan.util.stream.Streams
 
streamSupplier - Variable in class org.infinispan.stream.impl.local.AbstractLocalCacheStream
 
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.util.logging.Log_$logger
 
strictPeerToPeerDeprecated() - Method in interface org.infinispan.util.logging.Log
 
strictPeerToPeerDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
stringToElement(String) - Static method in class org.infinispan.configuration.parsing.XmlConfigHelper
Converts a String representing an XML snippet into an Element.
StripedHashFunction<T> - Class in org.infinispan.util
An hash function for stripping.
StripedHashFunction(int) - Constructor for class org.infinispan.util.StripedHashFunction
 
StripedLock - Class in org.infinispan.container.offheap
Holder for read write locks that provides ability to retrieve them by offset and hashCode Note that locks protect entries
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(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.
StripedLock(int, OffsetCalculator) - Constructor for class org.infinispan.container.offheap.StripedLock
 
StripedLockContainer - Class in org.infinispan.util.concurrent.locks.impl
A lock container used with lock stripping.
StripedLockContainer(int) - Constructor for class org.infinispan.util.concurrent.locks.impl.StripedLockContainer
 
STRIPING - org.infinispan.configuration.parsing.Attribute
 
subject - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
subject - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl.ListenerInvocationImpl
 
SubjectACL - Class in org.infinispan.security.impl
SubjectACL.
SubjectACL(Set<String>, int) - Constructor for class org.infinispan.security.impl.SubjectACL
 
submit(Runnable) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
submit(Runnable) - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
submit(Runnable) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
submit(Runnable) - Method in interface org.infinispan.manager.ClusterExecutor
Submits the runnable to the desired nodes and returns a CompletableFuture that will be completed when all desired nodes complete the given command
submit(Runnable, Void) - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
submit(Runnable, T) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
submit(Runnable, T) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
submit(Runnable, T) - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
submit(Runnable, T) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
submit(Runnable, T) - Method in class org.infinispan.executors.SemaphoreCompletionService
 
submit(Runnable, V) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
{@inheritDoc CompletionService}
submit(Callable<Void>) - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
submit(Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
submit(Callable<T>) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
submit(Callable<T>) - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
submit(Callable<T>) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
submit(Callable<T>) - Method in class org.infinispan.executors.SemaphoreCompletionService
 
submit(Callable<T>, K...) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
submit(Callable<T>, K...) - Method in interface org.infinispan.distexec.DistributedExecutorService
Deprecated.
Submits the given Callable task for execution on a single Infinispan node.
submit(Callable<V>) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
{@inheritDoc CompletionService}
submit(Callable<V>, K...) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
 
submit(DistributedTask<T>, K...) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
submit(DistributedTask<T>, K...) - Method in interface org.infinispan.distexec.DistributedExecutorService
Deprecated.
Submits the given DistributedTask for execution on a single Infinispan node.
submit(Address, Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
submit(Address, Callable<T>) - Method in interface org.infinispan.distexec.DistributedExecutorService
Deprecated.
Submits the given Callable task for execution on the specified target Infinispan node.
submit(Address, Callable<V>) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
 
submit(Address, DistributedTask<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
submit(Address, DistributedTask<T>) - Method in interface org.infinispan.distexec.DistributedExecutorService
Deprecated.
Submits the given DistributedTask for execution on the specified target Infinispan node.
submit(SerializableRunnable) - Method in interface org.infinispan.manager.ClusterExecutor
The same as ClusterExecutor.submit(Runnable), except the Runnable must also implement Serializable.
submitConsumer(Function<? super EmbeddedCacheManager, ? extends V>, TriConsumer<? super Address, ? super V, ? super Throwable>) - Method in interface org.infinispan.manager.ClusterExecutor
Submits the given command to the desired nodes and allows for handling of results as they return.
submitConsumer(SerializableFunction<? super EmbeddedCacheManager, ? extends V>, TriConsumer<? super Address, ? super V, ? super Throwable>) - Method in interface org.infinispan.manager.ClusterExecutor
The same as ClusterExecutor.submitConsumer(Function, TriConsumer), except the Callable must also implement Serializable.
submitEverywhere(Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
submitEverywhere(Callable<T>) - Method in interface org.infinispan.distexec.DistributedExecutorService
Deprecated.
Submits the given Callable task for execution on all available Infinispan nodes.
submitEverywhere(Callable<T>, K...) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
submitEverywhere(Callable<T>, K...) - Method in interface org.infinispan.distexec.DistributedExecutorService
Deprecated.
Submits the given Callable task for execution on all available Infinispan nodes using input keys specified by K input.
submitEverywhere(Callable<V>) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
 
submitEverywhere(Callable<V>, K...) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
 
submitEverywhere(DistributedTask<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
submitEverywhere(DistributedTask<T>) - Method in interface org.infinispan.distexec.DistributedExecutorService
Deprecated.
Submits the given DistributedTask for execution on all available Infinispan nodes.
submitEverywhere(DistributedTask<T>, K...) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
submitEverywhere(DistributedTask<T>, K...) - Method in interface org.infinispan.distexec.DistributedExecutorService
Deprecated.
Submits the given DistributedTask for execution on all available Infinispan nodes using input keys specified by K input.
subscribe(Subscriber<? super K>) - Method in interface org.infinispan.stream.impl.ClusterStreamManager.RemoteIteratorPublisher
 
subscribe(Subscriber<? super K>, Consumer<? super Supplier<PrimitiveIterator.OfInt>>, Consumer<? super Supplier<PrimitiveIterator.OfInt>>) - Method in interface org.infinispan.stream.impl.ClusterStreamManager.RemoteIteratorPublisher
Essentially the same as Publisher.subscribe(Subscriber) except that a Consumer is provided that will be invoked when a segment for a given request has been lost.
subscribe(Subscriber<? super T>, PrimitiveIterator.OfInt, IntFunction<T>) - Static method in class org.infinispan.util.rxjava.FlowableFromIntSetFunction
 
subscribeActual(Subscriber<? super T>) - Method in class org.infinispan.util.rxjava.FlowableFromIntSetFunction
 
SUCCESS - Static variable in class org.infinispan.xsite.XSiteAdminOperations
 
successful - Variable in class org.infinispan.commands.write.RemoveCommand
 
SUCCESSFUL_EMPTY_RESPONSE - Static variable in class org.infinispan.remoting.responses.SuccessfulResponse
 
SuccessfulResponse - Class in org.infinispan.remoting.responses
A successful response
SuccessfulResponse(Object) - Constructor for class org.infinispan.remoting.responses.SuccessfulResponse
 
SuccessfulResponse.Externalizer - Class in org.infinispan.remoting.responses
 
suggestCustomInterceptorInheritance(String) - Method in class org.infinispan.util.logging.Log_$logger
 
suggestCustomInterceptorInheritance(String) - Method in interface org.infinispan.util.logging.Log
 
suggestCustomInterceptorInheritance$str() - Method in class org.infinispan.util.logging.Log_$logger
 
sum() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
sum() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
sum() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
sum() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
sum() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
sum() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
sum() - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
sum() - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
sum() - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
SUMMARY - org.infinispan.jmx.annotations.DisplayType
 
summaryStatistics() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
summaryStatistics() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
summaryStatistics() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
summaryStatistics() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
summaryStatistics() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
summaryStatistics() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
summaryStatistics() - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
summaryStatistics() - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
summaryStatistics() - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
sumOwned() - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
 
sumPrimaryOwned() - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
 
supplier - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
supplier - Variable in class org.infinispan.stream.impl.termop.BaseTerminalOperation
 
supplierForSegments(ConsistentHash, IntSet, Set<Object>) - Method in class org.infinispan.stream.impl.AbstractCacheStream
 
supplierForSegments(ConsistentHash, IntSet, Set<Object>, boolean) - Method in class org.infinispan.stream.impl.AbstractCacheStream
If usePrimary is true the segments are the primary segments but only those that exist in targetSegments.
supplierForSegments(ConsistentHash, IntSet, Set<Object>, boolean) - Method in class org.infinispan.stream.impl.tx.TxDistributedCacheStream
 
supplierForSegments(ConsistentHash, IntSet, Set<Object>, boolean) - Method in class org.infinispan.stream.impl.tx.TxDistributedDoubleCacheStream
 
supplierForSegments(ConsistentHash, IntSet, Set<Object>, boolean) - Method in class org.infinispan.stream.impl.tx.TxDistributedIntCacheStream
 
supplierForSegments(ConsistentHash, IntSet, Set<Object>, boolean) - Method in class org.infinispan.stream.impl.tx.TxDistributedLongCacheStream
 
supplierStreamCast(Supplier) - Static method in class org.infinispan.stream.impl.DistributedCacheStream
 
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. 
supportsFilter(IndexedFilter<?, ?, ?>) - Method in interface org.infinispan.notifications.cachelistener.filter.FilterIndexingServiceProvider
Reports whether this provider supports the given filter type.
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.
SuspectException - Exception in org.infinispan.remoting.transport.jgroups
Thrown when a member is suspected during remote method invocation
SuspectException() - Constructor for exception org.infinispan.remoting.transport.jgroups.SuspectException
 
SuspectException(String) - Constructor for exception org.infinispan.remoting.transport.jgroups.SuspectException
 
SuspectException(String, Throwable) - Constructor for exception org.infinispan.remoting.transport.jgroups.SuspectException
 
SuspectException(String, Address) - 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
Deprecated.
Suspend the association the calling thread has to a transaction, and return the suspended transaction.
SUSPENDED - org.infinispan.topology.RebalancingStatus
 
suspendIfNeeded() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
suspendIfNeeded() - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
suspendIfNeeded() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
 
svm - Variable in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
svm - Variable in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
svm - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
svm - Variable in class org.infinispan.scattered.impl.ScatteredStateProviderImpl
 
swapPrimaryOwnersWithBackups(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
 
sync - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
sync - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
sync - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl.ListenerInvocationImpl
 
sync - Variable in class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
 
sync() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
Deprecated.
Since 9.0, the replTimeout attribute is now in ClusteringConfiguration.
sync() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
sync() - Method in interface org.infinispan.configuration.cache.ClusteringConfigurationChildBuilder
Deprecated.
Since 9.0, the replTimeout attribute is now in ClusteringConfigurationBuilder.
sync() - Method in annotation type org.infinispan.notifications.Listener
Specifies whether callbacks on any class annotated with this annotation happens synchronously (in the caller's thread) or asynchronously (using a separate thread).
SYNC - org.infinispan.configuration.cache.BackupConfiguration.BackupStrategy
 
SYNC - org.infinispan.configuration.parsing.Element
 
SYNC - org.infinispan.configuration.parsing.Parser.Mode
 
SYNC - org.infinispan.functional.Param.ReplicationMode
Command is completed when all owners are updated.
syncCommitPhase() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
Deprecated.
since 9.0. no longer supported
syncCommitPhase(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfiguration
Deprecated.
The syncRollbackPhase setting can no longer be modified at runtime. It must be the same on all nodes.
syncCommitPhase(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
Deprecated.
since 9.0. no longer supported
SyncConfiguration - Class in org.infinispan.configuration.cache
Deprecated.
Since 9.0, the replTimeout attribute is now ClusteringConfiguration.remoteTimeout.
SyncConfigurationBuilder - Class in org.infinispan.configuration.cache
Deprecated.
Since 9.0, the replTimeout attribute is now ClusteringConfigurationBuilder.remoteTimeout.
SyncConfigurationBuilder(ClusteringConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.SyncConfigurationBuilder
Deprecated.
 
SyncConsistentHashFactory - Class in org.infinispan.distribution.ch.impl
One of the assumptions people made on consistent hashing involves thinking that given a particular key and same topology, it would produce the same consistent hash value no matter which cache it was stored in.
SyncConsistentHashFactory() - Constructor for class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory
 
SyncConsistentHashFactory.Builder - Class in org.infinispan.distribution.ch.impl
 
SyncConsistentHashFactory.Externalizer - Class in org.infinispan.distribution.ch.impl
 
SynchronizationAdapter - Class in org.infinispan.transaction.synchronization
Synchronization implementation for integrating with the TM.
SynchronizationAdapter(LocalTransaction, TransactionTable) - Constructor for class org.infinispan.transaction.synchronization.SynchronizationAdapter
 
synchronizeData(String) - Method in class org.infinispan.upgrade.RollingUpgradeManager
 
synchronizeData(String, int, int) - 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
synchronizeData(Cache<Object, Object>, int, int) - Method in interface org.infinispan.upgrade.TargetMigrator
Performs the synchronization of data between source and target
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
 
SYNCHRONOUS - org.infinispan.remoting.rpc.ResponseMode
 
SYNCHRONOUS_IGNORE_LEAVERS - org.infinispan.remoting.rpc.ResponseMode
Most commands should use this mode to prevent SuspectExceptions when we are doing a broadcast (or anycast that translates to JGroups broadcast).
SyncInvocationStage - Class in org.infinispan.interceptors
 
SyncInvocationStage() - Constructor for class org.infinispan.interceptors.SyncInvocationStage
 
SyncInvocationStage(Object) - Constructor for class org.infinispan.interceptors.SyncInvocationStage
 
SyncLocalTransaction - Class in org.infinispan.transaction.synchronization
LocalTransaction implementation to be used with SynchronizationAdapter.
SyncLocalTransaction(Transaction, GlobalTransaction, boolean, int, long) - Constructor for class org.infinispan.transaction.synchronization.SyncLocalTransaction
 
syncProcessor - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl
 
syncPropertiesConfigOnAsyncCache() - Method in class org.infinispan.util.logging.Log_$logger
 
syncPropertiesConfigOnAsyncCache() - Method in interface org.infinispan.util.logging.Log
 
syncPropertiesConfigOnAsyncCache$str() - Method in class org.infinispan.util.logging.Log_$logger
 
SyncReplicatedConsistentHashFactory - Class in org.infinispan.distribution.ch.impl
SyncConsistentHashFactory adapted for replicated caches, so that the primary owner of a key is the same in replicated and distributed caches.
SyncReplicatedConsistentHashFactory() - Constructor for class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory
 
SyncReplicatedConsistentHashFactory.Externalizer - Class in org.infinispan.distribution.ch.impl
 
syncRollbackPhase() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
Deprecated.
since 9.0. no longer supported
syncRollbackPhase(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfiguration
Deprecated.
The syncRollbackPhase setting can no longer be modified at runtime. It must be the same on all nodes.
syncRollbackPhase(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
Deprecated.
since 9.0. no longer supported

T

take() - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
{@inheritDoc CompletionService}
take() - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
take() - Method in class org.infinispan.executors.SemaphoreCompletionService
 
TAKE_BACKUP_OFFLINE_AFTER_FAILURES - org.infinispan.configuration.parsing.Attribute
 
TAKE_BACKUP_OFFLINE_MIN_WAIT - org.infinispan.configuration.parsing.Attribute
 
TAKE_OFFLINE - org.infinispan.configuration.parsing.Element
 
TAKE_OFFLINE - org.infinispan.xsite.XSiteAdminCommand.AdminOperation
 
takeExecutorOwnership - Variable in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
TAKEN_OFFLINE - org.infinispan.xsite.BackupSender.TakeSiteOfflineResponse
 
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(AttributeSet) - 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.GlobalXSiteAdminOperations
 
takeSiteOffline(String) - Method in class org.infinispan.xsite.XSiteAdminOperations
 
target - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
target - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl.ListenerInvocationImpl
 
TargetMigrator - Interface in org.infinispan.upgrade
Performs migration operations on the target server or cluster of servers
targetNotFound(Address) - Method in class org.infinispan.remoting.transport.impl.SingleResponseCollector
 
targetNotFound(Address) - Method in class org.infinispan.remoting.transport.impl.SingletonMapResponseCollector
 
targetNotFound(Address) - Method in class org.infinispan.remoting.transport.ValidSingleResponseCollector
 
targets - Variable in class org.infinispan.notifications.cachelistener.cluster.impl.BatchingClusterEventManagerImpl.UnicastEventContext
 
task - Variable in class org.infinispan.distexec.RunnableAdapter
 
TaskContextImpl - Class in org.infinispan.persistence
 
TaskContextImpl() - Constructor for class org.infinispan.persistence.TaskContextImpl
 
TASKS - org.infinispan.util.logging.events.EventLogCategory
 
template() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
template(boolean) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
template(boolean) - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
templateConfigurationStartAttempt(String) - Method in class org.infinispan.util.logging.Log_$logger
 
templateConfigurationStartAttempt(String) - Method in interface org.infinispan.util.logging.Log
 
templateConfigurationStartAttempt$str() - Method in class org.infinispan.util.logging.Log_$logger
 
TEMPORARY_LOCATION - org.infinispan.configuration.parsing.Element
 
TEMPORARY_LOCATION - Static variable in class org.infinispan.configuration.global.GlobalStateConfiguration
 
temporaryLocation() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
Returns the filesystem path where temporary state should be stored.
temporaryLocation(String) - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
Defines the filesystem path where temporary state should be stored.
TERMINAL - org.infinispan.stream.impl.StreamRequestCommand.Type
 
TERMINAL_KEY - org.infinispan.stream.impl.StreamRequestCommand.Type
 
TERMINAL_KEY_REHASH - org.infinispan.stream.impl.StreamRequestCommand.Type
 
TERMINAL_REHASH - org.infinispan.stream.impl.StreamRequestCommand.Type
 
TerminalOperation<Original,​R> - Interface in org.infinispan.stream.impl
Interface describing an operation that is a terminal one that doesn't track keys.
TerminalOperationExternalizer - Class in org.infinispan.stream.impl.termop
AdvancedExternalizer that provides functionality required for marshalling all of the various terminal operations that are used by various distributed streams including the primitive forms.
TerminalOperationExternalizer() - Constructor for class org.infinispan.stream.impl.termop.TerminalOperationExternalizer
 
terminate() - Method in class org.infinispan.statetransfer.InboundTransferTask
Terminate abruptly regardless if the segments were received or not.
TERMINATED - org.infinispan.lifecycle.ComponentStatus
The stop() method has completed and the component has terminated.
test(K) - Method in interface org.infinispan.filter.KeyFilter
Deprecated.
 
test(ScopedState) - Method in class org.infinispan.globalstate.ScopeFilter
 
testListenerClassValidity(Class<?>) - Static method in class org.infinispan.notifications.impl.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.impl.AbstractListenerImpl
 
thenAccept(InvocationContext, VisitableCommand, InvocationSuccessAction) - Method in class org.infinispan.interceptors.InvocationStage
 
thenApply(InvocationContext, VisitableCommand, InvocationSuccessFunction) - Method in class org.infinispan.interceptors.InvocationStage
After the current stage completes successfully, invoke function and return its result.
thirdPartySuspected(Address, SuspectException) - Method in class org.infinispan.util.logging.Log_$logger
 
thirdPartySuspected(Address, SuspectException) - Method in interface org.infinispan.util.logging.Log
 
thirdPartySuspected$str() - Method in class org.infinispan.util.logging.Log_$logger
 
THREAD_FACTORY - org.infinispan.configuration.parsing.Attribute
 
THREAD_FACTORY - org.infinispan.configuration.parsing.Element
 
THREAD_NAME_PATTERN - org.infinispan.configuration.parsing.Attribute
 
THREAD_POLICY - org.infinispan.configuration.parsing.Attribute
 
THREAD_POLICY - Static variable in class org.infinispan.configuration.cache.EvictionConfiguration
Deprecated.
 
THREAD_POOL_SIZE - org.infinispan.configuration.parsing.Attribute
 
THREAD_POOL_SIZE - Static variable in class org.infinispan.configuration.cache.AsyncStoreConfiguration
 
threadFactory() - Method in class org.infinispan.configuration.global.ThreadPoolConfiguration
 
threadFactory(ThreadFactory) - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
 
threadGroup() - Method in class org.infinispan.factories.threads.DefaultThreadFactory
 
ThreadNameInfo - Class in org.infinispan.factories.threads
 
threadNamePattern() - Method in class org.infinispan.factories.threads.DefaultThreadFactory
 
threadPolicy() - Method in class org.infinispan.configuration.cache.EvictionConfiguration
Deprecated. 
threadPolicy(EvictionThreadPolicy) - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
Deprecated.
Threading policy for eviction.
ThreadPoolConfiguration - Class in org.infinispan.configuration.global
 
ThreadPoolConfiguration(ThreadFactory, ThreadPoolExecutorFactory) - Constructor for class org.infinispan.configuration.global.ThreadPoolConfiguration
 
ThreadPoolConfigurationBuilder - Class in org.infinispan.configuration.global
 
ThreadPoolConfigurationBuilder(GlobalConfigurationBuilder) - Constructor for class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
 
threadPoolFactory() - Method in class org.infinispan.configuration.global.ThreadPoolConfiguration
 
threadPoolFactory(ThreadPoolExecutorFactory) - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
 
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
Configures the number of threads in the thread pool that is responsible for applying modifications.
THREADS - org.infinispan.configuration.parsing.Element
 
THRESHOLD - Static variable in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
 
throwStackAwareConfigurationException(String) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
TIMED_OUT - org.infinispan.util.concurrent.locks.LockState
The time out occurred while the lock owner waits on the queue.
timeout - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
timeout - Variable in class org.infinispan.statetransfer.StateProviderImpl
 
timeout - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
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() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
timeout() - Method in interface org.infinispan.distexec.DistributedTask
Returns timeout for the execution of this task
timeout() - Method in class org.infinispan.remoting.rpc.RpcOptions
 
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) - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
The time (in milliseconds) to wait for the backup site acknowledge the state chunk received and applied.
timeout(long, TimeUnit) - Method in interface org.infinispan.BaseCacheStream
Sets a given time to wait for a remote operation to respond by.
timeout(long, TimeUnit) - Method in interface org.infinispan.CacheStream
Sets a given time to wait for a remote operation to respond by.
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(long, TimeUnit) - Method in interface org.infinispan.distexec.DistributedTaskBuilder
Provide DistributedTask task timeout
timeout(long, TimeUnit) - Method in interface org.infinispan.DoubleCacheStream
Sets a given time to wait for a remote operation to respond by.
timeout(long, TimeUnit) - Method in interface org.infinispan.IntCacheStream
Sets a given time to wait for a remote operation to respond by.
timeout(long, TimeUnit) - Method in interface org.infinispan.LockedStream
Sets the timeout for the acquisition of the lock for each entry.
timeout(long, TimeUnit) - Method in interface org.infinispan.LongCacheStream
Sets a given time to wait for a remote operation to respond by.
timeout(long, TimeUnit) - Method in interface org.infinispan.manager.ClusterExecutor
Sets a duration after which a command will timeout.
timeout(long, TimeUnit) - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
Deprecated.
Sets the timeout value and its TimeUnit.
timeout(long, TimeUnit) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
timeout(long, TimeUnit) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
timeout(long, TimeUnit) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
timeout(long, TimeUnit) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
timeout(long, TimeUnit) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
timeout(long, TimeUnit) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
timeout(long, TimeUnit) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
timeout(long, TimeUnit) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
timeout(long, TimeUnit) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
timeout(long, TimeUnit) - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
timeout(long, TimeUnit) - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
timeout(long, TimeUnit) - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
timeout(long, TimeUnit) - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
timeout(long, TimeUnit) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
timeout(TimeUnit) - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
Deprecated.
TIMEOUT - org.infinispan.configuration.parsing.Attribute
 
TIMEOUT - Static variable in class org.infinispan.configuration.cache.StateTransferConfiguration
 
TIMEOUT - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
TIMEOUT_SCHEDULE_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
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
 
timeoutExecutor - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
timeoutUnit - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
timeoutWaitingForAcks(String, long) - Method in class org.infinispan.util.logging.Log_$logger
 
timeoutWaitingForAcks(String, long) - Method in interface org.infinispan.util.logging.Log
 
timeoutWaitingForAcks$str() - Method in class org.infinispan.util.logging.Log_$logger
 
timeoutWaitingForInitialNodes(int, List<?>) - Method in class org.infinispan.util.logging.Log_$logger
 
timeoutWaitingForInitialNodes(int, List<?>) - Method in interface org.infinispan.util.logging.Log
 
timeoutWaitingForInitialNodes$str() - Method in class org.infinispan.util.logging.Log_$logger
 
timeoutWaitingForView(int, int) - Method in class org.infinispan.util.logging.Log_$logger
 
timeoutWaitingForView(int, int) - Method in interface org.infinispan.util.logging.Log
 
timeoutWaitingForView$str() - Method in class org.infinispan.util.logging.Log_$logger
 
timeoutWaitingUntilTransactionPrepared(String) - Method in class org.infinispan.util.logging.Log_$logger
 
timeoutWaitingUntilTransactionPrepared(String) - Method in interface org.infinispan.util.logging.Log
 
timeoutWaitingUntilTransactionPrepared$str() - Method in class org.infinispan.util.logging.Log_$logger
 
timeService - Variable in class org.infinispan.container.impl.AbstractInternalDataContainer
 
timeService - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
timeService - Variable in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
timeService - Variable in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
timeService - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
timeService - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
timeService - Variable in class org.infinispan.xsite.BaseBackupReceiver
 
TIMESTAMP - Static variable in class org.infinispan.globalstate.impl.GlobalStateManagerImpl
 
timeUnit() - Method in class org.infinispan.remoting.rpc.RpcOptions
 
toArray() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySetBase
 
toArray() - Method in class org.infinispan.commands.read.AbstractCloseableIteratorCollection
 
toArray() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
toArray() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
toArray() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
toArray() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
toArray() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
toArray() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
toArray() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
toArray() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
toArray() - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
toArray() - Method in class org.infinispan.stream.impl.local.LocalDoubleCacheStream
 
toArray() - Method in class org.infinispan.stream.impl.local.LocalIntCacheStream
 
toArray() - Method in class org.infinispan.stream.impl.local.LocalLongCacheStream
 
toArray() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
toArray() - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
 
toArray() - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
Deprecated.
 
toArray(IntFunction<A[]>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
toArray(IntFunction<A[]>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
toArray(IntFunction<A[]>) - Method in class org.infinispan.stream.impl.local.LocalCacheStream
 
toArray(IntFunction<A[]>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
toArray(SerializableIntFunction<A[]>) - Method in interface org.infinispan.CacheStream
Same as Stream.toArray(IntFunction) except that the BinaryOperator must also implement Serializable
toArray(T[]) - Method in class org.infinispan.commands.read.AbstractCloseableIteratorCollection
 
toArray(T[]) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
Deprecated.
 
toArray(T1[]) - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
 
toArray(U[]) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySetBase
 
toAsync() - Method in enum org.infinispan.configuration.cache.CacheMode
 
toCompletableFuture() - Method in class org.infinispan.interceptors.impl.SimpleAsyncInvocationStage
 
toCompletableFuture() - Method in class org.infinispan.interceptors.InvocationStage
CompletableFuture conversion.
toCompletableFuture() - Method in class org.infinispan.interceptors.SyncInvocationStage
 
toCompletionStage() - Method in interface org.infinispan.scattered.BiasManager.Revocation
 
toEntrySet(AdvancedCacheLoader<K, V>, Predicate<? super K>, InternalEntryFactory) - Static method in class org.infinispan.persistence.PersistenceUtil
 
toEntrySet(AdvancedCacheLoader<K, V>, KeyFilter<? super K>, InternalEntryFactory) - Static method in class org.infinispan.persistence.PersistenceUtil
toFlagsBitSet() - Method in class org.infinispan.functional.impl.Params
Bridging method between flags and params, provided for efficient checks.
toImmutable(Collection<E>) - Static method in class org.infinispan.xsite.status.AbstractMixedSiteStatus
 
toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
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
 
toInternalCacheEntry(K) - Method in interface org.infinispan.container.entries.InternalCacheValue
 
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
 
toInvocationStage() - Method in interface org.infinispan.util.concurrent.locks.LockPromise
 
toInvocationStage(Supplier<TimeoutException>) - Method in interface org.infinispan.util.concurrent.locks.ExtendedLockPromise
 
toKeyFunction - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
toKeySet(AdvancedCacheLoader<K, V>, Predicate<? super K>) - Static method in class org.infinispan.persistence.PersistenceUtil
 
toKeySet(AdvancedCacheLoader<K, V>, KeyFilter<? super K>) - Static method in class org.infinispan.persistence.PersistenceUtil
toLoggerLevel() - Method in enum org.infinispan.util.logging.events.EventLogLevel
 
toManageableComponentMetadata() - Method in class org.infinispan.factories.components.ComponentMetadata
 
toManageableComponentMetadata() - Method in class org.infinispan.factories.components.ManageableComponentMetadata
 
toMutation(Object) - Method in interface org.infinispan.commands.functional.FunctionalCommand
 
toMutation(Object) - Method in class org.infinispan.commands.functional.ReadWriteKeyCommand
 
toMutation(Object) - Method in class org.infinispan.commands.functional.ReadWriteKeyValueCommand
 
toMutation(Object) - Method in class org.infinispan.commands.functional.ReadWriteManyCommand
 
toMutation(Object) - Method in class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
toMutation(Object) - Method in class org.infinispan.commands.functional.WriteOnlyKeyCommand
 
toMutation(Object) - Method in class org.infinispan.commands.functional.WriteOnlyKeyValueCommand
 
toMutation(Object) - Method in class org.infinispan.commands.functional.WriteOnlyManyCommand
 
toMutation(Object) - Method in class org.infinispan.commands.functional.WriteOnlyManyEntriesCommand
 
toNewTypeIteratorFunction - Variable in class org.infinispan.util.WriteableCacheCollectionMapper
 
topologicalSort() - Method in class org.infinispan.util.DependencyGraph
Calculates a topological sort of the graph, in linear time
TOPOLOGY_CHANGED - org.infinispan.notifications.cachelistener.event.Event.Type
 
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.impl
Default topology-aware consistent hash factory implementation.
TopologyAwareConsistentHashFactory() - Constructor for class org.infinispan.distribution.ch.impl.TopologyAwareConsistentHashFactory
 
TopologyAwareConsistentHashFactory.Externalizer - Class in org.infinispan.distribution.ch.impl
 
TopologyAwareSyncConsistentHashFactory - Class in org.infinispan.distribution.ch.impl
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.impl.TopologyAwareSyncConsistentHashFactory
 
TopologyAwareSyncConsistentHashFactory.Builder - Class in org.infinispan.distribution.ch.impl
 
TopologyAwareSyncConsistentHashFactory.Externalizer - Class in org.infinispan.distribution.ch.impl
 
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.
topologyFuture(int) - Method in interface org.infinispan.statetransfer.StateTransferLock
 
topologyFuture(int) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
topologyId - Variable in class org.infinispan.commands.remote.BaseClusteredReadCommand
 
topologyId - Variable in class org.infinispan.container.versioning.SimpleClusteredVersion
The cache topology id in which it was first created.
topologyId - Variable in class org.infinispan.stream.impl.StreamIteratorNextCommand
 
topologyId - Variable in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
TopologyIdUpdater() - Constructor for class org.infinispan.container.versioning.SimpleClusteredVersionGenerator.TopologyIdUpdater
 
topologyInfo - Variable in class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory.Builder
 
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.
TopologyMode - Enum in org.infinispan.remoting.inboundhandler
It checks or waits until the required topology is installed.
topologyReceived(int) - Method in interface org.infinispan.statetransfer.StateTransferLock
 
topologyReceived(int) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
topologyUpdateError(String, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
topologyUpdateError(String, Throwable) - Method in interface org.infinispan.util.logging.Log
 
topologyUpdateError$str() - Method in class org.infinispan.util.logging.Log_$logger
 
toScopedState(ScopedPersistentState) - Method in interface org.infinispan.distribution.ch.ConsistentHash
Writes this ConsistentHash to the specified scoped state.
toScopedState(ScopedPersistentState) - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
toScopedState(ScopedPersistentState) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
 
toScopedState(ScopedPersistentState) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
toScopedState(ScopedPersistentState) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
 
toScopedState(ScopedPersistentState) - Method in class org.infinispan.distribution.group.impl.PartitionerConsistentHash
 
toSerialSupplierCollect(SerializableSupplier) - Static method in class org.infinispan.util.Casting
 
toStorage(Object) - Method in class org.infinispan.encoding.DataConversion
 
toStream() - Method in class org.infinispan.container.offheap.MemoryAddressHash
Returns a stream of longs that are all of the various memory locations
toStreamRemoved() - Method in class org.infinispan.container.offheap.MemoryAddressHash
Same as MemoryAddressHash.toStream() except that the memory addresses are also cleared out (set to 0)
toString() - Method in class org.infinispan.atomic.DeltaCompositeKey
Deprecated.
 
toString() - Method in class org.infinispan.atomic.impl.AtomicKeySetImpl
 
toString() - Method in class org.infinispan.atomic.impl.AtomicMapProxyImpl
 
toString() - Method in class org.infinispan.atomic.impl.FineGrainedAtomicMapProxyImpl
 
toString() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
toString() - Method in class org.infinispan.cache.impl.CacheImpl
 
toString() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
toString() - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
toString() - Method in class org.infinispan.commands.CancelCommand
 
toString() - Method in class org.infinispan.commands.CommandInvocationId
 
toString() - Method in class org.infinispan.commands.control.LockControlCommand
 
toString() - Method in class org.infinispan.commands.CreateCacheCommand
 
toString() - Method in class org.infinispan.commands.functional.AbstractWriteKeyCommand
 
toString() - Method in class org.infinispan.commands.functional.ReadOnlyKeyCommand
 
toString() - Method in class org.infinispan.commands.functional.ReadOnlyManyCommand
 
toString() - Method in class org.infinispan.commands.functional.ReadWriteKeyCommand
 
toString() - Method in class org.infinispan.commands.functional.ReadWriteKeyValueCommand
 
toString() - Method in class org.infinispan.commands.functional.ReadWriteManyCommand
 
toString() - Method in class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
toString() - Method in class org.infinispan.commands.functional.TxReadOnlyKeyCommand
 
toString() - Method in class org.infinispan.commands.functional.TxReadOnlyManyCommand
 
toString() - Method in class org.infinispan.commands.functional.WriteOnlyManyCommand
 
toString() - Method in class org.infinispan.commands.functional.WriteOnlyManyEntriesCommand
 
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.GetAllCommand
 
toString() - Method in class org.infinispan.commands.read.GetCacheEntryCommand
 
toString() - Method in class org.infinispan.commands.read.GetKeyValueCommand
 
toString() - Method in class org.infinispan.commands.read.KeySetCommand
 
toString() - Method in class org.infinispan.commands.read.SizeCommand
 
toString() - Method in class org.infinispan.commands.remote.BaseRpcCommand
 
toString() - Method in class org.infinispan.commands.remote.ClusteredGetAllCommand
 
toString() - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
toString() - Method in class org.infinispan.commands.remote.GetKeysInGroupCommand
 
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.RevokeBiasCommand
 
toString() - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
toString() - Method in class org.infinispan.commands.RemoveCacheCommand
Deprecated.
 
toString() - Method in class org.infinispan.commands.triangle.PutMapBackupWriteCommand
 
toString() - Method in class org.infinispan.commands.triangle.SingleKeyBackupWriteCommand
 
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
Deprecated.
 
toString() - Method in class org.infinispan.commands.write.BackupAckCommand
 
toString() - Method in class org.infinispan.commands.write.BackupMultiKeyAckCommand
 
toString() - Method in class org.infinispan.commands.write.ClearCommand
 
toString() - Method in class org.infinispan.commands.write.ComputeCommand
 
toString() - Method in class org.infinispan.commands.write.ComputeIfAbsentCommand
 
toString() - Method in class org.infinispan.commands.write.EvictCommand
 
toString() - Method in class org.infinispan.commands.write.ExceptionAckCommand
 
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.InvalidateVersionsCommand
 
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.RemoveExpiredCommand
 
toString() - Method in class org.infinispan.commands.write.ReplaceCommand
 
toString() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
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.AuthorizationConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
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.ContentTypeConfiguration
 
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
Deprecated.
 
toString() - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
Deprecated.
 
toString() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfiguration
Deprecated.
 
toString() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
Deprecated.
 
toString() - Method in class org.infinispan.configuration.cache.EncodingConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.EvictionConfiguration
Deprecated.
 
toString() - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
Deprecated.
 
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.MemoryConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
 
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.SecurityConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.SingletonStoreConfiguration
Deprecated.
 
toString() - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
Deprecated.
 
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
Deprecated.
 
toString() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
Deprecated.
 
toString() - Method in class org.infinispan.configuration.cache.SyncConfiguration
Deprecated.
 
toString() - Method in class org.infinispan.configuration.cache.SyncConfigurationBuilder
Deprecated.
 
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
Deprecated.
 
toString() - Method in class org.infinispan.configuration.cache.VersioningConfigurationBuilder
Deprecated.
 
toString() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
toString() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
 
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.GlobalAuthorizationConfiguration
 
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.GlobalSecurityConfiguration
 
toString() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
 
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.ThreadPoolConfiguration
 
toString() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
toString() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
toString() - Method in class org.infinispan.configuration.internal.PrivateGlobalConfiguration
 
toString() - Method in class org.infinispan.configuration.internal.PrivateGlobalConfigurationBuilder
 
toString() - Method in enum org.infinispan.configuration.parsing.Attribute
 
toString() - Method in enum org.infinispan.configuration.parsing.Element
 
toString() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
toString() - Method in class org.infinispan.container.entries.ClearCacheEntry
 
toString() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
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.NullCacheEntry
 
toString() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
toString() - Method in class org.infinispan.container.entries.RemoteMetadata
 
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.context.SingleKeyNonTxInvocationContext
Deprecated.
 
toString() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
 
toString() - Method in class org.infinispan.distribution.ch.impl.HashFunctionPartitioner
 
toString() - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
 
toString() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
toString() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
 
toString() - Method in class org.infinispan.distribution.DistributionInfo
 
toString() - Method in class org.infinispan.distribution.group.impl.PartitionerConsistentHash
 
toString() - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
toString() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
 
toString() - Method in class org.infinispan.encoding.DataConversion
 
toString() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
Deprecated.
 
toString() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
 
toString() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMethodMetadata
 
toString() - Method in class org.infinispan.factories.components.ComponentMetadata.PrioritizedMethodMetadata
 
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.functional.impl.MetaParamsInternalMetadata
 
toString() - Method in class org.infinispan.functional.impl.Params
 
toString() - Method in class org.infinispan.functional.impl.StatsEnvelope
 
toString() - Method in class org.infinispan.functional.MetaParam.MetaCreated
 
toString() - Method in class org.infinispan.functional.MetaParam.MetaEntryVersion
 
toString() - Method in class org.infinispan.functional.MetaParam.MetaLastUsed
 
toString() - Method in class org.infinispan.functional.MetaParam.MetaLifespan
 
toString() - Method in class org.infinispan.functional.MetaParam.MetaMaxIdle
 
toString() - Method in class org.infinispan.globalstate.ScopedState
 
toString() - Method in class org.infinispan.interceptors.distribution.VersionedResult
 
toString() - Method in class org.infinispan.interceptors.distribution.VersionedResults
 
toString() - Method in class org.infinispan.interceptors.impl.AsyncInterceptorChainImpl
 
toString() - Method in class org.infinispan.interceptors.impl.QueueAsyncInvocationStage
 
toString() - Method in class org.infinispan.interceptors.impl.SimpleAsyncInvocationStage
 
toString() - Method in class org.infinispan.interceptors.SyncInvocationStage
 
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.manager.DefaultCacheManager
 
toString() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl
 
toString() - Method in class org.infinispan.metadata.EmbeddedMetadata
 
toString() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
 
toString() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
toString() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEventCallable
 
toString() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
toString() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
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.support.SingletonCacheWriter
Deprecated.
 
toString() - Method in class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
 
toString() - Method in class org.infinispan.remoting.inboundhandler.DefaultTopologyRunnable
 
toString() - Method in class org.infinispan.remoting.responses.ExceptionResponse
 
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.UnsuccessfulResponse
 
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
Deprecated.
 
toString() - Method in class org.infinispan.remoting.transport.AggregateBackupResponse
 
toString() - Method in class org.infinispan.remoting.transport.jgroups.ClusterView
 
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.remoting.transport.LocalModeAddress
 
toString() - Method in class org.infinispan.remoting.transport.RetryOnFailureXSiteCommand
 
toString() - Method in enum org.infinispan.security.AuditContext
 
toString() - Method in class org.infinispan.security.impl.CachePrincipalPair
 
toString() - Method in class org.infinispan.security.impl.CacheRoleImpl
 
toString() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
toString() - Method in class org.infinispan.security.impl.SubjectACL
 
toString() - Method in class org.infinispan.statetransfer.CommitManager
 
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.StateTransferManagerImpl
 
toString() - Method in class org.infinispan.statetransfer.TransactionInfo
 
toString() - Method in class org.infinispan.stream.impl.StreamRequestCommand
 
toString() - Method in class org.infinispan.stream.impl.StreamResponseCommand
 
toString() - Method in class org.infinispan.topology.CacheJoinInfo
 
toString() - Method in class org.infinispan.topology.CacheStatusResponse
 
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.topology.ManagerStatusResponse
 
toString() - Method in class org.infinispan.topology.PersistentUUID
 
toString() - Method in class org.infinispan.transaction.impl.LocalTransaction
 
toString() - Method in class org.infinispan.transaction.impl.RemoteTransaction
 
toString() - Method in class org.infinispan.transaction.impl.TotalOrderRemoteTransactionState
 
toString() - Method in class org.infinispan.transaction.lookup.DummyTransactionManagerLookup
Deprecated.
 
toString() - Method in class org.infinispan.transaction.lookup.EmbeddedTransactionManagerLookup
 
toString() - Method in class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
 
toString() - Method in class org.infinispan.transaction.lookup.WildflyTransactionManagerLookup
 
toString() - Method in class org.infinispan.transaction.synchronization.SynchronizationAdapter
 
toString() - Method in class org.infinispan.transaction.tm.DummyNoXaXid
Deprecated.
 
toString() - Method in class org.infinispan.transaction.tm.DummyTransaction
Deprecated.
 
toString() - Method in class org.infinispan.transaction.tm.DummyXid
Deprecated.
 
toString() - Method in class org.infinispan.transaction.totalorder.TotalOrderLatchImpl
 
toString() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
Deprecated.
 
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
Deprecated.
 
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
Deprecated.
 
toString() - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
toString() - Method in class org.infinispan.util.ByteString
 
toString() - Method in class org.infinispan.util.concurrent.locks.impl.PerKeyLockContainer
 
toString() - Method in class org.infinispan.util.concurrent.locks.impl.StripedLockContainer
 
toString() - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
toString() - Method in exception org.infinispan.util.concurrent.TimeoutException
 
toString() - Method in class org.infinispan.util.KeyValuePair
 
toString() - Method in class org.infinispan.xsite.OfflineStatus
 
toString() - Method in class org.infinispan.xsite.SingleXSiteRpcCommand
 
toString() - Method in class org.infinispan.xsite.statetransfer.XSiteState
 
toString() - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
 
toString() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferCollector
 
toString() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
 
toString() - Method in class org.infinispan.xsite.XSiteAdminCommand
 
toString() - Method in class org.infinispan.xsite.XSiteBackup
 
toString(Element) - Static method in class org.infinispan.configuration.parsing.XmlConfigHelper
 
toSupplierCollect(Supplier) - Static method in class org.infinispan.util.Casting
 
toSync() - Method in enum org.infinispan.configuration.cache.CacheMode
 
TOTAL - org.infinispan.remoting.inboundhandler.DeliverOrder
The message is delivered in the same order in all the destinations.
TOTAL_ORDER - org.infinispan.transaction.TransactionProtocol
uses the total order protocol
TOTAL_ORDER_EXECUTOR - org.infinispan.configuration.parsing.Attribute
 
totalOrder - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
TotalOrderCommitCommand - Class in org.infinispan.commands.tx.totalorder
Commit Command used in the 2nd phase of 2PC.
TotalOrderCommitCommand(ByteString) - Constructor for class org.infinispan.commands.tx.totalorder.TotalOrderCommitCommand
 
TotalOrderCommitCommand(ByteString, GlobalTransaction) - 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
 
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 - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
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(ByteString) - Constructor for class org.infinispan.commands.tx.totalorder.TotalOrderNonVersionedPrepareCommand
 
TotalOrderNonVersionedPrepareCommand(ByteString, GlobalTransaction, List<WriteCommand>) - Constructor for class org.infinispan.commands.tx.totalorder.TotalOrderNonVersionedPrepareCommand
 
TotalOrderNonVersionedPrepareCommand(ByteString, GlobalTransaction, WriteCommand...) - Constructor for class org.infinispan.commands.tx.totalorder.TotalOrderNonVersionedPrepareCommand
 
totalOrderPrepare(TxInvocationContext<?>, PrepareCommand, Collection<Address>) - Method in class org.infinispan.interceptors.impl.BaseRpcInterceptor
 
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.impl
Represents a state for a Remote Transaction when the Total Order based protocol is used.
TotalOrderRemoteTransactionState(GlobalTransaction) - Constructor for class org.infinispan.transaction.impl.TotalOrderRemoteTransactionState
 
TotalOrderRollbackCommand - Class in org.infinispan.commands.tx.totalorder
The 2nd phase command of 2PC, used when a transaction must be aborted.
TotalOrderRollbackCommand(ByteString) - Constructor for class org.infinispan.commands.tx.totalorder.TotalOrderRollbackCommand
 
TotalOrderRollbackCommand(ByteString, GlobalTransaction) - 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.impl.BaseRpcInterceptor
 
TotalOrderTxPerCacheInboundInvocationHandler - Class in org.infinispan.remoting.inboundhandler
A PerCacheInboundInvocationHandler implementation for total order caches.
TotalOrderTxPerCacheInboundInvocationHandler() - Constructor for class org.infinispan.remoting.inboundhandler.TotalOrderTxPerCacheInboundInvocationHandler
 
totalOrderTxRollback(TxInvocationContext) - Static method in class org.infinispan.interceptors.impl.BaseRpcInterceptor
 
TotalOrderVersionedCommitCommand - Class in org.infinispan.commands.tx.totalorder
Command corresponding to the 2nd phase of 2PC.
TotalOrderVersionedCommitCommand(ByteString) - Constructor for class org.infinispan.commands.tx.totalorder.TotalOrderVersionedCommitCommand
 
TotalOrderVersionedCommitCommand(ByteString, GlobalTransaction) - 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(ByteString) - Constructor for class org.infinispan.commands.tx.totalorder.TotalOrderVersionedPrepareCommand
 
TotalOrderVersionedPrepareCommand(ByteString, GlobalTransaction, List<WriteCommand>, boolean) - Constructor for class org.infinispan.commands.tx.totalorder.TotalOrderVersionedPrepareCommand
 
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() - Method in interface org.infinispan.container.entries.InternalCacheEntry
touch() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
touch() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
touch() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
touch() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
touch() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
touch() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
touch(long) - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
touch(long) - Method in interface org.infinispan.container.entries.InternalCacheEntry
Updates access timestamps on this instance to a specified time
touch(long) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
touch(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
touch(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
touch(long) - Method in class org.infinispan.container.entries.MortalCacheEntry
 
touch(long) - Method in class org.infinispan.container.entries.TransientCacheEntry
 
touch(long) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
toURI() - Method in class org.infinispan.io.GridFile
 
toURL() - Method in class org.infinispan.io.GridFile
 
toXMLString(String) - Method in class org.infinispan.configuration.cache.Configuration
 
trace - Variable in class org.infinispan.interceptors.impl.BaseRpcInterceptor
 
trace - Static variable in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
trace - Static variable in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
 
trace - Static variable in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
trace - Static variable in class org.infinispan.stream.impl.ClusterStreamManagerImpl
 
TraceException - Exception in org.infinispan.util.logging
This exception is used to add stack trace information to exceptions as they move from one thread to another.
TraceException() - Constructor for exception org.infinispan.util.logging.TraceException
 
TRAIT - org.infinispan.jmx.annotations.DataType
 
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 - org.infinispan.configuration.parsing.Element
 
TRANSACTION_COMPLETED - org.infinispan.notifications.cachelistener.event.Event.Type
 
TRANSACTION_MANAGER_LOOKUP - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
 
TRANSACTION_MANAGER_LOOKUP_CLASS - org.infinispan.configuration.parsing.Attribute
 
TRANSACTION_MODE - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
 
TRANSACTION_PROTOCOL - org.infinispan.configuration.parsing.Attribute
 
TRANSACTION_PROTOCOL - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
 
TRANSACTION_REGISTERED - org.infinispan.notifications.cachelistener.event.Event.Type
 
TRANSACTION_SYNCHRONIZATION_REGISTRY_LOOKUP - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
 
TRANSACTION_VERSION_GENERATOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
transactional() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
transactional() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
 
transactional(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
This setting should be set to true when the underlying cache store supports transactions and it is desirable for the underlying store and the cache to remain synchronized.
transactional(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
 
transactional(boolean) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
This setting should be set to true when the underlying cache store supports transactions and it is desirable for the underlying store and the cache to remain synchronized.
TRANSACTIONAL - org.infinispan.configuration.parsing.Attribute
 
TRANSACTIONAL - org.infinispan.transaction.TransactionMode
 
TRANSACTIONAL - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
TransactionalCacheWriter<K,​V> - Interface in org.infinispan.persistence.spi
Defines the functionality of a transactional store.
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.
TransactionalExceptionEvictionInterceptor - Class in org.infinispan.interceptors.impl
Interceptor that prevents the cache from inserting too many entries over a configured maximum amount.
TransactionalExceptionEvictionInterceptor() - Constructor for class org.infinispan.interceptors.impl.TransactionalExceptionEvictionInterceptor
 
TransactionalInvocationContextFactory - Class in org.infinispan.context
Deprecated.
Since 9.0, this class is going to be moved to an internal package.
TransactionalInvocationContextFactory() - Constructor for class org.infinispan.context.TransactionalInvocationContextFactory
Deprecated.
 
TransactionalRemoteLockCommand - Interface in org.infinispan.util.concurrent.locks
Simple interface to extract all the keys that may need to be locked for transactional commands.
transactionalStoreCannotBeAsync(String) - Method in class org.infinispan.util.logging.Log_$logger
 
transactionalStoreCannotBeAsync(String) - Method in interface org.infinispan.util.logging.Log
 
transactionalStoreCannotBeAsync$str() - Method in class org.infinispan.util.logging.Log_$logger
 
transactionalStoreInNonTransactionalCache() - Method in class org.infinispan.util.logging.Log_$logger
 
transactionalStoreInNonTransactionalCache() - Method in interface org.infinispan.util.logging.Log
 
transactionalStoreInNonTransactionalCache$str() - Method in class org.infinispan.util.logging.Log_$logger
 
transactionalStoreInPassivatedCache() - Method in class org.infinispan.util.logging.Log_$logger
 
transactionalStoreInPassivatedCache() - Method in interface org.infinispan.util.logging.Log
 
transactionalStoreInPassivatedCache$str() - Method in class org.infinispan.util.logging.Log_$logger
 
TransactionalStoreInterceptor - Class in org.infinispan.interceptors.impl
An interceptor which ensures that writes to an underlying transactional store are prepared->committed/rolledback as part of the 2PC, therefore ensuring that the cache and transactional store(s) remain consistent.
TransactionalStoreInterceptor() - Constructor for class org.infinispan.interceptors.impl.TransactionalStoreInterceptor
 
TransactionBoundaryCommand - Interface in org.infinispan.commands.tx
An transaction boundary command that allows the retrieval of an attached GlobalTransaction
transactionCleanupError(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
transactionCleanupError(Throwable) - Method in interface org.infinispan.util.logging.Log
 
transactionCleanupError$str() - Method in class org.infinispan.util.logging.Log_$logger
 
transactionCompleted(TransactionCompletedEvent) - Method in class org.infinispan.notifications.cachelistener.cluster.RemoteClusterListener
 
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.impl
Coordinates transaction prepare/commits as received from the TransactionManager.
TransactionCoordinator() - Constructor for class org.infinispan.transaction.impl.TransactionCoordinator
 
transactionDataFuture(int) - Method in interface org.infinispan.statetransfer.StateTransferLock
 
transactionDataFuture(int) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
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.cache.impl.CacheImpl
 
transactionManager - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
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() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
 
transactionManagerLookup(TransactionManagerLookup) - Method in class org.infinispan.configuration.cache.TransactionConfiguration
Deprecated.
since 9.0. The transaction manager is only looked up once, during cache startup.
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
Deprecated.
Use TransactionManagerLookup instead.
transactionMode() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
 
transactionMode() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
 
transactionMode(TransactionMode) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
 
TransactionMode - Enum in org.infinispan.configuration.cache
Transaction mode
TransactionMode - Enum in org.infinispan.transaction
Enumeration containing the available transaction modes for a cache.
transactionNotificationsDisabled() - Method in class org.infinispan.util.logging.Log_$logger
 
transactionNotificationsDisabled() - Method in interface org.infinispan.util.logging.Log
 
transactionNotificationsDisabled$str() - Method in class org.infinispan.util.logging.Log_$logger
 
TransactionOriginatorChecker - Interface in org.infinispan.transaction.impl
An interface to check if the transaction originator is left or not.
transactionProtocol() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
 
transactionProtocol() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
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.impl.BaseRpcInterceptor
 
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.statetransfer.StateConsumerImpl
 
TransactionTable - Class in org.infinispan.transaction.impl
Repository for RemoteTransaction and TransactionXaAdapters (locally originated transactions).
TransactionTable - Interface in org.infinispan.transaction
Interface that allows to fetch the GlobalTransaction associated to local or remote transactions.
TransactionTable() - Constructor for class org.infinispan.transaction.impl.TransactionTable
 
TransactionTable.CompletedTransactionStatus - Enum in org.infinispan.transaction.impl
 
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, XaTransactionTable) - Constructor for class org.infinispan.transaction.xa.TransactionXaAdapter
 
TransactionXaAdapter(XaTransactionTable) - Constructor for class org.infinispan.transaction.xa.TransactionXaAdapter
 
transferComplete() - Method in interface org.infinispan.notifications.cachelistener.QueueingSegmentListener
This is needed to tell the handler when the complete iteration is done.
transferMapsLock - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
transfersBySegment - Variable in class org.infinispan.statetransfer.StateConsumerImpl
A map that keeps track of current inbound state transfers by segment id.
transform(Function<AdvancedCache<K, V>, ? extends AdvancedCache<K, V>>) - Method in interface org.infinispan.AdvancedCache
Apply the transformation on each AdvancedCache instance in a delegation chain, starting with the innermost implementation.
transform(Function<AdvancedCache<K, V>, ? extends AdvancedCache<K, V>>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
transform(Function<AdvancedCache<K, V>, ? extends AdvancedCache<K, V>>) - Method in class org.infinispan.cache.impl.CacheImpl
 
transform(Function<AdvancedCache<K, V>, ? extends AdvancedCache<K, V>>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
transform(Function<AdvancedCache<K, V>, ? extends AdvancedCache<K, V>>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
transformResult(Object[]) - Method in interface org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadManyCommandHelper
 
transformResult(Object[]) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadOnlyManyHelper
 
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) - Constructor for class org.infinispan.container.entries.TransientMortalCacheValue
 
TransientMortalCacheValue(Object, long, long, long, long) - Constructor for class org.infinispan.container.entries.TransientMortalCacheValue
 
TransientMortalCacheValue.Externalizer - Class in org.infinispan.container.entries
 
TRANSITORY - org.infinispan.topology.CacheTopology.Phase
Used by caches that don't use 4-phase topology change.
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-related (i.e.
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 - org.infinispan.configuration.parsing.Attribute
 
TRANSPORT - org.infinispan.configuration.parsing.Element
 
TransportConfiguration - Class in org.infinispan.configuration.global
 
TransportConfigurationBuilder - Class in org.infinispan.configuration.global
Configures the transport used for network communications across the cluster.
TransportFactory - Class in org.infinispan.factories
Factory for Transport implementations
TransportFactory() - Constructor for class org.infinispan.factories.TransportFactory
 
transportThreadPool() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
transportThreadPool() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
Traversable<T> - Interface in org.infinispan.functional
Unsorted traversable stream for sequential and aggregating operations.
Traversables - Class in org.infinispan.functional.impl
 
TRENDSDOWN - org.infinispan.jmx.annotations.MeasurementType
 
TRENDSUP - org.infinispan.jmx.annotations.MeasurementType
 
TriangleAckExternalizer - Class in org.infinispan.marshall.exts
Externalizer for the triangle acknowledges.
TriangleAckExternalizer() - Constructor for class org.infinispan.marshall.exts.TriangleAckExternalizer
 
TriangleDistributionInterceptor - Class in org.infinispan.interceptors.distribution
Non-transactional interceptor used by distributed caches that supports concurrent writes.
TriangleDistributionInterceptor() - Constructor for class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
 
TriangleFunctionsUtil - Class in org.infinispan.util
Some utility functions for TriangleDistributionInterceptor.
TriangleOrderAction - Class in org.infinispan.remoting.inboundhandler.action
An Action that checks if the command is the next to be executed.
TriangleOrderAction(TrianglePerCacheInboundInvocationHandler, long, int) - Constructor for class org.infinispan.remoting.inboundhandler.action.TriangleOrderAction
 
triangleOrderManager - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
TriangleOrderManager - Class in org.infinispan.distribution
It manages the order of updates from the primary owner to backup owner.
TriangleOrderManager(int) - Constructor for class org.infinispan.distribution.TriangleOrderManager
 
TrianglePerCacheInboundInvocationHandler - Class in org.infinispan.remoting.inboundhandler
A PerCacheInboundInvocationHandler implementation for non-transactional and distributed caches that uses the triangle algorithm.
TrianglePerCacheInboundInvocationHandler() - Constructor for class org.infinispan.remoting.inboundhandler.TrianglePerCacheInboundInvocationHandler
 
TriConsumer<T,​U,​V> - Interface in org.infinispan.util.function
Represents an operation that accepts three input arguments and returns no result.
truncate() - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Truncate the contents of the cache, returning a CompletableFuture that will be completed when the truncate process completes.
truncate() - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
TRY_LOCK - org.infinispan.functional.Param.LockingMode
The operation fails when it is not possible to acquire the lock without waiting.
tryAcquireShared(int) - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
tryAdvance(Consumer<? super T>) - Method in class org.infinispan.stream.impl.spliterators.IteratorAsSpliterator
 
tryingToBringOnlineNonexistentSite(String) - Method in class org.infinispan.util.logging.Log_$logger
 
tryingToBringOnlineNonexistentSite(String) - Method in interface org.infinispan.util.logging.Log
 
tryingToBringOnlineNonexistentSite$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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 class org.infinispan.stream.impl.spliterators.IteratorAsSpliterator
 
TWO_PHASE - org.infinispan.statetransfer.RebalanceType
Used by scattered cache.
twoPhaseCommitAsyncBackup() - Method in class org.infinispan.util.logging.Log_$logger
 
twoPhaseCommitAsyncBackup() - Method in interface org.infinispan.util.logging.Log
 
twoPhaseCommitAsyncBackup$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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.impl.AbstractCacheTransaction
 
TxBatchUpdater - Class in org.infinispan.interceptors.impl
 
TxClusterExpirationManager<K,​V> - Class in org.infinispan.expiration.impl
 
TxClusterExpirationManager() - Constructor for class org.infinispan.expiration.impl.TxClusterExpirationManager
 
TxClusterStreamManager<Original,​K> - Class in org.infinispan.stream.impl.tx
This is a delegating cluster stream manager that sends all calls to the underlying cluster stream manager.
TxClusterStreamManager(ClusterStreamManager<Original, K>, LocalTxInvocationContext, int, ToIntFunction<Object>) - Constructor for class org.infinispan.stream.impl.tx.TxClusterStreamManager
 
TxCompletionNotificationCommand - Class in org.infinispan.commands.remote.recovery
Command for removing recovery related information from the cluster.
TxCompletionNotificationCommand(long, ByteString) - Constructor for class org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
 
TxCompletionNotificationCommand(Xid, GlobalTransaction, ByteString) - Constructor for class org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
 
TxCompletionNotificationCommand(ByteString) - Constructor for class org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
 
txCoordinator - Variable in class org.infinispan.transaction.impl.TransactionTable
 
TxDistributedCacheStream<Original,​R,​K,​V> - Class in org.infinispan.stream.impl.tx
A distributed cache stream that also utilizes transactional awareness.
TxDistributedCacheStream(Address, boolean, DistributionManager, Supplier<CacheStream<R>>, TxClusterStreamManager<Original, K>, boolean, int, Executor, ComponentRegistry, LocalTxInvocationContext, Function<? super Original, ?>, Function<? super CacheEntry<K, V>, ? extends Original>) - Constructor for class org.infinispan.stream.impl.tx.TxDistributedCacheStream
 
TxDistributedDoubleCacheStream<Original,​K,​V> - Class in org.infinispan.stream.impl.tx
Double variant of tx cache stream
TxDistributedIntCacheStream<Original,​K,​V> - Class in org.infinispan.stream.impl.tx
Int variant of tx cache stream
TxDistributedLongCacheStream<Original,​K,​V> - Class in org.infinispan.stream.impl.tx
Long variant of tx cache stream
TxDistributionInterceptor - Class in org.infinispan.interceptors.distribution
Handles the distribution of the transactional caches.
TxDistributionInterceptor() - Constructor for class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
TxInterceptor<K,​V> - Class in org.infinispan.interceptors.impl
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.impl.TxInterceptor
 
TxInvocationContext<T extends AbstractCacheTransaction> - Interface in org.infinispan.context.impl
Interface defining additional functionality for invocation contexts that propagate within a transaction's scope.
TxLockedStreamImpl<K,​V> - Class in org.infinispan.stream.impl
Locked Stream that is designed for transactions.
TxLockedStreamImpl(TransactionManager, CacheStream<CacheEntry<K, V>>, long, TimeUnit) - Constructor for class org.infinispan.stream.impl.TxLockedStreamImpl
 
TxReadOnlyKeyCommand<K,​V,​R> - Class in org.infinispan.commands.functional
 
TxReadOnlyKeyCommand() - Constructor for class org.infinispan.commands.functional.TxReadOnlyKeyCommand
 
TxReadOnlyKeyCommand(Object, List<Mutation<K, V, ?>>, int, Params, DataConversion, DataConversion, ComponentRegistry) - Constructor for class org.infinispan.commands.functional.TxReadOnlyKeyCommand
 
TxReadOnlyKeyCommand(ReadOnlyKeyCommand, List<Mutation<K, V, ?>>, int, Params, DataConversion, DataConversion, ComponentRegistry) - Constructor for class org.infinispan.commands.functional.TxReadOnlyKeyCommand
 
TxReadOnlyManyCommand<K,​V,​R> - Class in org.infinispan.commands.functional
 
TxReadOnlyManyCommand() - Constructor for class org.infinispan.commands.functional.TxReadOnlyManyCommand
 
TxReadOnlyManyCommand(Collection<?>, List<List<Mutation<K, V, ?>>>, Params, DataConversion, DataConversion, ComponentRegistry) - Constructor for class org.infinispan.commands.functional.TxReadOnlyManyCommand
 
TxReadOnlyManyCommand(ReadOnlyManyCommand, List<List<Mutation<K, V, ?>>>) - Constructor for class org.infinispan.commands.functional.TxReadOnlyManyCommand
 
txTable - Variable in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
txTable - Variable in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
 
type() - Method in interface org.infinispan.commands.functional.Mutation
 
type() - Method in class org.infinispan.configuration.cache.EvictionConfiguration
Deprecated.
type() - Method in annotation type org.infinispan.jmx.annotations.Parameter
 
type(EvictionType) - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
Deprecated.
Sets the eviction type which can either be COUNT - entries will be evicted when the number of entries exceeds the EvictionConfigurationBuilder.size(long) MEMORY - entries will be evicted when the approximate combined size of all values exceeds the EvictionConfigurationBuilder.size(long) Cache size is guaranteed not to exceed upper limit specified by max entries.
TYPE - org.infinispan.configuration.parsing.Attribute
 
TYPE - Static variable in class org.infinispan.configuration.cache.EvictionConfiguration
Deprecated.
 
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.
 

U

unableToAcquireLock(String, Object, Object, Object) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToAcquireLock(String, Object, Object, Object) - Method in interface org.infinispan.util.logging.Log
 
unableToAcquireLock$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToAddNullCustomStore() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToAddNullCustomStore() - Method in interface org.infinispan.util.logging.Log
 
unableToAddNullCustomStore$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToAddNullEntryMergePolicyFactory() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToAddNullEntryMergePolicyFactory() - Method in interface org.infinispan.util.logging.Log
 
unableToAddNullEntryMergePolicyFactory$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToApplyXSiteState(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToApplyXSiteState(Throwable) - Method in interface org.infinispan.util.logging.Log
 
unableToApplyXSiteState$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToBroadcastInvalidation(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToBroadcastInvalidation(Throwable) - Method in interface org.infinispan.util.logging.Log
 
unableToBroadcastInvalidation$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToCopyEntryForUpdate(Object) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToCopyEntryForUpdate(Object) - Method in interface org.infinispan.util.logging.Log
 
unableToCopyEntryForUpdate$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToCreateInterceptor(Class, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToCreateInterceptor(Class, Exception) - Method in interface org.infinispan.util.logging.Log
 
unableToCreateInterceptor$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToFindLocalTransactionFromRemoteSiteTransaction(GlobalTransaction) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToFindLocalTransactionFromRemoteSiteTransaction(GlobalTransaction) - Method in interface org.infinispan.util.logging.Log
 
unableToFindLocalTransactionFromRemoteSiteTransaction$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToFindRemoteSiteTransaction(GlobalTransaction) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToFindRemoteSiteTransaction(GlobalTransaction) - Method in interface org.infinispan.util.logging.Log
 
unableToFindRemoteSiteTransaction$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToInstantiateClass(Class<?>) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToInstantiateClass(Class<?>) - Method in interface org.infinispan.util.logging.Log
 
unableToInstantiateClass$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToInstantiateSerializer(Class<?>) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToInstantiateSerializer(Class<?>) - Method in interface org.infinispan.util.logging.Log
 
unableToInstantiateSerializer$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToInvokeListenerMethod(Method, Object, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToInvokeListenerMethod(Method, Object, Throwable) - Method in interface org.infinispan.util.logging.Log
 
unableToInvokeListenerMethod$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToInvokeListenerMethodAndRemoveListener(Method, Object, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToInvokeListenerMethodAndRemoveListener(Method, Object, Throwable) - Method in interface org.infinispan.util.logging.Log
 
unableToInvokeListenerMethodAndRemoveListener$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToInvokeWebsphereStaticGetTmMethod(Exception, String) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToInvokeWebsphereStaticGetTmMethod(Exception, String) - Method in interface org.infinispan.util.logging.Log
 
unableToInvokeWebsphereStaticGetTmMethod$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToLockToInvalidate(Object, Address) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToLockToInvalidate(Object, Address) - Method in interface org.infinispan.util.logging.Log
 
unableToLockToInvalidate$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToPassivateEntry(Object, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToPassivateEntry(Object, Exception) - Method in interface org.infinispan.util.logging.Log
 
unableToPassivateEntry$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToProcessAsyncModifications(int) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToProcessAsyncModifications(int) - Method in interface org.infinispan.util.logging.Log
 
unableToProcessAsyncModifications$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToReadVersionId() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToReadVersionId() - Method in interface org.infinispan.util.logging.Log
 
unableToReadVersionId$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRegisterCacheManagerMBeans() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRegisterCacheManagerMBeans() - Method in interface org.infinispan.util.logging.Log
 
unableToRegisterCacheManagerMBeans$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRegisterMBeans() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRegisterMBeans() - Method in interface org.infinispan.util.logging.Log
 
unableToRegisterMBeans(String) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRegisterMBeans(String) - Method in interface org.infinispan.util.logging.Log
 
unableToRegisterMBeans0$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRegisterMBeans1$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRemoveEntryAfterActivation(Object, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRemoveEntryAfterActivation(Object, Exception) - Method in interface org.infinispan.util.logging.Log
 
unableToRemoveEntryAfterActivation$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRollbackEvictionsDuringPrepare(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRollbackEvictionsDuringPrepare(Throwable) - Method in interface org.infinispan.util.logging.Log
 
unableToRollbackEvictionsDuringPrepare$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRollbackGlobalTx(GlobalTransaction, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToRollbackGlobalTx(GlobalTransaction, Throwable) - Method in interface org.infinispan.util.logging.Log
 
unableToRollbackGlobalTx$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToSendXSiteState(String, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToSendXSiteState(String, Throwable) - Method in interface org.infinispan.util.logging.Log
 
unableToSendXSiteState$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToSetValue(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToSetValue(Exception) - Method in interface org.infinispan.util.logging.Log
 
unableToSetValue$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToUnregisterMBeanWithPattern(String, MBeanRegistrationException) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToUnregisterMBeanWithPattern(String, MBeanRegistrationException) - Method in interface org.infinispan.util.logging.Log
 
unableToUnregisterMBeanWithPattern$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unableToUseJGroupsPropertiesProvided(TypedProperties) - Method in class org.infinispan.util.logging.Log_$logger
 
unableToUseJGroupsPropertiesProvided(TypedProperties) - Method in interface org.infinispan.util.logging.Log
 
unableToUseJGroupsPropertiesProvided$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unauthorizedAccess(String, String) - Method in class org.infinispan.util.logging.Log_$logger
 
unauthorizedAccess(String, String) - Method in interface org.infinispan.util.logging.Log
 
unauthorizedAccess$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unavailableTotalOrderWithTxRecovery() - Method in class org.infinispan.util.logging.Log_$logger
 
unavailableTotalOrderWithTxRecovery() - Method in interface org.infinispan.util.logging.Log
 
unavailableTotalOrderWithTxRecovery$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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) - Static method in class org.infinispan.container.impl.DefaultDataContainer
 
UnclosableObjectInputStream - Class in org.infinispan.io
A delegating ObjectInput that delegates all methods except ObjectInput.close().
UnclosableObjectInputStream(ObjectInput) - Constructor for class org.infinispan.io.UnclosableObjectInputStream
 
UnclosableObjectOutputStream - Class in org.infinispan.io
An unclosable version of an ObjectOutput.
UnclosableObjectOutputStream(ObjectOutput) - Constructor for class org.infinispan.io.UnclosableObjectOutputStream
 
undeclaredConfiguration(String, String) - Method in class org.infinispan.util.logging.Log_$logger
 
undeclaredConfiguration(String, String) - Method in interface org.infinispan.util.logging.Log
 
undeclaredConfiguration$str() - Method in class org.infinispan.util.logging.Log_$logger
 
undefineConfiguration(String) - Method in class org.infinispan.manager.DefaultCacheManager
 
undefineConfiguration(String) - Method in interface org.infinispan.manager.EmbeddedCacheManager
Removes a configuration from the set of defined configurations.
undefineConfiguration(String) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
UndefineConfigurationAction - Class in org.infinispan.security.actions
UndefineConfigurationAction.
UndefineConfigurationAction(EmbeddedCacheManager, String) - Constructor for class org.infinispan.security.actions.UndefineConfigurationAction
 
undefinedThreadPoolName(String) - Method in class org.infinispan.util.logging.Log_$logger
 
undefinedThreadPoolName(String) - Method in interface org.infinispan.util.logging.Log
 
undefinedThreadPoolName$str() - Method in class org.infinispan.util.logging.Log_$logger
 
undelegate() - Method in class org.infinispan.persistence.support.DelegatingCacheLoader
 
undelegate() - Method in class org.infinispan.persistence.support.DelegatingCacheWriter
 
undelete(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
Deprecated.
underlyingStream - Variable in class org.infinispan.util.AbstractDelegatingCacheStream
 
unexpected(Response) - Static method in class org.infinispan.interceptors.impl.ClusteringInterceptor
 
unexpectedAttribute(XMLStreamReader, int) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Get an exception reporting an unexpected XML attribute.
unexpectedAttribute(XMLStreamReader, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Get an exception reporting an unexpected XML attribute.
unexpectedAvailabilityMode(AvailabilityMode, CacheTopology) - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
unexpectedAvailabilityMode(AvailabilityMode, CacheTopology) - Method in interface org.infinispan.util.logging.events.Messages
 
unexpectedAvailabilityMode$str() - Method in class org.infinispan.util.logging.events.Messages_$bundle
 
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.util.logging.Log_$logger
 
unexpectedErrorFromResourceManager(Throwable) - Method in interface org.infinispan.util.logging.Log
 
unexpectedErrorFromResourceManager$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unexpectedErrorInAsyncStoreCoordinator(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
unexpectedErrorInAsyncStoreCoordinator(Throwable) - Method in interface org.infinispan.util.logging.Log
 
unexpectedErrorInAsyncStoreCoordinator$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unexpectedErrorReplicating(Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
unexpectedErrorReplicating(Throwable) - Method in interface org.infinispan.util.logging.Log
 
unexpectedErrorReplicating$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unexpectedInitialVersion(String) - Method in class org.infinispan.util.logging.Log_$logger
 
unexpectedInitialVersion(String) - Method in interface org.infinispan.util.logging.Log
 
unexpectedInitialVersion$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unfinishedTransactionsRemain(int, int) - Method in class org.infinispan.util.logging.Log_$logger
 
unfinishedTransactionsRemain(int, int) - Method in interface org.infinispan.util.logging.Log
 
unfinishedTransactionsRemain$str() - Method in class org.infinispan.util.logging.Log_$logger
 
UNHEALTHY - org.infinispan.health.HealthStatus
Given entity is unhealthy.
UnicastEventContext() - Constructor for class org.infinispan.notifications.cachelistener.cluster.impl.BatchingClusterEventManagerImpl.UnicastEventContext
 
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.impl.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.impl.DefaultConsistentHashFactory
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.impl.SyncConsistentHashFactory
 
union(ReplicatedConsistentHash) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
union(ReplicatedConsistentHash, ReplicatedConsistentHash) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory
 
union(ReplicatedConsistentHash, ReplicatedConsistentHash) - Method in class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory
 
union(ScatteredConsistentHash) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
Prefers owners from the second hash -> effectively this will make pendingCH == unionCH (I think)
union(ScatteredConsistentHash, ScatteredConsistentHash) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory
Merges two consistent hash objects that have the same number of segments, numOwners and hash function.
unionCapacityFactors(AbstractConsistentHash) - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
units() - Method in annotation type org.infinispan.jmx.annotations.ManagedAttribute
 
Units - Enum in org.infinispan.jmx.annotations
 
UNKNOWN - org.infinispan.configuration.parsing.Attribute
 
UNKNOWN - org.infinispan.configuration.parsing.Element
 
unknownExternalizerReaderIndex(int) - Method in class org.infinispan.util.logging.Log_$logger
 
unknownExternalizerReaderIndex(int) - Method in interface org.infinispan.util.logging.Log
 
unknownExternalizerReaderIndex$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unknownMigrator(String) - Method in class org.infinispan.util.logging.Log_$logger
 
unknownMigrator(String) - Method in interface org.infinispan.util.logging.Log
 
unknownMigrator$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unknownResponsesFromRemoteCache(Collection<Response>) - Method in class org.infinispan.util.logging.Log_$logger
 
unknownResponsesFromRemoteCache(Collection<Response>) - Method in interface org.infinispan.util.logging.Log
 
unknownResponsesFromRemoteCache$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unknownTransactionConfiguration(TransactionMode, boolean, boolean, boolean) - Method in class org.infinispan.util.logging.Log_$logger
 
unknownTransactionConfiguration(TransactionMode, boolean, boolean, boolean) - Method in interface org.infinispan.util.logging.Log
 
unknownTransactionConfiguration$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unlock(Object, Object) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
 
unlock(Object, Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Releases the lock for the key if the lockOwner is the lock owner.
unlockAll(Collection<?>, Object) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
 
unlockAll(Collection<?>, Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Same as LockManager.unlock(Object, Object) but for multiple keys.
unlockAll(InvocationContext) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
 
unlockAll(InvocationContext) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Same as unlockAll(context.getLockedKeys(), context.getKeyLockOwner();.
unordered() - Method in interface org.infinispan.CacheStream
unordered() - Method in interface org.infinispan.DoubleCacheStream
unordered() - Method in interface org.infinispan.IntCacheStream
unordered() - Method in interface org.infinispan.LongCacheStream
unordered() - Method in class org.infinispan.stream.impl.AbstractCacheStream
 
unordered() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
unordered() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
unordered() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
unordered() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
unordered() - Method in class org.infinispan.stream.impl.local.AbstractLocalCacheStream
 
unordered() - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
unordered() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
UNORDERED - org.infinispan.eviction.EvictionStrategy
Deprecated.
UnorderedOperation<Type,​Stream extends BaseStream<Type,​Stream>> - Class in org.infinispan.stream.impl.intops
Performs unordered operation on a BaseStream
UnorderedOperation() - Constructor for class org.infinispan.stream.impl.intops.UnorderedOperation
 
unpack(InvocationContext, VisitableCommand, Object) - Static method in class org.infinispan.functional.impl.StatsEnvelope
 
unpackCollection(InvocationContext, VisitableCommand, Object) - Static method in class org.infinispan.functional.impl.StatsEnvelope
 
unpackStream(InvocationContext, VisitableCommand, Object) - Static method in class org.infinispan.functional.impl.StatsEnvelope
 
UnpooledOffHeapMemoryAllocator - Class in org.infinispan.container.offheap
Memory allocator that just allocates memory directly using Unsafe.
UnpooledOffHeapMemoryAllocator() - Constructor for class org.infinispan.container.offheap.UnpooledOffHeapMemoryAllocator
 
unrecognizedAttribute(String) - Method in class org.infinispan.util.logging.Log_$logger
 
unrecognizedAttribute(String) - Method in interface org.infinispan.util.logging.Log
 
unrecognizedAttribute$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unregister() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
Stops handling the invocation.
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(String, String) - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
 
unregisterInternalCache(String) - Method in class org.infinispan.registry.impl.InternalCacheRegistryImpl
 
unregisterInternalCache(String) - Method in interface org.infinispan.registry.InternalCacheRegistry
Unregisters an internal cache
unregisterL1WriteSynchronizer(Object, L1WriteSynchronizer) - Method in class org.infinispan.distribution.impl.L1ManagerImpl
 
unregisterL1WriteSynchronizer(Object, L1WriteSynchronizer) - Method in interface org.infinispan.distribution.L1Manager
Unregister the given write synchronizer if present.
unregisterMBeans(Collection<ResourceDMBean>) - Method in class org.infinispan.jmx.AbstractJmxRegistration
 
unregisterMBeans(Collection<ResourceDMBean>) - Method in class org.infinispan.jmx.ComponentsJmxRegistration
Unregisters all the MBeans registered through ComponentsJmxRegistration.registerMBeans(Collection).
unregisterNamedComponentRegistry(String) - Method in class org.infinispan.factories.GlobalComponentRegistry
 
unregisterSegment(int) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
unregisterSegment(int) - Method in interface org.infinispan.scattered.ScatteredVersionManager
unregisterWrite(K) - Method in interface org.infinispan.expiration.ExpirationManager
Deprecated.
since 9.3 There is no reason for this method and is implementation specific
UNRELIABLE_RETURN_VALUES - org.infinispan.configuration.parsing.Attribute
 
UNRELIABLE_RETURN_VALUES - Static variable in class org.infinispan.configuration.cache.UnsafeConfiguration
 
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
 
UNSAFE - org.infinispan.configuration.parsing.Element
 
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
 
UnsuccessfulResponse - Class in org.infinispan.remoting.responses
An unsuccessful response
UnsuccessfulResponse.Externalizer - Class in org.infinispan.remoting.responses
 
unsuccessfulResponseForClusterListeners(Address, Response) - Method in class org.infinispan.util.logging.Log_$logger
 
unsuccessfulResponseForClusterListeners(Address, Response) - Method in interface org.infinispan.util.logging.Log
 
unsuccessfulResponseForClusterListeners$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unsuccessfulResponseRetrievingTransactionsForSegments(Address, Response) - Method in class org.infinispan.util.logging.Log_$logger
 
unsuccessfulResponseRetrievingTransactionsForSegments(Address, Response) - Method in interface org.infinispan.util.logging.Log
 
unsuccessfulResponseRetrievingTransactionsForSegments$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unsupportedAsyncCacheMode(CacheMode) - Method in class org.infinispan.util.logging.Log_$logger
 
unsupportedAsyncCacheMode(CacheMode) - Method in interface org.infinispan.util.logging.Log
 
unsupportedAsyncCacheMode(CacheMode, CacheMode) - Method in class org.infinispan.util.logging.Log_$logger
 
unsupportedAsyncCacheMode(CacheMode, CacheMode) - Method in interface org.infinispan.util.logging.Log
 
unsupportedAsyncCacheMode1$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unsupportedAsyncCacheMode2$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unsupportedConfiguration(String, String) - Method in class org.infinispan.util.logging.Log_$logger
 
unsupportedConfiguration(String, String) - Method in interface org.infinispan.util.logging.Log
 
unsupportedConfiguration$str() - Method in class org.infinispan.util.logging.Log_$logger
 
unsupportedContent(Object) - Method in class org.infinispan.util.logging.Log_$logger
 
unsupportedContent(Object) - Method in interface org.infinispan.util.logging.Log
 
unsupportedContent$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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
 
UnsupportedMergePolicy() - Constructor for class org.infinispan.conflict.MergePolicy.UnsupportedMergePolicy
 
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
 
until() - Method in annotation type org.infinispan.configuration.parsing.Namespace
The last version of the schema where this is supported.
unwrap() - Method in class org.infinispan.distribution.group.impl.GroupingPartitioner
 
unwrap() - Method in class org.infinispan.stream.impl.AbstractCacheStream
 
unwrap() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
unwrap() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
unwrap() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
unwrap() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
unwrapCache(Cache<K, V>) - Static method in class org.infinispan.cache.impl.AbstractDelegatingCache
Fully unwraps a given cache returning the base cache.
unwrapFunctionalManyResultOnOrigin(InvocationContext, List<Object>, Object) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
unwrapFunctionalManyResultOnOrigin(InvocationContext, List<Object>, Object) - Method in class org.infinispan.interceptors.distribution.VersionedDistributionInterceptor
 
unwrapFunctionalResultOnOrigin(InvocationContext, Object, Object) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
unwrapFunctionalResultOnOrigin(InvocationContext, Object, Object) - Method in class org.infinispan.interceptors.distribution.VersionedDistributionInterceptor
 
update(InternalCacheEntry<K, V>, Metadata) - Method in interface org.infinispan.container.impl.InternalEntryFactory
TODO: Adjust javadoc Updates an existing InternalCacheEntry with new metadata.
update(InternalCacheEntry<K, V>, V, Metadata) - Method in interface org.infinispan.container.impl.InternalEntryFactory
update(InternalCacheEntry, Object, Metadata) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
 
update(InternalCacheEntry, Metadata) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
 
UPDATE - Static variable in class org.infinispan.functional.impl.StatsEnvelope
 
updateAvailabilityMode(List<Address>, AvailabilityMode, boolean) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
Enter a new availability mode.
updateAvailabilityMode(List<Address>, AvailabilityMode, boolean) - Method in class org.infinispan.topology.ClusterCacheStatus
 
updateCacheMembers(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).
updateCurrentTopology(List<Address>) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
Use the configured ConsistentHashFactory to create a new CH with the given members, but do not start a rebalance.
updateCurrentTopology(List<Address>) - Method in class org.infinispan.topology.ClusterCacheStatus
 
updateDomain(ComponentsJmxRegistration, MBeanServer, String) - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
 
updateDomain(ComponentsJmxRegistration, MBeanServer, String, CacheManagerJmxRegistration) - Method in class org.infinispan.jmx.CacheJmxRegistration
 
updateFilteredKeys(List<Object>) - Method in class org.infinispan.remoting.inboundhandler.action.ActionState
 
UpdateLastAccessCommand - Class in org.infinispan.commands.remote.expiration
Command that will update the last access time for an entry given the specific time
UpdateLastAccessCommand(ByteString) - Constructor for class org.infinispan.commands.remote.expiration.UpdateLastAccessCommand
 
UpdateLastAccessCommand(ByteString, Object, int, long) - Constructor for class org.infinispan.commands.remote.expiration.UpdateLastAccessCommand
 
updateMembers(CH, List<Address>, Map<Address, Float>) - Method in interface org.infinispan.distribution.ch.ConsistentHashFactory
Updates an existing consistent hash instance to remove owners that are not in the newMembers list.
updateMembers(Collection<Address>) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferCollector
 
updateMembers(DefaultConsistentHash, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
Leavers are removed and segments without owners are assigned new owners.
updateMembers(DefaultConsistentHash, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory
 
updateMembers(ReplicatedConsistentHash, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory
 
updateMembers(ReplicatedConsistentHash, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory
 
updateMembers(ScatteredConsistentHash, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory
Leavers are removed and segments without owners are assigned new owners.
updateMetadata(CacheEntry, Metadata) - Static method in class org.infinispan.metadata.Metadatas
Set the providedMetadata on the cache entry.
updateOnCommunicationFailure(long) - Method in class org.infinispan.xsite.OfflineStatus
 
updatePreloadedEntryVersion(EntryVersion) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
updatePreloadedEntryVersion(EntryVersion) - Method in interface org.infinispan.scattered.ScatteredVersionManager
This is called only during preload.
updatePreviousValue() - Method in interface org.infinispan.container.entries.MVCCEntry
Update the previous value of the entry - set it to current value.
updatePreviousValue() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
updatePreviousValue() - Method in class org.infinispan.container.entries.RepeatableReadEntry
 
updateStatusFromRemoteResponse(Object) - Method in interface org.infinispan.commands.write.WriteCommand
Deprecated.
since 9.1
updateTimeout(long) - Method in class org.infinispan.remoting.inboundhandler.action.ActionState
 
updateTopologiesAfterMerge(CacheTopology, CacheTopology, AvailabilityMode) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
Updates both the stable and the current topologies.
updateTopologiesAfterMerge(CacheTopology, CacheTopology, AvailabilityMode) - Method in class org.infinispan.topology.ClusterCacheStatus
 
updateTopologyId(TopologyAffectedCommand) - Method in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor
 
updatingAvailabilityMode(String, AvailabilityMode, AvailabilityMode, CacheTopology) - Method in class org.infinispan.util.logging.Log_$logger
 
updatingAvailabilityMode(String, AvailabilityMode, AvailabilityMode, CacheTopology) - Method in interface org.infinispan.util.logging.Log
 
updatingAvailabilityMode$str() - Method in class org.infinispan.util.logging.Log_$logger
 
updatingStableTopology(String, CacheTopology) - Method in class org.infinispan.util.logging.Log_$logger
 
updatingStableTopology(String, CacheTopology) - Method in interface org.infinispan.util.logging.Log
 
updatingStableTopology$str() - Method in class org.infinispan.util.logging.Log_$logger
 
updatingTopology(String, CacheTopology, AvailabilityMode) - Method in class org.infinispan.util.logging.Log_$logger
 
updatingTopology(String, CacheTopology, AvailabilityMode) - Method in interface org.infinispan.util.logging.Log
 
updatingTopology$str() - Method in class org.infinispan.util.logging.Log_$logger
 
upgradeLock(Object) - Method in class org.infinispan.util.concurrent.locks.StripedLock
 
uri() - Method in annotation type org.infinispan.configuration.parsing.Namespace
The URI of the namespace.
USE_1_PC_FOR_AUTO_COMMIT_TRANSACTIONS - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
 
USE_LOCK_STRIPING - Static variable in class org.infinispan.configuration.cache.LockingConfiguration
 
USE_SYNCHRONIZATION - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
 
USE_TWO_PHASE_COMMIT - org.infinispan.configuration.parsing.Attribute
 
USE_TWO_PHASE_COMMIT - Static variable in class org.infinispan.configuration.cache.BackupConfiguration
 
use1PcForAutoCommitTransactions() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
Before Infinispan 5.1 you could access the cache both transactionally and non-transactionally.
use1PcForAutoCommitTransactions() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
 
use1PcForAutoCommitTransactions(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
Before Infinispan 5.1 you could access the cache both transactionally and non-transactionally.
useCount - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
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.
USER - org.infinispan.registry.InternalCacheRegistry.Flag
means that this cache is visible to users
useRequestFormat() - Method in interface org.infinispan.notifications.cachelistener.filter.CacheEventConverter
 
UserRaisedFunctionalException - Exception in org.infinispan.util
Thrown when client's code passed as a labda expression in commands such as ComputeIfAbsentCommand raises a exception.
UserRaisedFunctionalException(Throwable) - Constructor for exception org.infinispan.util.UserRaisedFunctionalException
 
useStorageFormat() - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
 
useStorageFormat() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
useStorageFormat() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
useStorageFormat(boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
useSynchronization() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
 
useSynchronization(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
Configures whether the cache registers a synchronization with the transaction manager, or registers itself as an XA resource.
useTwoPhaseCommit(boolean) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
Configures whether the replication happens in a 1PC or 2PC for sync backups.
usingAsyncStore() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
 
usingBatchModeTransactionManager() - Method in class org.infinispan.util.logging.Log_$logger
 
usingBatchModeTransactionManager() - Method in interface org.infinispan.util.logging.Log
 
usingBatchModeTransactionManager$str() - Method in class org.infinispan.util.logging.Log_$logger
 
usingStores() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
 
UuidExternalizer - Class in org.infinispan.marshall.exts
 
UuidExternalizer() - Constructor for class org.infinispan.marshall.exts.UuidExternalizer
 

V

validate() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
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.ContentTypeConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
Deprecated.
 
validate() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
Deprecated.
 
validate() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
Deprecated.
 
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.MemoryConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
 
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.SecurityConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
Deprecated.
 
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
Deprecated.
 
validate() - Method in class org.infinispan.configuration.cache.SyncConfigurationBuilder
Deprecated.
 
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
Deprecated.
 
validate() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.internal.PrivateGlobalConfigurationBuilder
 
validate() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
validate(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.CompatibilityModeConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
validate(GlobalConfiguration) - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
Deprecated.
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
Deprecated.
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
Deprecated.
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.SecurityConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
Deprecated.
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
Deprecated.
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.SyncConfigurationBuilder
Deprecated.
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.VersioningConfigurationBuilder
Deprecated.
 
validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
 
validateAndAddFilterListenerInvocations(Object, AbstractListenerImpl.AbstractInvocationBuilder, Set<Class<? extends Annotation>>) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
 
validateAndAddListenerInvocations(Object, AbstractListenerImpl.AbstractInvocationBuilder) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
Loops through all valid methods on the object passed in, and caches the relevant methods as ListenerInvocation for invocation by reflection.
validateFlags(EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.ImmutableLocalConfigurationStorage
 
validateFlags(EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.OverlayLocalConfigurationStorage
 
validateFlags(EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
 
validateFlags(EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.LocalConfigurationStorage
Checks whether this LocalConfigurationStorage supports the supplied flags.
validOnly() - Static method in class org.infinispan.remoting.transport.impl.MapResponseCollector
 
validOnly() - Static method in class org.infinispan.remoting.transport.impl.SingleResponseCollector
 
validOnly() - Static method in class org.infinispan.remoting.transport.impl.SingletonMapResponseCollector
 
validOnly() - Static method in class org.infinispan.remoting.transport.impl.VoidResponseCollector
 
validOnly(int) - Static method in class org.infinispan.remoting.transport.impl.MapResponseCollector
 
ValidResponse - Class in org.infinispan.remoting.responses
A valid response
ValidResponse() - Constructor for class org.infinispan.remoting.responses.ValidResponse
 
ValidResponseCollector<T> - Class in org.infinispan.remoting.transport
Base class for response collectors, splitting responses into valid responses, exception responses, and target missing.
ValidResponseCollector() - Constructor for class org.infinispan.remoting.transport.ValidResponseCollector
 
ValidSingleResponseCollector<T> - Class in org.infinispan.remoting.transport
 
ValidSingleResponseCollector() - Constructor for class org.infinispan.remoting.transport.ValidSingleResponseCollector
 
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.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 - Variable in class org.infinispan.functional.MetaParam.MetaLong
 
value() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
 
value() - Method in annotation type org.infinispan.configuration.parsing.Namespaces
 
value() - Method in annotation type org.infinispan.configuration.serializing.SerializedWith
 
value() - Method in annotation type org.infinispan.factories.annotations.ComponentName
 
value() - Method in annotation type org.infinispan.factories.scopes.Scope
 
value() - Method in class org.infinispan.functional.impl.StatsEnvelope
 
value() - Method in class org.infinispan.xsite.statetransfer.XSiteState
 
VALUE - org.infinispan.configuration.parsing.Attribute
 
VALUE_DATA_TYPE - org.infinispan.configuration.parsing.Element
 
VALUE_EQUIVALENCE - org.infinispan.configuration.parsing.Attribute
 
VALUE_TRANSFER - org.infinispan.scattered.ScatteredVersionManager.SegmentState
 
valueAllowed(Object) - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
 
valueAllowed(Object) - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareEntryCollection
 
valueAllowed(Object) - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareEntryIterator
 
valueAllowed(Object) - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator
 
ValueAndMetadata() - Constructor for class org.infinispan.cache.impl.SimpleCacheImpl.ValueAndMetadata
 
ValueCacheCollection<K,​V> - Class in org.infinispan.stream.impl.local
CacheCollection that can be used for the values method of a cache.
ValueCacheCollection(Cache<K, V>, CacheSet<CacheEntry<K, V>>) - Constructor for class org.infinispan.stream.impl.local.ValueCacheCollection
 
valueConverter(Class, String) - Static method in class org.infinispan.configuration.parsing.XmlConfigHelper
 
valueDataConversion - Variable in class org.infinispan.commands.functional.ReadOnlyKeyCommand
 
valueDataConversion - Variable in class org.infinispan.commands.functional.ReadOnlyManyCommand
 
valueDataConversion() - Method in interface org.infinispan.commands.functional.Mutation
 
valueDataType() - Method in class org.infinispan.configuration.cache.EncodingConfiguration
 
valueEquivalence() - Method in class org.infinispan.configuration.cache.DataContainerConfiguration
Deprecated.
Equivalence is no longer used. This will be removed in the future. Only returns AnyEquivalence
valueEquivalence(Equivalence<V>) - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
Deprecated.
Equivalence is to be removed (byte[] are directly supported)
valueFromStorage(Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
valueIterated(Object) - Method in class org.infinispan.stream.impl.CompletionRehashPublisherDecorator
 
valueMatcher - Variable in class org.infinispan.commands.write.RemoveCommand
 
valueMatcher(Object) - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.ConstantLambdaExternalizer
 
valueMatcher(Object) - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.LambdaWithMetasExternalizer
 
valueMatcher(Object) - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.SetValueIfEqualsReturnBooleanExternalizer
 
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(int) - Static method in enum org.infinispan.commands.write.ValueMatcher
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.infinispan.configuration.cache.CacheMode
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.infinispan.functional.Param.ExecutionMode
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.infinispan.functional.Param.LockingMode
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.infinispan.functional.Param.PersistenceMode
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.infinispan.functional.Param.ReplicationMode
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.infinispan.functional.Param.StatisticsMode
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.infinispan.notifications.cachelistener.event.Event.Type
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.infinispan.partitionhandling.AvailabilityMode
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.infinispan.topology.CacheTopology.Phase
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.commands.VisitableCommand.LoadType
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.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.BiasAcquisition
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.Index
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.StorageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.configuration.cache.TransactionMode
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.configuration.parsing.Parser.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.configuration.parsing.Parser.TransactionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.configuration.parsing.ParserScope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.conflict.MergePolicy
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.Ownership
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.eviction.EvictionType
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.functional.Param.ExecutionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.functional.Param.LockingMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.functional.Param.PersistenceMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.functional.Param.ReplicationMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.functional.Param.StatisticsMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.globalstate.ConfigurationStorage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.health.HealthStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.interceptors.locking.ClusteringDependentLogic.Commit
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.manager.ClusterExecutionPolicy
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.notifications.Listener.Observation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.partitionhandling.AvailabilityMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.partitionhandling.PartitionHandling
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.persistence.manager.PersistenceManager.AccessMode
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.registry.InternalCacheRegistry.Flag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.remoting.inboundhandler.action.ActionStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.remoting.inboundhandler.action.BaseLockingAction.InternalState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.remoting.inboundhandler.DeliverOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.remoting.inboundhandler.TopologyMode
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.scattered.ScatteredVersionManager.SegmentState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.security.AuditContext
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.security.AuditResponse
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.security.AuthorizationPermission
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.statetransfer.RebalanceType
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.stream.impl.IntermediateType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.stream.impl.StreamRequestCommand.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.topology.CacheTopology.Phase
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.topology.ClusterTopologyManager.ClusterManagerStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.topology.RebalancingStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.transaction.impl.TransactionTable.CompletedTransactionStatus
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.IsolationLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.util.concurrent.locks.LockState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.util.logging.events.EventLogCategory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.infinispan.util.logging.events.EventLogLevel
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.statetransfer.XSiteStateTransferControlCommand.StateTransferControl
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.
valueOrException(Object, Throwable) - Static method in class org.infinispan.interceptors.BaseAsyncInterceptor
Return the value if throwable != null, throw the exception otherwise.
values - Variable in class org.infinispan.interceptors.distribution.VersionedResults
 
values() - Method in class org.infinispan.atomic.impl.AtomicMapProxyImpl
 
values() - Method in class org.infinispan.atomic.impl.FineGrainedAtomicMapProxyImpl
 
values() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
values() - Method in class org.infinispan.cache.impl.CacheImpl
 
values() - Method in class org.infinispan.cache.impl.DecoratedCache
 
values() - Method in class org.infinispan.cache.impl.EncoderCache
 
values() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
values() - Method in interface org.infinispan.Cache
Returns a collection view of the values contained in this cache across the entire cluster.
values() - Static method in enum org.infinispan.commands.VisitableCommand.LoadType
Returns an array containing the constants of this enum type, in the order they are declared.
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() - 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.BiasAcquisition
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.Index
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.StorageType
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.TransactionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.configuration.cache.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() - Static method in enum org.infinispan.configuration.parsing.Parser.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.configuration.parsing.Parser.TransactionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.configuration.parsing.ParserScope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.conflict.MergePolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.infinispan.container.DataContainer
Deprecated.
Please use iterator method if bulk operations are required.
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() - Method in class org.infinispan.container.impl.AbstractDelegatingDataContainer
 
values() - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
values() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
values() - Static method in enum org.infinispan.container.versioning.InequalVersionComparisonResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.context.Flag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.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.Ownership
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() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
NOTE: this method is not supported.
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.eviction.EvictionType
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.functional.Param.ExecutionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.functional.Param.LockingMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.functional.Param.PersistenceMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.functional.Param.ReplicationMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.functional.Param.StatisticsMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.globalstate.ConfigurationStorage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.health.HealthStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.interceptors.locking.ClusteringDependentLogic.Commit
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.manager.ClusterExecutionPolicy
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.notifications.Listener.Observation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.partitionhandling.AvailabilityMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.partitionhandling.PartitionHandling
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.persistence.manager.PersistenceManager.AccessMode
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.registry.InternalCacheRegistry.Flag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.remoting.inboundhandler.action.ActionStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.remoting.inboundhandler.action.BaseLockingAction.InternalState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.remoting.inboundhandler.DeliverOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.remoting.inboundhandler.TopologyMode
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.scattered.ScatteredVersionManager.SegmentState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.security.AuditContext
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.security.AuditResponse
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.security.AuthorizationPermission
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
values() - Static method in enum org.infinispan.statetransfer.RebalanceType
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.stream.impl.IntermediateType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.stream.impl.StreamRequestCommand.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.CacheTopology.Phase
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.topology.ClusterTopologyManager.ClusterManagerStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.topology.RebalancingStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.transaction.impl.TransactionTable.CompletedTransactionStatus
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.IsolationLevel
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.locks.LockState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.util.logging.events.EventLogCategory
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.infinispan.util.logging.events.EventLogLevel
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.statetransfer.XSiteStateTransferControlCommand.StateTransferControl
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.
Values() - Constructor for class org.infinispan.cache.impl.SimpleCacheImpl.Values
 
Values() - Constructor for class org.infinispan.container.impl.AbstractInternalDataContainer.Values
Deprecated.
 
valuesFuture(int) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
valuesFuture(int) - Method in interface org.infinispan.scattered.ScatteredVersionManager
 
valueToStorage(Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
version - Variable in class org.infinispan.container.versioning.SimpleClusteredVersion
 
version - Variable in class org.infinispan.interceptors.distribution.VersionedResult
 
version - Variable in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
version - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl.KeyAndVersion
 
version() - Method in class org.infinispan.configuration.global.SerializationConfiguration
 
version() - Method in class org.infinispan.container.entries.RemoteMetadata
 
version() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
 
version() - Method in class org.infinispan.metadata.EmbeddedMetadata
 
version() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
 
version() - Method in class org.infinispan.metadata.impl.L1Metadata
 
version() - Method in interface org.infinispan.metadata.Metadata
Returns the version of the cache entry with which this metadata object is associated.
version(short) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
Largest allowable version to use when marshalling internal state.
version(String) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
Largest allowable version to use when marshalling internal state.
version(String) - Method in class org.infinispan.util.logging.Log_$logger
 
version(String) - Method in interface org.infinispan.util.logging.Log
 
version(EntryVersion) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata.Builder
 
version(EntryVersion) - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
version(EntryVersion) - Method in interface org.infinispan.metadata.Metadata.Builder
Set version.
Version - Class in org.infinispan
Contains version information about this release of Infinispan.
VERSION - org.infinispan.configuration.parsing.Attribute
 
VERSION - Static variable in class org.infinispan.configuration.global.SerializationConfiguration
 
VERSION - Static variable in class org.infinispan.globalstate.impl.GlobalStateManagerImpl
 
VERSION_MAJOR - Static variable in class org.infinispan.globalstate.impl.GlobalStateManagerImpl
 
version$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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(ByteString) - Constructor for class org.infinispan.commands.tx.VersionedCommitCommand
 
VersionedCommitCommand(ByteString, GlobalTransaction) - 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.impl
Interceptor in charge with wrapping entries and add them in caller's context.
VersionedEntryWrappingInterceptor() - Constructor for class org.infinispan.interceptors.impl.VersionedEntryWrappingInterceptor
 
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(ByteString) - Constructor for class org.infinispan.commands.tx.VersionedPrepareCommand
 
VersionedPrepareCommand(ByteString, GlobalTransaction, List<WriteCommand>, boolean) - Constructor for class org.infinispan.commands.tx.VersionedPrepareCommand
 
VersionedRepeatableReadEntry - Class in org.infinispan.container.entries
A version of RepeatableReadEntry that can perform write-skew checks during prepare.
VersionedRepeatableReadEntry(Object, Object, Metadata) - Constructor for class org.infinispan.container.entries.VersionedRepeatableReadEntry
 
VersionedResult - Class in org.infinispan.interceptors.distribution
 
VersionedResult(Object, EntryVersion) - Constructor for class org.infinispan.interceptors.distribution.VersionedResult
 
VersionedResult.Externalizer - Class in org.infinispan.interceptors.distribution
 
VersionedResults - Class in org.infinispan.interceptors.distribution
 
VersionedResults(Object[], EntryVersion[]) - Constructor for class org.infinispan.interceptors.distribution.VersionedResults
 
VersionedResults.Externalizer - Class in org.infinispan.interceptors.distribution
 
versionGenerator - Variable in class org.infinispan.interceptors.impl.VersionedEntryWrappingInterceptor
 
versionGenerator - Variable in class org.infinispan.interceptors.impl.VersionInterceptor
 
VersionGenerator - Interface in org.infinispan.container.versioning
Generates versions
VersionGeneratorFactory - Class in org.infinispan.factories
Version generator component factory.
VersionGeneratorFactory() - Constructor for class org.infinispan.factories.VersionGeneratorFactory
 
versioning() - Method in class org.infinispan.configuration.cache.Configuration
Deprecated.
since 9.0. Infinispan automatically enables versioning when needed.
versioning() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
versioning() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
Deprecated.
since 9.0. Infinispan automatically enables versioning when needed.
VERSIONING - org.infinispan.configuration.parsing.Element
 
VERSIONING_SCHEME - org.infinispan.configuration.parsing.Attribute
 
VersioningConfiguration - Class in org.infinispan.configuration.cache
Deprecated.
since 9.0. Infinispan automatically enable versioning when needed.
VersioningConfigurationBuilder - Class in org.infinispan.configuration.cache
Deprecated.
since 9.0. Infinispan automatically enable versioning when needed.
VersioningConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.VersioningConfigurationBuilder
Deprecated.
 
VersioningScheme - Enum in org.infinispan.configuration.cache
The various versioning schemes supported
VersionInterceptor - Class in org.infinispan.interceptors.impl
Interceptor installed when compatiblity is enabled.
VersionInterceptor() - Constructor for class org.infinispan.interceptors.impl.VersionInterceptor
 
versions - Variable in class org.infinispan.interceptors.distribution.VersionedResults
 
VIEW_CHANGED - org.infinispan.notifications.cachemanagerlistener.event.Event.Type
 
viewChange(ViewChangedEvent) - Method in class org.infinispan.notifications.cachelistener.cluster.RemoteClusterListener
 
viewChange(ViewChangedEvent) - Method in class org.infinispan.persistence.support.SingletonCacheWriter.SingletonStoreListener
Deprecated.
The cluster formation changed, so determine whether the current cache stopped being the coordinator or became the coordinator.
viewChange(ViewChangedEvent) - Method in class org.infinispan.stream.impl.IteratorHandler
 
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.
viewHandlingError(int, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
viewHandlingError(int, Throwable) - Method in interface org.infinispan.util.logging.Log
 
viewHandlingError$str() - Method in class org.infinispan.util.logging.Log_$logger
 
VisitableCommand - Interface in org.infinispan.commands
A type of command that can accept Visitors, such as DDAsyncInterceptor.
VisitableCommand.LoadType - Enum in org.infinispan.commands
 
visitApplyDeltaCommand(InvocationContext, ApplyDeltaCommand) - Method in interface org.infinispan.commands.Visitor
Deprecated.
visitApplyDeltaCommand(InvocationContext, ApplyDeltaCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
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
Deprecated.
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.impl.BatchingInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.impl.InvalidationInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.impl.PassivationWriterInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.impl.TransactionalExceptionEvictionInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.impl.TxBatchUpdater
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
Deprecated.
 
visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
visitCollection(InvocationContext, Collection<? extends VisitableCommand>) - Method in class org.infinispan.commands.AbstractVisitor
Helper method to visit a collection of VisitableCommands.
visitCommand(InvocationContext, VisitableCommand) - Method in interface org.infinispan.interceptors.AsyncInterceptor
Perform some work for a command invocation.
visitCommand(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.base.CommandInterceptor
Deprecated.
 
visitCommand(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
visitCommand(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.impl.CallInterceptor
 
visitCommand(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.impl.InvocationContextInterceptor
 
visitCommand(InvocationContext, VisitableCommand) - Method in class org.infinispan.statetransfer.TransactionSynchronizerInterceptor
 
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
Deprecated.
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
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.impl.CacheWriterInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.impl.InvalidationInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.impl.NotificationInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.impl.TransactionalExceptionEvictionInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.impl.TransactionalStoreInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.impl.VersionedEntryWrappingInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
 
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.xsite.OptimisticBackupInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.xsite.PessimisticBackupInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
Deprecated.
 
visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in interface org.infinispan.commands.Visitor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
Deprecated.
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.distribution.L1TxInterceptor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseGenerator
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.impl.DistCacheWriterInterceptor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.impl.InvalidationInterceptor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.impl.IsMarshallableInterceptor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
Deprecated.
 
visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in interface org.infinispan.commands.Visitor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
Deprecated.
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.distribution.L1TxInterceptor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseGenerator
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.impl.DistCacheWriterInterceptor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.impl.InvalidationInterceptor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.impl.IsMarshallableInterceptor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
Deprecated.
 
visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
visitDataReadCommand(InvocationContext, DataCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitDataReadCommand(InvocationContext, DataCommand) - Method in class org.infinispan.interceptors.locking.NonTransactionalLockingInterceptor
 
visitDataReadCommand(InvocationContext, DataCommand) - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
 
visitDataReadCommand(InvocationContext, DataCommand) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
 
visitDataWriteCommand(InvocationContext, DataWriteCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitDataWriteCommand(InvocationContext, DataWriteCommand) - Method in class org.infinispan.interceptors.locking.NonTransactionalLockingInterceptor
 
visitDataWriteCommand(InvocationContext, DataWriteCommand) - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
 
visitDataWriteCommand(InvocationContext, DataWriteCommand) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
 
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
 
visitDistributedExecuteCommand(InvocationContext, DistributedExecuteCommand<V>) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
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.DDAsyncInterceptor
 
visitEntrySetCommand(InvocationContext, EntrySetCommand) - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor
 
visitEntrySetCommand(InvocationContext, EntrySetCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
visitEntrySetCommand(InvocationContext, EntrySetCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
visitEntrySetCommand(InvocationContext, EntrySetCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitEntrySetCommand(InvocationContext, EntrySetCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
 
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
Deprecated.
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.impl.BatchingInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
Deprecated.
 
visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitGetAllCommand(InvocationContext, GetAllCommand) - Method in interface org.infinispan.commands.Visitor
 
visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor
 
visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor
 
visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
 
visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in interface org.infinispan.commands.Visitor
 
visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor.LostDataVisitor
 
visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor
 
visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor
 
visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
 
visitGetKeysInGroupCommand(InvocationContext, GetKeysInGroupCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitGetKeysInGroupCommand(InvocationContext, GetKeysInGroupCommand) - Method in interface org.infinispan.commands.Visitor
 
visitGetKeysInGroupCommand(InvocationContext, GetKeysInGroupCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
visitGetKeysInGroupCommand(InvocationContext, GetKeysInGroupCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
visitGetKeysInGroupCommand(InvocationContext, GetKeysInGroupCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitGetKeysInGroupCommand(InvocationContext, GetKeysInGroupCommand) - Method in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor
 
visitGetKeysInGroupCommand(InvocationContext, GetKeysInGroupCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
visitGetKeysInGroupCommand(InvocationContext, GetKeysInGroupCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitGetKeysInGroupCommand(InvocationContext, GetKeysInGroupCommand) - Method in class org.infinispan.interceptors.impl.GroupingInterceptor
 
visitGetKeysInGroupCommand(InvocationContext, GetKeysInGroupCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
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
Deprecated.
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor.LostDataVisitor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
 
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.DDAsyncInterceptor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.interceptors.impl.TransactionalExceptionEvictionInterceptor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
Deprecated.
 
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.DDAsyncInterceptor
 
visitInvalidateL1Command(InvocationContext, InvalidateL1Command) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
visitInvalidateL1Command(InvocationContext, InvalidateL1Command) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitInvalidateL1Command(InvocationContext, InvalidateL1Command) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitInvalidateL1Command(InvocationContext, InvalidateL1Command) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
Deprecated.
 
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.DDAsyncInterceptor
 
visitKeySetCommand(InvocationContext, KeySetCommand) - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor
 
visitKeySetCommand(InvocationContext, KeySetCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
visitKeySetCommand(InvocationContext, KeySetCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
visitKeySetCommand(InvocationContext, KeySetCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitKeySetCommand(InvocationContext, KeySetCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
 
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.DDAsyncInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.impl.InvalidationInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
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.totalorder.TotalOrderInterceptor
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
Deprecated.
 
visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
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
Deprecated.
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
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.impl.CacheWriterInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.impl.InvalidationInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.impl.NotificationInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.impl.TransactionalExceptionEvictionInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.impl.TransactionalStoreInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.impl.VersionedEntryWrappingInterceptor
 
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.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.xsite.BaseBackupInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
Deprecated.
 
visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
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
Deprecated.
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
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.ScatteredDistributionInterceptor.PrimaryResponseGenerator
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.impl.BatchingInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.impl.DistCacheWriterInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.impl.InvalidationInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.impl.IsMarshallableInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.impl.TxBatchUpdater
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
Deprecated.
 
visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
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.base.PrePostProcessingCommandInterceptor
Deprecated.
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
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.ScatteredDistributionInterceptor.PrimaryResponseGenerator
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.impl.DistCacheWriterInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.impl.InvalidationInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.impl.IsMarshallableInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.impl.TxBatchUpdater
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
Deprecated.
 
visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
visitReadOnlyKeyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitReadOnlyKeyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in interface org.infinispan.commands.Visitor
 
visitReadOnlyKeyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
visitReadOnlyKeyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
visitReadOnlyKeyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitReadOnlyKeyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor.LostDataVisitor
 
visitReadOnlyKeyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor
 
visitReadOnlyKeyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
visitReadOnlyKeyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
visitReadOnlyKeyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitReadOnlyKeyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
visitReadOnlyKeyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitReadOnlyKeyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitReadOnlyManyCommand(InvocationContext, ReadOnlyManyCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitReadOnlyManyCommand(InvocationContext, ReadOnlyManyCommand) - Method in interface org.infinispan.commands.Visitor
 
visitReadOnlyManyCommand(InvocationContext, ReadOnlyManyCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
visitReadOnlyManyCommand(InvocationContext, ReadOnlyManyCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
visitReadOnlyManyCommand(InvocationContext, ReadOnlyManyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitReadOnlyManyCommand(InvocationContext, ReadOnlyManyCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
visitReadOnlyManyCommand(InvocationContext, ReadOnlyManyCommand) - Method in class org.infinispan.interceptors.impl.BaseStateTransferInterceptor
 
visitReadOnlyManyCommand(InvocationContext, ReadOnlyManyCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
visitReadOnlyManyCommand(InvocationContext, ReadOnlyManyCommand) - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
visitReadOnlyManyCommand(InvocationContext, ReadOnlyManyCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitReadOnlyManyCommand(InvocationContext, ReadOnlyManyCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
visitReadOnlyManyCommand(InvocationContext, ReadOnlyManyCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitReadOnlyManyCommand(InvocationContext, ReadOnlyManyCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in interface org.infinispan.commands.Visitor
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseGenerator
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.impl.IsMarshallableInterceptor
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.impl.TxBatchUpdater
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
Deprecated.
 
visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in interface org.infinispan.commands.Visitor
 
visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
 
visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseGenerator
 
visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
 
visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
 
visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor
 
visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.impl.TxBatchUpdater
 
visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in interface org.infinispan.commands.Visitor
 
visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
 
visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseGenerator
 
visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
 
visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
 
visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor
 
visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.impl.TxBatchUpdater
 
visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in interface org.infinispan.commands.Visitor
 
visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
 
visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseGenerator
 
visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
 
visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
 
visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor
 
visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.impl.TxBatchUpdater
 
visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
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
Deprecated.
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
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.ScatteredDistributionInterceptor.PrimaryResponseGenerator
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.impl.DistCacheWriterInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.impl.InvalidationInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.impl.IsMarshallableInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.impl.TxBatchUpdater
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
Deprecated.
 
visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
visitRemoveExpiredCommand(InvocationContext, RemoveExpiredCommand) - Method in interface org.infinispan.commands.Visitor
 
visitRemoveExpiredCommand(InvocationContext, RemoveExpiredCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
visitRemoveExpiredCommand(InvocationContext, RemoveExpiredCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitRemoveExpiredCommand(InvocationContext, RemoveExpiredCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
visitRemoveExpiredCommand(InvocationContext, RemoveExpiredCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
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
Deprecated.
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
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.ScatteredDistributionInterceptor.PrimaryResponseGenerator
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.impl.DistCacheWriterInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.impl.InvalidationInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.impl.IsMarshallableInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.impl.TxBatchUpdater
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.impl.VersionInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
Deprecated.
 
visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
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
Deprecated.
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.impl.NotificationInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.impl.TransactionalExceptionEvictionInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.impl.TransactionalStoreInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
 
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.xsite.OptimisticBackupInterceptor
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
Deprecated.
 
visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
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
Deprecated.
 
visitSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
visitSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
visitSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.interceptors.impl.CacheLoaderInterceptor
 
visitSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitUnknownCommand(InvocationContext, VisitableCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitUnknownCommand(InvocationContext, VisitableCommand) - Method in interface org.infinispan.commands.Visitor
 
visitUnknownCommand(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in interface org.infinispan.commands.Visitor
 
visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
 
visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseGenerator
 
visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
 
visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
 
visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor
 
visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.impl.TxBatchUpdater
 
visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in interface org.infinispan.commands.Visitor
 
visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
 
visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseGenerator
 
visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
 
visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
 
visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.impl.CacheMgmtInterceptor
 
visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor
 
visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.impl.TxBatchUpdater
 
visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in interface org.infinispan.commands.Visitor
 
visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
 
visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
 
visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor
 
visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.impl.TxBatchUpdater
 
visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.commands.AbstractVisitor
 
visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in interface org.infinispan.commands.Visitor
 
visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
 
visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
 
visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
 
visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
 
visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
 
visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
 
visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.impl.CacheWriterInterceptor
 
visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.impl.PrefetchInterceptor
 
visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.impl.ScatteredCacheWriterInterceptor
 
visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.impl.TxBatchUpdater
 
visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.impl.TxInterceptor
 
visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
 
visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
 
voidMerge(ValidResponse, Void) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
VoidResponseCollector - Class in org.infinispan.remoting.transport.impl
Response collector that discards successful responses and returns null.
VOLATILE - org.infinispan.globalstate.ConfigurationStorage
A volatile configuration storage provider which doesn't support CacheContainerAdmin.AdminFlag.PERMANENT
VOLATILE_CONFIGURATION_STORAGE - org.infinispan.configuration.parsing.Element
 
VolatileLocalConfigurationStorage - Class in org.infinispan.globalstate.impl
An implementation of LocalConfigurationStorage which does not support CacheContainerAdmin.AdminFlag.PERMANENT operations
VolatileLocalConfigurationStorage() - Constructor for class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
 

W

WAIT_FOR_VALID_RESPONSE - org.infinispan.remoting.rpc.ResponseMode
 
WAIT_TIME - org.infinispan.configuration.parsing.Attribute
 
WAIT_TIME - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
WAIT_TOPOLOGY - org.infinispan.remoting.inboundhandler.TopologyMode
 
WAIT_TX_DATA - org.infinispan.remoting.inboundhandler.TopologyMode
 
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
 
waitForCacheToStabilize(Cache<Object, Object>, Configuration) - Method in class org.infinispan.commands.CreateCacheCommand
 
waitForInitialStateTransferToComplete() - Method in interface org.infinispan.statetransfer.StateTransferManager
 
waitForInitialStateTransferToComplete() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
 
waitForLockRelease(long) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
waitForLockRelease(long) - Method in interface org.infinispan.transaction.xa.CacheTransaction
Deprecated.
waitForTopology(int, long, TimeUnit) - Method in interface org.infinispan.statetransfer.StateTransferLock
Deprecated.
waitForTransactionData(int, long, TimeUnit) - Method in interface org.infinispan.statetransfer.StateTransferLock
Deprecated.
waitForView(int) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
waitForView(int) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
waitForView(int) - Method in interface org.infinispan.remoting.transport.Transport
Deprecated.
Since 9.0, please use Transport.withView(int) instead.
waitFuture(Object) - Method in interface org.infinispan.persistence.manager.OrderedUpdatesManager
 
waitFuture(Object) - Method in class org.infinispan.persistence.manager.OrderedUpdatesManagerImpl
 
WAITING - org.infinispan.util.concurrent.locks.LockState
The lock owner is in the queue waiting for the lock to be available.
waitingForState - Variable in class org.infinispan.statetransfer.StateConsumerImpl
Indicates if there is a rebalance in progress and there the local node has not yet received all the new segments yet.
waitTime() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
waitTime(long) - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
The waiting time (in milliseconds) between each retry.
waitUntilAllCompleted() - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
waitUntilPrepared(boolean) - Method in class org.infinispan.transaction.impl.TotalOrderRemoteTransactionState
Commit and rollback commands invokes this method and they are blocked here if the state is PREPARING
WAKEUP_INTERVAL - Static variable in class org.infinispan.configuration.cache.ExpirationConfiguration
 
wakeupInterval() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
 
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.
warn(EventLogCategory, String) - Method in interface org.infinispan.util.logging.events.EventLogger
Logs a message to the event log using the EventLogLevel.WARN severity
WARN - org.infinispan.configuration.cache.BackupFailurePolicy
 
WARN - org.infinispan.util.logging.events.EventLogLevel
 
warnAboutUberJarDuplicates() - Method in class org.infinispan.util.logging.Log_$logger
 
warnAboutUberJarDuplicates() - Method in interface org.infinispan.util.logging.Log
 
warnAboutUberJarDuplicates$str() - Method in class org.infinispan.util.logging.Log_$logger
 
warnAttemptToOverrideExistingConfiguration(String) - Method in class org.infinispan.util.logging.Log_$logger
 
warnAttemptToOverrideExistingConfiguration(String) - Method in interface org.infinispan.util.logging.Log
 
warnAttemptToOverrideExistingConfiguration$str() - Method in class org.infinispan.util.logging.Log_$logger
 
warnCompatibilityDeprecated(String) - Method in class org.infinispan.util.logging.Log_$logger
 
warnCompatibilityDeprecated(String) - Method in interface org.infinispan.util.logging.Log
 
warnCompatibilityDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
warnConcurrentUpdateSupportCannotBeConfigured() - Method in class org.infinispan.util.logging.Log_$logger
 
warnConcurrentUpdateSupportCannotBeConfigured() - Method in interface org.infinispan.util.logging.Log
 
warnConcurrentUpdateSupportCannotBeConfigured$str() - Method in class org.infinispan.util.logging.Log_$logger
 
warnConfigurationForAnnotationMissing(String) - Method in class org.infinispan.util.logging.Log_$logger
 
warnConfigurationForAnnotationMissing(String) - Method in interface org.infinispan.util.logging.Log
 
warnConfigurationForAnnotationMissing$str() - Method in class org.infinispan.util.logging.Log_$logger
 
warnCouldNotCommitLocalTx(Object, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
warnCouldNotCommitLocalTx(Object, Exception) - Method in interface org.infinispan.util.logging.Log
 
warnCouldNotCommitLocalTx$str() - Method in class org.infinispan.util.logging.Log_$logger
 
warnCouldNotRollbackLocalTx(Object, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
warnCouldNotRollbackLocalTx(Object, Exception) - Method in interface org.infinispan.util.logging.Log
 
warnCouldNotRollbackLocalTx$str() - Method in class org.infinispan.util.logging.Log_$logger
 
warnExceptionRemovingRecovery(Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
warnExceptionRemovingRecovery(Exception) - Method in interface org.infinispan.util.logging.Log
 
warnExceptionRemovingRecovery$str() - Method in class org.infinispan.util.logging.Log_$logger
 
warnFifoStrategyIsDeprecated() - Method in class org.infinispan.util.logging.Log_$logger
 
warnFifoStrategyIsDeprecated() - Method in interface org.infinispan.util.logging.Log
 
warnFifoStrategyIsDeprecated$str() - Method in class org.infinispan.util.logging.Log_$logger
 
warnGridFSMetadataCacheRequiresSync() - Method in class org.infinispan.util.logging.Log_$logger
 
warnGridFSMetadataCacheRequiresSync() - Method in interface org.infinispan.util.logging.Log
 
warnGridFSMetadataCacheRequiresSync$str() - Method in class org.infinispan.util.logging.Log_$logger
 
warnL1NotHavingReaperThread() - Method in class org.infinispan.util.logging.Log_$logger
 
warnL1NotHavingReaperThread() - Method in interface org.infinispan.util.logging.Log
 
warnL1NotHavingReaperThread$str() - Method in class org.infinispan.util.logging.Log_$logger
 
warnStoreAnnotationMissing(String) - Method in class org.infinispan.util.logging.Log_$logger
 
warnStoreAnnotationMissing(String) - Method in interface org.infinispan.util.logging.Log
 
warnStoreAnnotationMissing$str() - Method in class org.infinispan.util.logging.Log_$logger
 
warnXsiteBackupFailed(String, String, Object) - Method in class org.infinispan.util.logging.Log_$logger
 
warnXsiteBackupFailed(String, String, Object) - Method in interface org.infinispan.util.logging.Log
 
warnXsiteBackupFailed$str() - Method in class org.infinispan.util.logging.Log_$logger
 
WHEN_SPLIT - org.infinispan.configuration.parsing.Attribute
 
WHEN_SPLIT - Static variable in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
 
whenSplit() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
 
whenSplit(PartitionHandling) - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
 
who - Variable in class org.infinispan.util.logging.events.impl.DecoratedEventLogger
 
who(String) - Method in interface org.infinispan.util.logging.events.EventLogger
Sets a security name for this event log.
who(String) - Method in class org.infinispan.util.logging.events.impl.BasicEventLogger
 
who(String) - Method in class org.infinispan.util.logging.events.impl.DecoratedEventLogger
 
who(Principal) - Method in interface org.infinispan.util.logging.events.EventLogger
Sets a security principal for this event log.
who(Subject) - Method in interface org.infinispan.util.logging.events.EventLogger
Sets a security subject for this event log.
wildcardsNotAllowedInCacheNames(String) - Method in class org.infinispan.util.logging.Log_$logger
 
wildcardsNotAllowedInCacheNames(String) - Method in interface org.infinispan.util.logging.Log
 
wildcardsNotAllowedInCacheNames$str() - Method in class org.infinispan.util.logging.Log_$logger
 
WildflyTransactionManagerLookup - Class in org.infinispan.transaction.lookup
Wildfly transaction client lookup (WildFly 11 and later).
WildflyTransactionManagerLookup() - Constructor for class org.infinispan.transaction.lookup.WildflyTransactionManagerLookup
 
wired() - Method in interface org.infinispan.factories.impl.ComponentRef
 
wireDependencies(Object) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
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.
wireDependencies(Object, boolean) - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
Look up the dependencies of target as if it were a component, and inject them.
wireDependencies(Object, boolean) - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
 
wireDependencies(CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
wireRealCache() - Method in class org.infinispan.cache.impl.EncoderCache
 
with(ClassLoader) - Method in interface org.infinispan.AdvancedCache
Deprecated.
Since 9.4, the classloader is ignored.
with(ClassLoader) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
with(ClassLoader) - Method in class org.infinispan.cache.impl.CacheImpl
 
with(ClassLoader) - Method in class org.infinispan.cache.impl.DecoratedCache
 
with(ClassLoader) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
with(ClassLoader) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
with(ClassLoader) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
withArguments(Map<?, ?>) - Method in class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
withArguments(Map<?, ?>) - Method in class org.infinispan.commands.functional.WriteOnlyManyEntriesCommand
 
withEncoding(Class<? extends Encoder>) - Method in interface org.infinispan.AdvancedCache
Performs any cache operations using the specified Encoder.
withEncoding(Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
withEncoding(Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.CacheImpl
 
withEncoding(Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
withEncoding(Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.EncoderCache
 
withEncoding(Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
withEncoding(Class<? extends Encoder>) - Method in class org.infinispan.encoding.DataConversion
 
withEncoding(Class<? extends Encoder>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
withEncoding(Class<? extends Encoder>, Class<? extends Encoder>) - Method in interface org.infinispan.AdvancedCache
Performs any cache operations using the specified pair of Encoder.
withEncoding(Class<? extends Encoder>, Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
withEncoding(Class<? extends Encoder>, Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.CacheImpl
 
withEncoding(Class<? extends Encoder>, Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
withEncoding(Class<? extends Encoder>, Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.EncoderCache
 
withEncoding(Class<? extends Encoder>, Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
withEncoding(Class<? extends Encoder>, Class<? extends Encoder>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
withException(Address, Exception) - Method in class org.infinispan.remoting.transport.ValidSingleResponseCollector
 
withFlags(Collection<Flag>) - Method in interface org.infinispan.AdvancedCache
An alternative to AdvancedCache.withFlags(Flag...) not requiring array allocation.
withFlags(Collection<Flag>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
withFlags(Collection<Flag>) - Method in class org.infinispan.cache.impl.CacheImpl
 
withFlags(Collection<Flag>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
withFlags(Collection<Flag>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
withFlags(Collection<Flag>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
withFlags(EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.manager.DefaultCacheManagerAdmin
 
withFlags(CacheContainerAdmin.AdminFlag...) - Method in class org.infinispan.manager.DefaultCacheManagerAdmin
 
withFlags(Flag...) - Method in interface org.infinispan.AdvancedCache
A method that adds flags to any API call.
withFlags(Flag...) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
withFlags(Flag...) - Method in class org.infinispan.cache.impl.CacheImpl
 
withFlags(Flag...) - Method in class org.infinispan.cache.impl.DecoratedCache
 
withFlags(Flag...) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
withFlags(Flag...) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
withFlags(Flag...) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
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
 
withKeyEncoding(Class<? extends Encoder>) - Method in interface org.infinispan.AdvancedCache
 
withKeyEncoding(Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
withKeyEncoding(Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.CacheImpl
 
withKeyEncoding(Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.EncoderCache
 
withKeyEncoding(Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
withKeyEncoding(Class<? extends Encoder>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
withKeys(Collection<?>) - Method in class org.infinispan.commands.functional.ReadOnlyManyCommand
 
withKeys(Collection<?>) - Method in class org.infinispan.commands.functional.ReadWriteManyCommand
 
withKeys(Collection<?>) - Method in class org.infinispan.commands.functional.WriteOnlyManyCommand
 
withMap(Map<Object, Object>) - Method in class org.infinispan.commands.write.PutMapCommand
 
withMediaType(String, String) - Method in interface org.infinispan.AdvancedCache
Perform any cache operations using an alternate MediaType.
withMediaType(String, String) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
withMediaType(String, String) - Method in class org.infinispan.cache.impl.CacheImpl
 
withMediaType(String, String) - Method in class org.infinispan.cache.impl.EncoderCache
 
withMediaType(String, String) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
withMediaType(String, String) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
withParams(Param<?>...) - Method in interface org.infinispan.functional.FunctionalMap.ReadOnlyMap
Tweak read-only functional map executions providing Param instances.
withParams(Param<?>...) - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
Tweak read-write functional map executions providing Param instances.
withParams(Param<?>...) - Method in interface org.infinispan.functional.FunctionalMap
Tweak functional map executions providing Param instances.
withParams(Param<?>...) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Tweak write-only functional map executions providing Param instances.
withParams(Param<?>...) - Method in class org.infinispan.functional.impl.FunctionalMapImpl
 
withParams(Param<?>...) - Method in class org.infinispan.functional.impl.ReadOnlyMapImpl
 
withParams(Param<?>...) - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
 
withParams(Param<?>...) - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
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
Deprecated.
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
withRequestMediaType(MediaType) - Method in class org.infinispan.encoding.DataConversion
 
withSubject(Subject) - Method in interface org.infinispan.AdvancedCache
Performs any cache operations using the specified Subject.
withSubject(Subject) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
withSubject(Subject) - Method in class org.infinispan.cache.impl.CacheImpl
 
withSubject(Subject) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
withSubject(Subject) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
withValidResponse(Address, ValidResponse) - Method in class org.infinispan.remoting.transport.impl.SingleResponseCollector
 
withValidResponse(Address, ValidResponse) - Method in class org.infinispan.remoting.transport.impl.SingletonMapResponseCollector
 
withValidResponse(Address, ValidResponse) - Method in class org.infinispan.remoting.transport.ValidSingleResponseCollector
 
withView(int) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
withView(int) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
withView(int) - Method in interface org.infinispan.remoting.transport.Transport
 
withWrapping(Class<? extends Wrapper>) - Method in interface org.infinispan.AdvancedCache
Performs any cache operations using the specified Wrapper.
withWrapping(Class<? extends Wrapper>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
withWrapping(Class<? extends Wrapper>) - Method in class org.infinispan.cache.impl.CacheImpl
 
withWrapping(Class<? extends Wrapper>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
withWrapping(Class<? extends Wrapper>) - Method in class org.infinispan.cache.impl.EncoderCache
 
withWrapping(Class<? extends Wrapper>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
withWrapping(Class<? extends Wrapper>) - Method in class org.infinispan.encoding.DataConversion
 
withWrapping(Class<? extends Wrapper>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
withWrapping(Class<? extends Wrapper>, Class<? extends Wrapper>) - Method in interface org.infinispan.AdvancedCache
Performs any cache operations using the specified pair of Wrapper.
withWrapping(Class<? extends Wrapper>, Class<? extends Wrapper>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
withWrapping(Class<? extends Wrapper>, Class<? extends Wrapper>) - Method in class org.infinispan.cache.impl.CacheImpl
 
withWrapping(Class<? extends Wrapper>, Class<? extends Wrapper>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
withWrapping(Class<? extends Wrapper>, Class<? extends Wrapper>) - Method in class org.infinispan.cache.impl.EncoderCache
 
withWrapping(Class<? extends Wrapper>, Class<? extends Wrapper>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
withWrapping(Class<? extends Wrapper>, Class<? extends Wrapper>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
wouldLose(DldGlobalTransaction) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
Deprecated.
 
wrap(AdvancedCache<K, V>) - Method in interface org.infinispan.cache.impl.AbstractDelegatingAdvancedCache.AdvancedCacheWrapper
 
wrap(AdvancedCache<K, V>, AdvancedCache<K, V>) - Method in interface org.infinispan.cache.impl.AbstractDelegatingAdvancedCache.AdvancedCacheWrapper
 
wrapEntriesForPrepareAndApply(TxInvocationContext, PrepareCommand, InvocationSuccessFunction) - Method in class org.infinispan.interceptors.impl.EntryWrappingInterceptor
 
wrapEntryForExpired(InvocationContext, Object, int, boolean) - Method in interface org.infinispan.container.impl.EntryFactory
Insert an entry that exists in the data container into the context, even if it is expired Doesn't do anything if the key was already wrapped
wrapEntryForExpired(InvocationContext, Object, int, boolean) - Method in class org.infinispan.container.impl.EntryFactoryImpl
 
wrapEntryForReading(InvocationContext, Object, int, boolean) - Method in interface org.infinispan.container.impl.EntryFactory
Wraps an entry for reading.
wrapEntryForReading(InvocationContext, Object, int, boolean) - Method in class org.infinispan.container.impl.EntryFactoryImpl
 
wrapEntryForWriting(InvocationContext, Object, int, boolean, boolean) - Method in interface org.infinispan.container.impl.EntryFactory
Insert an entry that exists in the data container into the context.
wrapEntryForWriting(InvocationContext, Object, int, boolean, boolean) - Method in class org.infinispan.container.impl.EntryFactoryImpl
 
wrapExternalEntry(InvocationContext, Object, CacheEntry, boolean, boolean) - Method in interface org.infinispan.container.impl.EntryFactory
Insert an external entry (e.g.
wrapExternalEntry(InvocationContext, Object, CacheEntry, boolean, boolean) - Method in class org.infinispan.container.impl.EntryFactoryImpl
 
wrapFunctionalManyResultOnNonOrigin(InvocationContext, Collection<?>, Object[]) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
wrapFunctionalManyResultOnNonOrigin(InvocationContext, Collection<?>, Object[]) - Method in class org.infinispan.interceptors.distribution.VersionedDistributionInterceptor
 
wrapFunctionalResultOnNonOriginOnReturn(Object, CacheEntry) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
wrapFunctionalResultOnNonOriginOnReturn(Object, CacheEntry) - Method in class org.infinispan.interceptors.distribution.VersionedDistributionInterceptor
 
WrappedByteArrayOrPrimitiveMapper - Class in org.infinispan.persistence.keymappers
This class is an implementation for TwoWayKey2StringMapper that supports both primitives and WrappedByteArrays.
WrappedByteArrayOrPrimitiveMapper() - Constructor for class org.infinispan.persistence.keymappers.WrappedByteArrayOrPrimitiveMapper
 
WrappedByteArraySizeCalculator<K,​V> - Class in org.infinispan.marshall.core
Size calculator that supports a WrappedByteArray by adding its size and the underlying byte[].
WrappedByteArraySizeCalculator(EntrySizeCalculator<?, ?>) - Constructor for class org.infinispan.marshall.core.WrappedByteArraySizeCalculator
 
wrapperClassNotFound(Class<?>) - Method in class org.infinispan.util.logging.Log_$logger
 
wrapperClassNotFound(Class<?>) - Method in interface org.infinispan.util.logging.Log
 
wrapperClassNotFound$str() - Method in class org.infinispan.util.logging.Log_$logger
 
wrapperIdNotFound(byte) - Method in class org.infinispan.util.logging.Log_$logger
 
wrapperIdNotFound(byte) - Method in interface org.infinispan.util.logging.Log
 
wrapperIdNotFound$str() - Method in class org.infinispan.util.logging.Log_$logger
 
wrapRemoteEntry(InvocationContext, Object, CacheEntry, boolean) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
 
wrapRemoteEntry(InvocationContext, Object, CacheEntry, boolean) - Method in class org.infinispan.interceptors.distribution.VersionedDistributionInterceptor
 
wrapRemoteException(Address, Throwable) - Static method in class org.infinispan.remoting.transport.ResponseCollectors
 
writable() - Method in annotation type org.infinispan.jmx.annotations.ManagedAttribute
 
WritableGridFileChannel - Class in org.infinispan.io
 
write(byte[]) - Method in class org.infinispan.io.GridOutputStream
 
write(byte[]) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
write(byte[], int, int) - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
 
write(byte[], int, int) - Method in class org.infinispan.io.ExposedByteArrayOutputStream
Deprecated.
 
write(byte[], int, int) - Method in class org.infinispan.io.GridOutputStream
 
write(byte[], int, int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
write(int) - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
 
write(int) - Method in class org.infinispan.io.ExposedByteArrayOutputStream
Deprecated.
 
write(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(int, MarshalledEntry<? extends K, ? extends V>) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
Persists the entry to the storage with the given segment to optimize further lookups based on
write(int, MarshalledEntry<? extends K, ? extends V>) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
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.support.DelegatingCacheWriter
 
write(MarshalledEntry) - Method in class org.infinispan.persistence.support.SingletonCacheWriter
Deprecated.
 
write(MarshalledEntry<? extends K, ? extends V>) - Method in class org.infinispan.persistence.file.SingleFileStore
 
write(MarshalledEntry<? extends K, ? extends V>) - Method in interface org.infinispan.persistence.spi.CacheWriter
Persists the entry to the storage.
write(MarshalledEntry<? extends K, ? extends V>) - Method in class org.infinispan.persistence.support.AbstractSegmentedAdvancedLoadWriteStore
 
WRITE - org.infinispan.security.AuthorizationPermission
Allows writing data to a cache
WRITE_BEHIND - org.infinispan.configuration.parsing.Element
 
WRITE_SKEW_CHECK - org.infinispan.configuration.parsing.Attribute
 
WRITE_SKEW_CHECK - Static variable in class org.infinispan.configuration.cache.LockingConfiguration
 
WriteableCacheCollectionMapper<E,​R> - Class in org.infinispan.util
A writeable cache collection mapper that also has constant time operations for things such as Collection.contains(Object) if the underlying Collection does.
WriteableCacheCollectionMapper(CacheCollection<E>, Function<? super E, ? extends R>, Function<? super E, ? extends R>, Function<? super R, ? extends E>, InjectiveFunction<Object, ?>) - Constructor for class org.infinispan.util.WriteableCacheCollectionMapper
 
WriteableCacheCollectionMapper(CacheCollection<E>, Function<? super E, ? extends R>, Function<? super R, ? extends E>, InjectiveFunction<Object, ?>) - Constructor for class org.infinispan.util.WriteableCacheCollectionMapper
 
WriteableCacheSetMapper<E,​R> - Class in org.infinispan.util
A writeable cache set mapper that also has constant time operations for things such as Collection.contains(Object) if the underlying Set does.
WriteableCacheSetMapper(CacheSet<E>, InjectiveFunction<? super E, ? extends R>, InjectiveFunction<? super E, ? extends R>, InjectiveFunction<? super R, ? extends E>, InjectiveFunction<Object, ?>) - Constructor for class org.infinispan.util.WriteableCacheSetMapper
 
WriteableCacheSetMapper(CacheSet<E>, InjectiveFunction<? super E, ? extends R>, InjectiveFunction<? super R, ? extends E>, InjectiveFunction<Object, ?>) - Constructor for class org.infinispan.util.WriteableCacheSetMapper
 
writeAttribute(Enum<?>, String) - Method in interface org.infinispan.configuration.serializing.XMLExtendedStreamWriter
 
writeAttribute(Enum<?>, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeAttribute(String, Iterable<String>) - Method in interface org.infinispan.configuration.serializing.XMLExtendedStreamWriter
 
writeAttribute(String, Iterable<String>) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeAttribute(String, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeAttribute(String, String[]) - Method in interface org.infinispan.configuration.serializing.XMLExtendedStreamWriter
 
writeAttribute(String, String[]) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeAttribute(String, String, Iterable<String>) - Method in interface org.infinispan.configuration.serializing.XMLExtendedStreamWriter
 
writeAttribute(String, String, Iterable<String>) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeAttribute(String, String, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeAttribute(String, String, String[]) - Method in interface org.infinispan.configuration.serializing.XMLExtendedStreamWriter
 
writeAttribute(String, String, String[]) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeAttribute(String, String, String, Iterable<String>) - Method in interface org.infinispan.configuration.serializing.XMLExtendedStreamWriter
 
writeAttribute(String, String, String, Iterable<String>) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeAttribute(String, String, String, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeAttribute(String, String, String, String[]) - Method in interface org.infinispan.configuration.serializing.XMLExtendedStreamWriter
 
writeAttribute(String, String, String, String[]) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeBackups() - Method in class org.infinispan.distribution.DistributionInfo
 
writeBatch(Iterable) - Method in class org.infinispan.persistence.async.AsyncCacheWriter
 
writeBatch(Iterable<MarshalledEntry<? extends K, ? extends V>>) - Method in interface org.infinispan.persistence.spi.CacheWriter
Persist all provided entries to the store in a single batch update.
writeBatch(Iterable<MarshalledEntry<? extends K, ? extends V>>) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
writeBatchToAllNonTxStores(Iterable<MarshalledEntry>, Predicate<? super StoreConfiguration>, long) - Method in interface org.infinispan.persistence.manager.PersistenceManager
Write all entries to the underlying non-transactional stores as a single batch.
writeBatchToAllNonTxStores(Iterable<MarshalledEntry>, Predicate<? super StoreConfiguration>, long) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
writeBatchToAllNonTxStores(Iterable<MarshalledEntry>, Predicate<? super StoreConfiguration>, long) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
writeBoolean(boolean) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeByte(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeBytes(String) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeCData(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeChar(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeCharacters(char[], int, int) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeCharacters(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
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
 
writeComment(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeCommonStoreElements(XMLExtendedStreamWriter, StoreConfiguration) - Method in class org.infinispan.configuration.serializing.AbstractStoreSerializer
 
writeCommonStoreSubAttributes(XMLExtendedStreamWriter, AbstractStoreConfiguration) - Method in class org.infinispan.configuration.serializing.AbstractStoreSerializer
 
writeContext(int) - Method in class org.infinispan.cache.impl.DecoratedCache
 
writeDefaultNamespace(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeDouble(double) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeDTD(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeEmptyElement(Enum<?>) - Method in interface org.infinispan.configuration.serializing.XMLExtendedStreamWriter
 
writeEmptyElement(Enum<?>) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeEmptyElement(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeEmptyElement(String, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeEmptyElement(String, String, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeEndDocument() - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeEndElement() - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeEntityRef(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeExternal(ObjectOutput) - Method in class org.infinispan.io.GridFile.Metadata
 
writeFloat(float) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeGlobalState() - Method in interface org.infinispan.globalstate.GlobalStateManager
Persists the global state by contacting all registered scope providers
writeGlobalState() - Method in class org.infinispan.globalstate.impl.GlobalStateManagerImpl
 
writeInt(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeLong(long) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeNamespace(String, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.filter.CacheFilters.CacheFiltersExternalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.ConstantLambdaExternalizer
 
writeObject(ObjectOutput, Object) - Method in class org.infinispan.stream.StreamMarshalling.StreamMarshallingExternalizer
 
writeObject(ObjectOutput, Collection) - Method in class org.infinispan.marshall.exts.CollectionExternalizer
 
writeObject(ObjectOutput, DoubleSummaryStatistics) - Method in class org.infinispan.marshall.exts.DoubleSummaryStatisticsExternalizer
 
writeObject(ObjectOutput, IntSummaryStatistics) - Method in class org.infinispan.marshall.exts.IntSummaryStatisticsExternalizer
 
writeObject(ObjectOutput, LongSummaryStatistics) - Method in class org.infinispan.marshall.exts.LongSummaryStatisticsExternalizer
 
writeObject(ObjectOutput, Map) - Method in class org.infinispan.marshall.exts.MapExternalizer
 
writeObject(ObjectOutput, Optional) - Method in class org.infinispan.marshall.exts.OptionalExternalizer
 
writeObject(ObjectOutput, Set) - Method in class org.infinispan.marshall.exts.EnumSetExternalizer
 
writeObject(ObjectOutput, UUID) - Method in class org.infinispan.marshall.exts.UuidExternalizer
 
writeObject(ObjectOutput, DeltaCompositeKey) - Method in class org.infinispan.atomic.DeltaCompositeKey.DeltaCompositeKeyExternalizer
Deprecated.
 
writeObject(ObjectOutput, ApplyDelta) - Method in class org.infinispan.atomic.impl.ApplyDelta.Externalizer
Deprecated.
 
writeObject(ObjectOutput, AtomicKeySetImpl) - Method in class org.infinispan.atomic.impl.AtomicKeySetImpl.Externalizer
 
writeObject(ObjectOutput, AtomicKeySetImpl.Externalizable) - Method in class org.infinispan.atomic.impl.AtomicKeySetImpl.FunctionExternalizer
 
writeObject(ObjectOutput, AtomicMapProxyImpl.ExternalizableFunction) - Method in class org.infinispan.atomic.impl.AtomicMapProxyImpl.Externalizer
 
writeObject(ObjectOutput, EncoderEntryMapper) - Method in class org.infinispan.cache.impl.EncoderEntryMapper.Externalizer
 
writeObject(ObjectOutput, EncoderKeyMapper) - Method in class org.infinispan.cache.impl.EncoderKeyMapper.Externalizer
 
writeObject(ObjectOutput, EncoderValueMapper) - Method in class org.infinispan.cache.impl.EncoderValueMapper.Externalizer
 
writeObject(ObjectOutput, MergeFunction) - Method in class org.infinispan.commands.functional.functions.MergeFunction.Externalizer
 
writeObject(ObjectOutput, CacheRpcCommand) - Method in class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
 
writeObject(ObjectOutput, CacheRpcCommand) - Method in class org.infinispan.marshall.exts.TriangleAckExternalizer
 
writeObject(ObjectOutput, ReplicableCommand) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
writeObject(ObjectOutput, IntSet) - Method in class org.infinispan.util.IntSetExternalizer
 
writeObject(ObjectOutput, BiFunctionMapper) - Method in class org.infinispan.compat.BiFunctionMapper.Externalizer
 
writeObject(ObjectOutput, FunctionMapper) - Method in class org.infinispan.compat.FunctionMapper.Externalizer
 
writeObject(ObjectOutput, ImmortalCacheEntry) - Method in class org.infinispan.container.entries.ImmortalCacheEntry.Externalizer
 
writeObject(ObjectOutput, ImmortalCacheValue) - Method in class org.infinispan.container.entries.ImmortalCacheValue.Externalizer
 
writeObject(ObjectOutput, 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, RemoteMetadata) - Method in class org.infinispan.container.entries.RemoteMetadata.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, DefaultConsistentHashFactory) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Externalizer
 
writeObject(ObjectOutput, ReplicatedConsistentHashFactory) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory.Externalizer
 
writeObject(ObjectOutput, ScatteredConsistentHashFactory) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Externalizer
 
writeObject(ObjectOutput, SyncConsistentHashFactory) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Externalizer
 
writeObject(ObjectOutput, SyncReplicatedConsistentHashFactory) - Method in class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory.Externalizer
 
writeObject(ObjectOutput, TopologyAwareConsistentHashFactory) - Method in class org.infinispan.distribution.ch.impl.TopologyAwareConsistentHashFactory.Externalizer
 
writeObject(ObjectOutput, TopologyAwareSyncConsistentHashFactory) - Method in class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory.Externalizer
 
writeObject(ObjectOutput, DataConversion) - Method in class org.infinispan.encoding.DataConversion.Externalizer
 
writeObject(ObjectOutput, AcceptAllKeyValueFilter) - Method in class org.infinispan.filter.AcceptAllKeyValueFilter.Externalizer
 
writeObject(ObjectOutput, CollectionKeyFilter) - Method in class org.infinispan.filter.CollectionKeyFilter.Externalizer
 
writeObject(ObjectOutput, CompositeKeyFilter) - Method in class org.infinispan.filter.CompositeKeyFilter.Externalizer
 
writeObject(ObjectOutput, CompositeKeyValueFilter) - Method in class org.infinispan.filter.CompositeKeyValueFilter.Externalizer
 
writeObject(ObjectOutput, KeyFilterAsKeyValueFilter) - Method in class org.infinispan.filter.KeyFilterAsKeyValueFilter.Externalizer
 
writeObject(ObjectOutput, KeyValueFilterAsKeyFilter) - Method in class org.infinispan.filter.KeyValueFilterAsKeyFilter.Externalizer
 
writeObject(ObjectOutput, EntryViews.NoValueReadOnlyView) - Method in class org.infinispan.functional.impl.EntryViews.NoValueReadOnlyViewExternalizer
 
writeObject(ObjectOutput, EntryViews.ReadOnlySnapshotView) - Method in class org.infinispan.functional.impl.EntryViews.ReadOnlySnapshotViewExternalizer
 
writeObject(ObjectOutput, EntryViews.ReadWriteSnapshotView) - Method in class org.infinispan.functional.impl.EntryViews.ReadWriteSnapshotViewExternalizer
 
writeObject(ObjectOutput, MetaParamsInternalMetadata) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata.Externalizer
 
writeObject(ObjectOutput, Params) - Static method in class org.infinispan.functional.impl.Params
 
writeObject(ObjectOutput, StatsEnvelope) - Method in class org.infinispan.functional.impl.StatsEnvelope.Externalizer
 
writeObject(ObjectOutput, MetaParam.MetaEntryVersion) - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.EntryVersionParamExternalizer
 
writeObject(ObjectOutput, MetaParam.MetaLifespan) - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.LifespanExternalizer
 
writeObject(ObjectOutput, MetaParam.MetaMaxIdle) - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.MaxIdleExternalizer
 
writeObject(ObjectOutput, CacheState) - Method in class org.infinispan.globalstate.impl.CacheState.Externalizer
 
writeObject(ObjectOutput, ScopedState) - Method in class org.infinispan.globalstate.ScopedState.Externalizer
 
writeObject(ObjectOutput, ScopeFilter) - Method in class org.infinispan.globalstate.ScopeFilter.Externalizer
 
writeObject(ObjectOutput, VersionedResult) - Method in class org.infinispan.interceptors.distribution.VersionedResult.Externalizer
 
writeObject(ObjectOutput, VersionedResults) - Method in class org.infinispan.interceptors.distribution.VersionedResults.Externalizer
 
writeObject(ObjectOutput, MarshallableFunctions.LambdaWithMetas) - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.LambdaWithMetasExternalizer
 
writeObject(ObjectOutput, MarshallableFunctions.SetValueIfEqualsReturnBoolean) - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.SetValueIfEqualsReturnBooleanExternalizer
 
writeObject(ObjectOutput, MarshalledEntryImpl) - Method in class org.infinispan.marshall.core.MarshalledEntryImpl.Externalizer
 
writeObject(ObjectOutput, EmbeddedMetadata) - Method in class org.infinispan.metadata.EmbeddedMetadata.Externalizer
 
writeObject(ObjectOutput, InternalMetadataImpl) - Method in class org.infinispan.metadata.impl.InternalMetadataImpl.Externalizer
 
writeObject(ObjectOutput, ClusterEvent) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent.Externalizer
 
writeObject(ObjectOutput, ClusterEventCallable) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEventCallable.Externalizer
 
writeObject(ObjectOutput, ClusterListenerRemoveCallable) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerRemoveCallable.Externalizer
 
writeObject(ObjectOutput, ClusterListenerReplicateCallable) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerReplicateCallable.Externalizer
 
writeObject(ObjectOutput, MultiClusterEventCallable) - Method in class org.infinispan.notifications.cachelistener.cluster.MultiClusterEventCallable.Externalizer
 
writeObject(ObjectOutput, CacheEventConverterAsConverter) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventConverterAsConverter.Externalizer
 
writeObject(ObjectOutput, CacheEventFilterAsKeyValueFilter) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterAsKeyValueFilter.Externalizer
 
writeObject(ObjectOutput, CacheEventFilterConverterAsKeyValueFilterConverter) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverterAsKeyValueFilterConverter.Externalizer
 
writeObject(ObjectOutput, KeyFilterAsCacheEventFilter) - Method in class org.infinispan.notifications.cachelistener.filter.KeyFilterAsCacheEventFilter.Externalizer
 
writeObject(ObjectOutput, KeyValueFilterAsCacheEventFilter) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterAsCacheEventFilter.Externalizer
 
writeObject(ObjectOutput, KeyValueFilterConverterAsCacheEventFilterConverter) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter.Externalizer
 
writeObject(ObjectOutput, AvailabilityMode) - Method in class org.infinispan.partitionhandling.AvailabilityMode.Externalizer
 
writeObject(ObjectOutput, MIMECacheEntry) - Method in class org.infinispan.remoting.MIMECacheEntry.Externalizer
 
writeObject(ObjectOutput, BiasRevocationResponse) - Method in class org.infinispan.remoting.responses.BiasRevocationResponse.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, StateChunk) - Method in class org.infinispan.statetransfer.StateChunk.Externalizer
 
writeObject(ObjectOutput, TransactionInfo) - Method in class org.infinispan.statetransfer.TransactionInfo.Externalizer
 
writeObject(ObjectOutput, EndIterator) - Method in class org.infinispan.stream.impl.EndIterator.EndIteratorExternalizer
 
writeObject(ObjectOutput, IntermediateOperation) - Method in class org.infinispan.stream.impl.AbstractCacheStream.MapOpsExternalizer
 
writeObject(ObjectOutput, IntermediateOperation) - Method in class org.infinispan.stream.impl.intops.IntermediateOperationExternalizer
 
writeObject(ObjectOutput, IteratorResponses) - Method in class org.infinispan.stream.impl.IteratorResponses.IteratorResponsesExternalizer
 
writeObject(ObjectOutput, BaseTerminalOperation) - Method in class org.infinispan.stream.impl.termop.TerminalOperationExternalizer
 
writeObject(ObjectOutput, CacheJoinInfo) - Method in class org.infinispan.topology.CacheJoinInfo.Externalizer
 
writeObject(ObjectOutput, CacheStatusResponse) - Method in class org.infinispan.topology.CacheStatusResponse.Externalizer
 
writeObject(ObjectOutput, PersistentUUID) - Method in class org.infinispan.topology.PersistentUUID.Externalizer
 
writeObject(ObjectOutput, DldGlobalTransaction) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction.Externalizer
Deprecated.
 
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
Deprecated.
 
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
Deprecated.
 
writeObject(ObjectOutput, ByteString) - Static method in class org.infinispan.util.ByteString
 
writeObject(ObjectOutput, KeyValuePair) - Method in class org.infinispan.util.KeyValuePair.Externalizer
 
writeObject(ObjectOutput, XSiteState) - Method in class org.infinispan.xsite.statetransfer.XSiteState.XSiteStateExternalizer
 
writeObject(ObjectOutput, T) - Method in class org.infinispan.transaction.xa.GlobalTransaction.AbstractGlobalTxExternalizer
 
writeObject(Object) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeOnly(CacheEntry, DataConversion) - Static method in class org.infinispan.functional.impl.EntryViews
 
WriteOnlyKeyCommand<K,​V> - Class in org.infinispan.commands.functional
 
WriteOnlyKeyCommand() - Constructor for class org.infinispan.commands.functional.WriteOnlyKeyCommand
 
WriteOnlyKeyCommand(Object, Consumer<EntryView.WriteEntryView<K, V>>, int, CommandInvocationId, ValueMatcher, Params, DataConversion, DataConversion, ComponentRegistry) - Constructor for class org.infinispan.commands.functional.WriteOnlyKeyCommand
 
WriteOnlyKeyValueCommand<K,​V,​T> - Class in org.infinispan.commands.functional
 
WriteOnlyKeyValueCommand() - Constructor for class org.infinispan.commands.functional.WriteOnlyKeyValueCommand
 
WriteOnlyKeyValueCommand(Object, Object, BiConsumer<T, EntryView.WriteEntryView<K, V>>, int, CommandInvocationId, ValueMatcher, Params, DataConversion, DataConversion, ComponentRegistry) - Constructor for class org.infinispan.commands.functional.WriteOnlyKeyValueCommand
 
WriteOnlyManyCommand<K,​V> - Class in org.infinispan.commands.functional
 
WriteOnlyManyCommand() - Constructor for class org.infinispan.commands.functional.WriteOnlyManyCommand
 
WriteOnlyManyCommand(Collection<?>, Consumer<EntryView.WriteEntryView<K, V>>, Params, CommandInvocationId, DataConversion, DataConversion, ComponentRegistry) - Constructor for class org.infinispan.commands.functional.WriteOnlyManyCommand
 
WriteOnlyManyCommand(WriteOnlyManyCommand<K, V>) - Constructor for class org.infinispan.commands.functional.WriteOnlyManyCommand
 
WriteOnlyManyEntriesCommand<K,​V,​T> - Class in org.infinispan.commands.functional
 
WriteOnlyManyEntriesCommand() - Constructor for class org.infinispan.commands.functional.WriteOnlyManyEntriesCommand
 
WriteOnlyManyEntriesCommand(Map<?, ?>, BiConsumer<T, EntryView.WriteEntryView<K, V>>, Params, CommandInvocationId, DataConversion, DataConversion, ComponentRegistry) - Constructor for class org.infinispan.commands.functional.WriteOnlyManyEntriesCommand
 
WriteOnlyManyEntriesCommand(WriteOnlyManyEntriesCommand<K, V, T>) - Constructor for class org.infinispan.commands.functional.WriteOnlyManyEntriesCommand
 
WriteOnlyMapImpl<K,​V> - Class in org.infinispan.functional.impl
Write-only map implementation.
writeOptional(XMLExtendedStreamWriter, Enum<?>, String) - Static method in class org.infinispan.configuration.serializing.SerializeUtils
 
writeOwners() - Method in class org.infinispan.distribution.DistributionInfo
 
writeOwnership() - Method in class org.infinispan.distribution.DistributionInfo
 
writeProcessingInstruction(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeProcessingInstruction(String, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeScopedState(ScopedPersistentState) - Method in interface org.infinispan.globalstate.GlobalStateManager
Persists the specified scoped state
writeScopedState(ScopedPersistentState) - Method in class org.infinispan.globalstate.impl.GlobalStateManagerImpl
 
writeShort(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
writeSkewCheck() - Method in class org.infinispan.configuration.cache.LockingConfiguration
Deprecated.
since 9.0.
writeSkewCheck(boolean) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
Deprecated.
since 9.0. It will be automatically enabled for OPTIMISTIC and REPEATABLE_READ transactions
WriteSkewException - Exception in org.infinispan.transaction
Thrown when a write skew is detected
WriteSkewException() - 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
 
WriteSkewException(Throwable, Object) - Constructor for exception org.infinispan.transaction.WriteSkewException
 
WriteSkewHelper - Class in org.infinispan.transaction.impl
Encapsulates write skew logic in maintaining version maps, etc.
WriteSkewHelper() - Constructor for class org.infinispan.transaction.impl.WriteSkewHelper
 
WriteSkewHelper.KeySpecificLogic - Interface in org.infinispan.transaction.impl
 
writeSkewOnRead(Object, Object, EntryVersion, EntryVersion) - Method in class org.infinispan.util.logging.Log_$logger
 
writeSkewOnRead(Object, Object, EntryVersion, EntryVersion) - Method in interface org.infinispan.util.logging.Log
 
writeSkewOnRead$str() - Method in class org.infinispan.util.logging.Log_$logger
 
writeStartDocument() - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeStartDocument(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeStartDocument(String, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeStartElement(Enum<?>) - Method in interface org.infinispan.configuration.serializing.XMLExtendedStreamWriter
 
writeStartElement(Enum<?>) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeStartElement(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeStartElement(String, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeStartElement(String, String, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.CancelCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.control.LockControlCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.CreateCacheCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.functional.ReadOnlyKeyCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.functional.ReadOnlyManyCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.functional.ReadWriteKeyCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.functional.ReadWriteKeyValueCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.functional.ReadWriteManyCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.functional.ReadWriteManyEntriesCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.functional.TxReadOnlyKeyCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.functional.TxReadOnlyManyCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.functional.WriteOnlyKeyCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.functional.WriteOnlyKeyValueCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.functional.WriteOnlyManyCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.functional.WriteOnlyManyEntriesCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.read.AbstractLocalCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.read.DistributedExecuteCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.read.GetAllCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.read.GetCacheEntryCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.read.GetKeyValueCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.remote.ClusteredGetAllCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.remote.ClusteredGetCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.remote.expiration.RetrieveLastAccessCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.remote.expiration.UpdateLastAccessCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.remote.GetKeysInGroupCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.remote.recovery.CompleteTransactionCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.remote.recovery.GetInDoubtTransactionsCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.remote.recovery.GetInDoubtTxInfoCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.remote.RenewBiasCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.remote.RevokeBiasCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.remote.SingleRpcCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.RemoveCacheCommand
Deprecated.
 
writeTo(ObjectOutput) - Method in interface org.infinispan.commands.ReplicableCommand
Writes this instance to the ObjectOutput.
writeTo(ObjectOutput) - Method in class org.infinispan.commands.triangle.MultiEntriesFunctionalBackupWriteCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.triangle.MultiKeyFunctionalBackupWriteCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.triangle.PutMapBackupWriteCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.triangle.SingleKeyBackupWriteCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.triangle.SingleKeyFunctionalBackupWriteCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.tx.AbstractTransactionBoundaryCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.tx.PrepareCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.tx.VersionedCommitCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.tx.VersionedPrepareCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.write.ApplyDeltaCommand
Deprecated.
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.write.BackupAckCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.write.BackupMultiKeyAckCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.write.ClearCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.write.ComputeCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.write.ComputeIfAbsentCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.write.ExceptionAckCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.write.InvalidateCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.write.InvalidateL1Command
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.write.InvalidateVersionsCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.write.PutKeyValueCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.write.PutMapCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.write.RemoveCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.write.RemoveExpiredCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.commands.write.ReplaceCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.manager.impl.ReplicableCommandManagerFunction
 
writeTo(ObjectOutput) - Method in class org.infinispan.manager.impl.ReplicableCommandRunnable
 
writeTo(ObjectOutput) - Method in class org.infinispan.statetransfer.StateRequestCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.statetransfer.StateResponseCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.stream.impl.StreamIteratorCloseCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.stream.impl.StreamIteratorNextCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.stream.impl.StreamIteratorRequestCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.stream.impl.StreamRequestCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.stream.impl.StreamResponseCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.topology.CacheTopologyControlCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.topology.HeartBeatCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.xsite.SingleXSiteRpcCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
 
writeTo(ObjectOutput) - Method in class org.infinispan.xsite.XSiteAdminCommand
 
writeTo(ObjectOutput, CommandInvocationId) - Static method in class org.infinispan.commands.CommandInvocationId
 
writeTo(ObjectOutput, DataConversion) - Static method in class org.infinispan.encoding.DataConversion
 
writeToAllNonTxStores(MarshalledEntry, int, Predicate<? super StoreConfiguration>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
Write to all stores that are not transactional.
writeToAllNonTxStores(MarshalledEntry, int, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
writeToAllNonTxStores(MarshalledEntry, int, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
writeToAllNonTxStores(MarshalledEntry, int, Predicate<? super StoreConfiguration>, long) - Method in interface org.infinispan.persistence.manager.PersistenceManager
 
writeToAllNonTxStores(MarshalledEntry, int, Predicate<? super StoreConfiguration>, long) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
 
writeToAllNonTxStores(MarshalledEntry, int, Predicate<? super StoreConfiguration>, long) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
 
writeTypedProperties(XMLExtendedStreamWriter, TypedProperties) - Static method in class org.infinispan.configuration.serializing.SerializeUtils
 
writeUTF(String) - Method in class org.infinispan.io.UnclosableObjectOutputStream
 
wrongTypeForJGroupsChannelLookup(String, Exception) - Method in class org.infinispan.util.logging.Log_$logger
 
wrongTypeForJGroupsChannelLookup(String, Exception) - Method in interface org.infinispan.util.logging.Log
 
wrongTypeForJGroupsChannelLookup$str() - Method in class org.infinispan.util.logging.Log_$logger
 

X

xaResourceEndFailed(XAResource, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
xaResourceEndFailed(XAResource, Throwable) - Method in interface org.infinispan.util.logging.Log
 
xaResourceEndFailed$str() - Method in class org.infinispan.util.logging.Log_$logger
 
XaTransactionTable - Class in org.infinispan.transaction.xa
XaTransactionTable() - Constructor for class org.infinispan.transaction.xa.XaTransactionTable
 
xid2LocalTx - Variable in class org.infinispan.transaction.xa.XaTransactionTable
 
XidExternalizer() - Constructor for class org.infinispan.transaction.xa.recovery.SerializableXid.XidExternalizer
Deprecated.
 
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.
XMLExtendedStreamWriter - Interface in org.infinispan.configuration.serializing
 
XMLExtendedStreamWriterImpl - Class in org.infinispan.configuration.serializing
XMLExtendedStreamWriterImpl.
XMLExtendedStreamWriterImpl(XMLStreamWriter) - Constructor for class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
XMLExtendedStreamWriterImpl.ArgRunnable - Interface in org.infinispan.configuration.serializing
 
XSiteAdminCommand - Class in org.infinispan.xsite
Command used for handling XSiteReplication administrative operations.
XSiteAdminCommand() - Constructor for class org.infinispan.xsite.XSiteAdminCommand
 
XSiteAdminCommand(ByteString) - Constructor for class org.infinispan.xsite.XSiteAdminCommand
 
XSiteAdminCommand(ByteString, 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
 
xsiteAdminOperationError(String, String, Throwable) - Method in class org.infinispan.util.logging.Log_$logger
 
xsiteAdminOperationError(String, String, Throwable) - Method in interface org.infinispan.util.logging.Log
 
xsiteAdminOperationError$str() - Method in class org.infinispan.util.logging.Log_$logger
 
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
 
XSiteReplicateCommand - Class in org.infinispan.xsite
Abstract class to invoke RPC on the remote site.
XSiteReplicateCommand(ByteString) - Constructor for class org.infinispan.xsite.XSiteReplicateCommand
 
XSiteState - Class in org.infinispan.xsite.statetransfer
Represents the state of a single key to be sent to a backup site.
XSiteState.XSiteStateExternalizer - Class in org.infinispan.xsite.statetransfer
 
XSiteStateConsumer - Interface in org.infinispan.xsite.statetransfer
It contains the logic needed to consume the state sent from other site.
XSiteStateConsumerImpl - Class in org.infinispan.xsite.statetransfer
It contains the logic needed to consume the state sent from other site.
XSiteStateConsumerImpl() - Constructor for class org.infinispan.xsite.statetransfer.XSiteStateConsumerImpl
 
XSiteStateExternalizer() - Constructor for class org.infinispan.xsite.statetransfer.XSiteState.XSiteStateExternalizer
 
XSiteStateProvider - Interface in org.infinispan.xsite.statetransfer
It contains the logic to send state to another site.
XSiteStateProviderImpl - Class in org.infinispan.xsite.statetransfer
It contains the logic to send state to another site.
XSiteStateProviderImpl() - Constructor for class org.infinispan.xsite.statetransfer.XSiteStateProviderImpl
 
XSiteStatePushCommand - Class in org.infinispan.xsite.statetransfer
Wraps the state to be sent to another site
XSiteStatePushCommand() - Constructor for class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
 
XSiteStatePushCommand(ByteString) - Constructor for class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
 
XSiteStatePushCommand(ByteString, XSiteState[], long) - Constructor for class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
 
XSiteStateTransferCollector - Class in org.infinispan.xsite.statetransfer
It collects the acknowledgements sent from local site member to signal the ending of the state sent.
XSiteStateTransferCollector(Collection<Address>) - Constructor for class org.infinispan.xsite.statetransfer.XSiteStateTransferCollector
 
XSiteStateTransferConfiguration - Class in org.infinispan.configuration.cache
Configuration needed for State Transfer between different sites.
XSiteStateTransferConfiguration(AttributeSet) - Constructor for class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
XSiteStateTransferConfigurationBuilder - Class in org.infinispan.configuration.cache
Configuration Builder to configure the state transfer between sites.
XSiteStateTransferConfigurationBuilder(ConfigurationBuilder, BackupConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
 
XSiteStateTransferControlCommand - Class in org.infinispan.xsite.statetransfer
Command used to control the state transfer between sites.
XSiteStateTransferControlCommand() - Constructor for class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
 
XSiteStateTransferControlCommand(ByteString) - Constructor for class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
 
XSiteStateTransferControlCommand(ByteString, XSiteStateTransferControlCommand.StateTransferControl, String) - Constructor for class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
 
XSiteStateTransferControlCommand.StateTransferControl - Enum in org.infinispan.xsite.statetransfer
 
XSiteStateTransferManager - Interface in org.infinispan.xsite.statetransfer
It manages the state transfer between sites.
XSiteStateTransferManagerImpl - Class in org.infinispan.xsite.statetransfer
XSiteStateTransferManagerImpl() - Constructor for class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 

Z

ZERO_LOCK_ACQUISITION_TIMEOUT - org.infinispan.context.Flag
Overrides the LockingConfiguration.lockAcquisitionTimeout(long) configuration setting by ensuring lock managers use a 0-millisecond lock acquisition timeout.
ZERO_LOCK_ACQUISITION_TIMEOUT - Static variable in class org.infinispan.context.impl.FlagBitSets
 

_

_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 Z _ 
All Classes All Packages