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

ABORT_RATE - org.infinispan.stats.container.ExtendedStatistic
 
AbstractApplicationPublisherBridge - Class in org.infinispan.spring.session
A bridge for passing events between Infinispan (both embedded and remote) and Spring.
AbstractApplicationPublisherBridge(SpringCache) - Constructor for class org.infinispan.spring.session.AbstractApplicationPublisherBridge
 
AbstractCacheEventFilterConverter<K,​V,​C> - Class in org.infinispan.notifications.cachelistener.filter
AbstractCacheEventFilterConverter() - Constructor for class org.infinispan.notifications.cachelistener.filter.AbstractCacheEventFilterConverter
 
AbstractCacheIgnoreAware - Class in org.infinispan.server.core
Abstract class providing stock implementations for CacheIgnoreAware so all that is required is to extend this class.
AbstractCacheIgnoreAware() - Constructor for class org.infinispan.server.core.AbstractCacheIgnoreAware
 
AbstractClusteringDependentLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
 
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
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
 
AbstractCounterConfiguration - Class in org.infinispan.counter.configuration
Base counter configuration with its name, initial value and Storage mode.
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
 
AbstractDelegatingAdvancedCache<K,​V> - Class in org.infinispan
Deprecated.
Extend from AbstractDelegatingAdvancedCache instead. This class will be removed in the future.
AbstractDelegatingAdvancedCache(AdvancedCache<K, V>) - Constructor for class org.infinispan.AbstractDelegatingAdvancedCache
Deprecated.
 
AbstractDelegatingAdvancedCache(AdvancedCache<K, V>, AbstractDelegatingAdvancedCache.AdvancedCacheWrapper<K, V>) - Constructor for class org.infinispan.AbstractDelegatingAdvancedCache
Deprecated.
 
AbstractDelegatingCache<K,​V> - Class in org.infinispan
Deprecated.
Extend from AbstractDelegatingCache instead. This class will be removed in the future.
AbstractDelegatingCache(Cache<K, V>) - Constructor for class org.infinispan.AbstractDelegatingCache
Deprecated.
 
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
 
AbstractDelegatingCollection<E> - Class in org.infinispan.commons.util
Delegating collection that delegates all calls to the collection returned from AbstractDelegatingCollection.delegate()
AbstractDelegatingCollection() - Constructor for class org.infinispan.commons.util.AbstractDelegatingCollection
 
AbstractDelegatingConcurrentMap<K,​V> - Class in org.infinispan.commons.util
 
AbstractDelegatingConcurrentMap() - Constructor for class org.infinispan.commons.util.AbstractDelegatingConcurrentMap
 
AbstractDelegatingEmbeddedCacheManager - Class in org.infinispan.manager
Deprecated.
Extend from AbstractDelegatingEmbeddedCacheManager instead. This class will be removed in the future.
AbstractDelegatingEmbeddedCacheManager(EmbeddedCacheManager) - Constructor for class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
Deprecated.
 
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
 
AbstractDelegatingMap<K,​V> - Class in org.infinispan.commons.util
 
AbstractDelegatingMap() - Constructor for class org.infinispan.commons.util.AbstractDelegatingMap
 
AbstractDelegatingMarshaller - Class in org.infinispan.commons.marshall
With the introduction of global and cache marshallers, there's a need to separate marshallers but still rely on the same marshalling backend as previously.
AbstractDelegatingMarshaller() - Constructor for class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
 
AbstractDelegatingSet<E> - Class in org.infinispan.commons.util
 
AbstractDelegatingSet() - Constructor for class org.infinispan.commons.util.AbstractDelegatingSet
 
AbstractDelegatingTransport - Class in org.infinispan.remoting.transport
Designed to be overwrite.
AbstractDelegatingTransport(Transport) - Constructor for class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
AbstractEmbeddedCacheManagerFactory - Class in org.infinispan.spring
An abstract base class for factories creating cache managers that are backed by an EmbeddedCacheManager.
AbstractEmbeddedCacheManagerFactory() - Constructor for class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
 
AbstractEncoder1x - Class in org.infinispan.server.hotrod
Hot Rod encoder for protocol version 1.1
AbstractEncoder1x() - Constructor for class org.infinispan.server.hotrod.AbstractEncoder1x
 
AbstractEntrySizeCalculatorHelper<K,​V> - Class in org.infinispan.commons.util
Abstract class that provides a method to round up to the nearest value of 8 which is important for most jvm when doing size calculations.
AbstractEntrySizeCalculatorHelper() - Constructor for class org.infinispan.commons.util.AbstractEntrySizeCalculatorHelper
 
AbstractExternalizer<T> - Class in org.infinispan.commons.marshall
Base class for AdvancedExternalizer implementations that offers default implementations for some of its methods.
AbstractExternalizer() - Constructor for class org.infinispan.commons.marshall.AbstractExternalizer
 
AbstractFileLookup - Class in org.infinispan.commons.util
 
AbstractFileLookup() - Constructor for class org.infinispan.commons.util.AbstractFileLookup
 
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
 
AbstractHotRodServerChildConfigurationBuilder - Class in org.infinispan.server.hotrod.configuration
AbstractHotRodServerChildConfigurationBuilder.
AbstractHotRodServerChildConfigurationBuilder(HotRodServerChildConfigurationBuilder) - Constructor for class org.infinispan.server.hotrod.configuration.AbstractHotRodServerChildConfigurationBuilder
 
AbstractInfinispanSessionRepository - Class in org.infinispan.spring.session
Infinispan implementation for Spring Session with basic functionality.
AbstractInfinispanSessionRepository(SpringCache, AbstractApplicationPublisherBridge) - Constructor for class org.infinispan.spring.session.AbstractInfinispanSessionRepository
 
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
 
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.
 
AbstractIterator<E> - Class in org.infinispan.commons.util
Abstract iterator that allows overriding just the AbstractIterator.getNext() method to implement it.
AbstractIterator() - Constructor for class org.infinispan.commons.util.AbstractIterator
 
AbstractJBossMarshaller - Class in org.infinispan.commons.marshall.jboss
Common parent for both embedded and standalone JBoss Marshalling-based marshallers.
AbstractJBossMarshaller() - Constructor for class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
 
AbstractJBossMarshaller.DebuggingExceptionListener - Class in org.infinispan.commons.marshall.jboss
 
AbstractJdbcStoreConfiguration - Class in org.infinispan.persistence.jdbc.configuration
 
AbstractJdbcStoreConfiguration(AttributeSet, AsyncStoreConfiguration, SingletonStoreConfiguration, ConnectionFactoryConfiguration) - Constructor for class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfiguration
 
AbstractJdbcStoreConfigurationBuilder<T extends AbstractJdbcStoreConfiguration,​S extends AbstractJdbcStoreConfigurationBuilder<T,​S>> - Class in org.infinispan.persistence.jdbc.configuration
 
AbstractJdbcStoreConfigurationBuilder(PersistenceConfigurationBuilder, AttributeSet) - Constructor for class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
 
AbstractJdbcStoreConfigurationChildBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,​S>> - Class in org.infinispan.persistence.jdbc.configuration
AbstractJdbcStoreConfigurationChildBuilder.
AbstractJdbcStoreConfigurationChildBuilder(AbstractJdbcStoreConfigurationBuilder<?, S>) - Constructor for class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationChildBuilder
 
AbstractJdbcStoreConfigurationSerializer - Class in org.infinispan.persistence.jdbc.configuration
AbstractJdbcStoreConfigurationSerializer.
AbstractJdbcStoreConfigurationSerializer() - Constructor for class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationSerializer
 
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
 
AbstractLockingInterceptor - Class in org.infinispan.interceptors.locking
Base class for various locking interceptors in this package.
AbstractLockingInterceptor() - Constructor for class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
AbstractMap<K,​V> - Class in org.infinispan.commons.util
Similar to the JDK's AbstractMap, this provides common functionality for custom map implementations.
AbstractMap() - Constructor for class org.infinispan.commons.util.AbstractMap
 
AbstractMap.SimpleEntry<K,​V> - Class in org.infinispan.commons.util
 
AbstractMarshaller - Class in org.infinispan.commons.marshall
Abstract Marshaller implementation containing shared implementations.
AbstractMarshaller() - Constructor for class org.infinispan.commons.marshall.AbstractMarshaller
 
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
 
AbstractProtocolServer<A extends ProtocolServerConfiguration> - Class in org.infinispan.server.core
A common protocol server dealing with common property parameter validation and assignment and transport lifecycle.
AbstractProtocolServer(String) - Constructor for class org.infinispan.server.core.AbstractProtocolServer
 
AbstractProtocolServerConfigurationChildBuilder<T extends ProtocolServerConfiguration,​S extends ProtocolServerConfigurationChildBuilder<T,​S>> - Class in org.infinispan.server.core.configuration
Helper
AbstractProtocolServerConfigurationChildBuilder(ProtocolServerConfigurationChildBuilder<T, S>) - Constructor for class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
 
AbstractRemoteCacheManagerFactory - Class in org.infinispan.spring
An abstract base class for factories creating cache manager that are backed by an Infinispan RemoteCacheManager.
AbstractRemoteCacheManagerFactory() - Constructor for class org.infinispan.spring.AbstractRemoteCacheManagerFactory
 
AbstractRemoteStoreConfigurationChildBuilder<S> - Class in org.infinispan.persistence.remote.configuration
AbstractRemoteStoreConfigurationChildBuilder.
AbstractRemoteStoreConfigurationChildBuilder(RemoteStoreConfigurationBuilder, AttributeSet) - Constructor for class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
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
 
AbstractRestStoreConfigurationChildBuilder<S> - Class in org.infinispan.persistence.rest.configuration
AbstractRestStoreConfigurationChildBuilder.
AbstractRestStoreConfigurationChildBuilder(RestStoreConfigurationBuilder, AttributeSet) - Constructor for class org.infinispan.persistence.rest.configuration.AbstractRestStoreConfigurationChildBuilder
 
AbstractSecurityConfigurationChildBuilder - Class in org.infinispan.persistence.remote.configuration
AbstractSecurityConfigurationChildBuilder.
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
 
AbstractTopologyAwareEncoder1x - Class in org.infinispan.server.hotrod
Hot Rod encoder for protocol version 1.1
AbstractTopologyAwareEncoder1x() - Constructor for class org.infinispan.server.hotrod.AbstractTopologyAwareEncoder1x
 
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
 
AbstractTxLockingInterceptor - Class in org.infinispan.interceptors.locking
Base class for transaction based locking interceptors.
AbstractTxLockingInterceptor() - Constructor for class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
 
AbstractTypedPropertiesConfiguration - Class in org.infinispan.commons.configuration
 
AbstractTypedPropertiesConfiguration(Properties) - Constructor for class org.infinispan.commons.configuration.AbstractTypedPropertiesConfiguration
AbstractTypedPropertiesConfiguration(AttributeSet) - Constructor for class org.infinispan.commons.configuration.AbstractTypedPropertiesConfiguration
 
AbstractUpdateCommand - Class in org.infinispan.query.indexmanager
Base class for index commands.
AbstractUpdateCommand(ByteString) - Constructor for class org.infinispan.query.indexmanager.AbstractUpdateCommand
 
accept(Object, Object, Metadata) - Method in class org.infinispan.filter.AcceptAllKeyValueFilter
 
accept(Object, Object, Metadata, Object, Metadata, EventType) - Method in class org.infinispan.persistence.remote.upgrade.RemovedFilter
 
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.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(KeyVisitor) - Method in class org.infinispan.lucene.ChunkCacheKey
 
accept(KeyVisitor) - Method in class org.infinispan.lucene.FileCacheKey
 
accept(KeyVisitor) - Method in class org.infinispan.lucene.FileListCacheKey
 
accept(KeyVisitor) - Method in class org.infinispan.lucene.FileReadLockKey
 
accept(KeyVisitor<T>) - Method in interface org.infinispan.lucene.IndexScopedKey
 
accept(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.
 
ACCEPT_ALL_KEY_VALUE_FILTER - Static variable in interface org.infinispan.commons.marshall.Ids
 
AcceptAllKeyValueFilter - Class in org.infinispan.filter
A key value filter that accepts all entries found.
AcceptAllKeyValueFilter.Externalizer - Class in org.infinispan.filter
 
ACCESS - org.infinispan.persistence.jdbc.DatabaseType
 
ACCESS_ORDER - org.infinispan.commons.equivalence.EquivalentLinkedHashMap.IterationOrder
Deprecated.
 
accessLogging() - Method in class org.infinispan.server.hotrod.HotRodServer
 
AccessLoggingHeader - Class in org.infinispan.server.hotrod
 
AccessLoggingHeader(HotRodHeader, Subject, Object, int, Temporal) - Constructor for class org.infinispan.server.hotrod.AccessLoggingHeader
 
accumulator() - Method in class org.infinispan.commons.util.ArrayCollector
 
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
 
acquireReadLock(String) - Method in class org.infinispan.lucene.readlocks.DistributedSegmentReadLocker
Acquires a readlock on all chunks for this file, to make sure chunks are not deleted while iterating on the group.
acquireReadLock(String) - Method in class org.infinispan.lucene.readlocks.LocalLockMergingSegmentReadLocker
Acquires a readlock, in order to prevent other invocations to SegmentReadLocker.deleteOrReleaseReadLock(String) from deleting the file.
acquireReadLock(String) - Method in class org.infinispan.lucene.readlocks.NoopSegmentReadLocker
doesn't do anything and returns true
acquireReadLock(String) - Method in interface org.infinispan.lucene.readlocks.SegmentReadLocker
Acquires a readlock, in order to prevent other invocations to SegmentReadLocker.deleteOrReleaseReadLock(String) from deleting the file.
acquireSharedTopologyLock() - Method in interface org.infinispan.statetransfer.StateTransferLock
 
acquireSharedTopologyLock() - Method in class org.infinispan.statetransfer.StateTransferLockImpl
 
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.
ActionSequencer - Class in org.infinispan.util.concurrent
Orders multiple actions/tasks based on a key.
ActionSequencer(ExecutorService, boolean, TimeService) - Constructor for class org.infinispan.util.concurrent.ActionSequencer
 
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.
active - Variable in class org.infinispan.persistence.support.SingletonCacheWriter
Deprecated.
Whether the the current cache is the coordinator and therefore SingletonStore is active.
ACTIVE - org.infinispan.server.hotrod.tx.table.Status
The client transaction is being replayed.
activeIterations() - Method in class org.infinispan.server.hotrod.iteration.DefaultIterationManager
 
activeIterations() - Method in interface org.infinispan.server.hotrod.iteration.IterationManager
 
activePublisherInvocations() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
Returns how many publisher invocations are currently 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
 
AdaptiveBufferSizePredictor - Class in org.infinispan.commons.marshall
The BufferSizePredictor that automatically increases and decreases the predicted buffer size on feed back.
AdaptiveBufferSizePredictor() - Constructor for class org.infinispan.commons.marshall.AdaptiveBufferSizePredictor
Creates a new predictor with the default parameters.
AdaptiveBufferSizePredictor(int, int, int) - Constructor for class org.infinispan.commons.marshall.AdaptiveBufferSizePredictor
Creates a new predictor with the specified parameters.
add(int) - Method in interface org.infinispan.commons.util.IntSet
Adds the given int to this set and returns true if it was set or false if it was already present
add(int) - Method in class org.infinispan.commons.util.RangeSet
Deprecated.
 
add(int) - Method in class org.infinispan.commons.util.SmallIntSet
Deprecated.
Add an integer to the set without boxing the parameter.
add(int, E) - Method in class org.infinispan.commons.util.ForwardingList
 
add(long) - Method in interface org.infinispan.counter.api.SyncWeakCounter
 
add(long) - Method in interface org.infinispan.counter.api.WeakCounter
Adds the given value to the new value.
add(E) - Method in class org.infinispan.commons.equivalence.EquivalentHashSet
Deprecated.
Adds the specified element to this set if it is not already present.
add(E) - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
 
add(E) - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
 
add(E) - Method in class org.infinispan.commons.util.concurrent.ConcurrentHashSet
 
add(E) - Method in class org.infinispan.commons.util.ForwardingList
 
add(E) - Method in class org.infinispan.commons.util.ImmutableHopscotchHashSet
 
add(E) - Method in class org.infinispan.commons.util.ImmutableListCopy
 
add(Integer) - Method in class org.infinispan.commons.util.RangeSet
Deprecated.
 
add(Integer) - Method in class org.infinispan.commons.util.SmallIntSet
Deprecated.
 
add(Object) - Method in class org.infinispan.commons.util.ArrayCollector
 
add(Object) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
Deprecated.
 
add(Permission) - Method in class org.infinispan.security.CachePermissionCollection
 
add(AtomicLongFieldUpdater<T>, T, long) - Method in class org.infinispan.commons.util.concurrent.StripedCounters
 
add(List<Xid>) - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
 
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 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(ExtendedStatistic, double, boolean) - Method in class org.infinispan.stats.container.ConcurrentGlobalContainer
 
add(ExtendedStatistic, double, GlobalTransaction, boolean) - Method in class org.infinispan.stats.CacheStatisticManager
Adds a value to a statistic.
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
 
ADD_CLIENT_LISTENER - org.infinispan.server.hotrod.HotRodOperation
 
ADD_CLIENT_LISTENER_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
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.
addAll(int, Collection<? extends E>) - Method in class org.infinispan.commons.util.ForwardingList
 
addAll(int, Collection<? extends E>) - Method in class org.infinispan.commons.util.ImmutableListCopy
 
addAll(int, Collection<? extends E>) - Method in class org.infinispan.commons.util.ImmutableListCopy.ImmutableSubList
 
addAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
Deprecated.
 
addAll(Collection<? extends E>) - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
 
addAll(Collection<? extends E>) - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
 
addAll(Collection<? extends E>) - Method in class org.infinispan.commons.util.concurrent.ConcurrentHashSet
 
addAll(Collection<? extends E>) - Method in class org.infinispan.commons.util.ForwardingList
 
addAll(Collection<? extends E>) - Method in class org.infinispan.commons.util.ImmutableHopscotchHashSet
 
addAll(Collection<? extends E>) - Method in class org.infinispan.commons.util.ImmutableListCopy
 
addAll(Collection<? extends E>) - Method in class org.infinispan.commons.util.ImmutableListCopy.ImmutableSubList
 
addAll(Collection<? extends Integer>) - Method in class org.infinispan.commons.util.RangeSet
Deprecated.
 
addAll(Collection<? extends Integer>) - Method in class org.infinispan.commons.util.SmallIntSet
Deprecated.
 
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(List<CorsConfig>) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
 
addAll(IntSet) - Method in class org.infinispan.commons.util.ImmutableIntSet
Deprecated.
 
addAll(IntSet) - Method in interface org.infinispan.commons.util.IntSet
Adds all ints from the provided set into this one
addAll(IntSet) - Method in class org.infinispan.commons.util.RangeSet
Deprecated.
 
addAll(IntSet) - Method in class org.infinispan.commons.util.SmallIntSet
Deprecated.
 
addAllowedMech(String) - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
 
addAndGet(long) - Method in interface org.infinispan.counter.api.StrongCounter
Atomically adds the given value and return the new value.
addAndGet(long) - Method in interface org.infinispan.counter.api.SyncStrongCounter
 
addBackup() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
addBackupLockForKey(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
addCache(ByteString, Status) - Method in class org.infinispan.server.hotrod.tx.operation.CommitTransactionOperation
 
addCache(ByteString, Status) - Method in class org.infinispan.server.hotrod.tx.operation.RollbackTransactionOperation
 
addCache(ByteString, Status) - Method in interface org.infinispan.server.hotrod.tx.table.CacheNameCollector
Adds the cache name and the SetDecisionFunction return value.
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.
AddCacheDependencyAction - Class in org.infinispan.security.actions
AddCacheDependencyAction.
AddCacheDependencyAction(EmbeddedCacheManager, String, String) - Constructor for class org.infinispan.security.actions.AddCacheDependencyAction
 
addCacheEventConverterFactory(String, CacheEventConverterFactory) - Method in class org.infinispan.server.hotrod.HotRodServer
 
addCacheEventFilterConverterFactory(String, CacheEventFilterConverterFactory) - Method in class org.infinispan.server.hotrod.HotRodServer
 
addCacheEventFilterFactory(String, CacheEventFilterFactory) - Method in class org.infinispan.server.hotrod.HotRodServer
 
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.InvocationStage
 
addCallback(InvocationContext, VisitableCommand, InvocationCallback) - Method in class org.infinispan.interceptors.SyncInvocationStage
 
addClasses(Class<?>...) - Method in class org.infinispan.commons.configuration.ClassWhiteList
 
addClusteredLock() - Method in class org.infinispan.lock.configuration.ClusteredLockManagerConfigurationBuilder
 
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
 
addContinuousQueryListener(String, Map<String, Object>, ContinuousQueryListener<K, C>) - Method in interface org.infinispan.query.api.continuous.ContinuousQuery
Add a listener for a continuous query.
addContinuousQueryListener(String, ContinuousQueryListener<K, C>) - Method in interface org.infinispan.query.api.continuous.ContinuousQuery
Add a listener for a continuous query.
addContinuousQueryListener(Query, ContinuousQueryListener<K, C>) - Method in interface org.infinispan.query.api.continuous.ContinuousQuery
Add a listener for a continuous query.
addCounterListener(byte[], byte, String, Channel, VersionedEncoder) - Method in class org.infinispan.server.hotrod.counter.listener.ClientCounterManagerNotificationManager
 
addCustomCacheConfiguration(ConfigurationBuilder) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
Sets the ConfigurationBuilder to use when creating an EmbeddedCacheManager.
addCustomConfiguration(ConfigurationBuilder) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
API to introduce a customised ConfigurationBuilder that will override the default configurations which are already available on this class.
addCustomGlobalConfiguration(GlobalConfigurationBuilder) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
Sets the GlobalConfigurationBuilder to use when creating an EmbeddedCacheManager.
addDependency(T, T) - Method in class org.infinispan.util.DependencyGraph
Add a dependency between two elements
addErroneousAttribute(String) - Method in exception org.infinispan.commons.CacheConfigurationException
Deprecated.
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.
addException(Address, Exception) - Method in class org.infinispan.remoting.transport.ValidResponseCollector
Process an exception from a target.
addExecutorProperty(String, String) - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
Add key/value property pair to this executor factory configuration
addFailure(String, Throwable) - Method in exception org.infinispan.xsite.BackupFailureException
 
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(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
 
addGet(Object, boolean) - Method in class org.infinispan.stats.topK.StreamSummaryContainer
Adds the key to the read top-key.
addGrouper(Grouper<?>) - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
Add a grouper
addHexByte(StringBuilder, byte) - Static method in class org.infinispan.commons.util.Util
 
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(CommandInterceptor, int) - Method in interface org.infinispan.AdvancedCache
Deprecated.
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).
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(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in interface org.infinispan.AdvancedCache
Deprecated.
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.
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(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in interface org.infinispan.AdvancedCache
Deprecated.
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>, boolean) - Method in class org.infinispan.interceptors.InterceptorChain
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.
addKeyValueFilterConverterFactory(String, KeyValueFilterConverterFactory) - Method in class org.infinispan.server.hotrod.HotRodServer
 
addKeyValueFilterConverterFactory(String, KeyValueFilterConverterFactory) - Method in class org.infinispan.server.hotrod.iteration.DefaultIterationManager
 
addKeyValueFilterConverterFactory(String, KeyValueFilterConverterFactory) - Method in interface org.infinispan.server.hotrod.iteration.IterationManager
 
addListener() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
addListener(Object) - Method in class org.infinispan.manager.DefaultCacheManager
 
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, 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.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>, 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.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>, 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(AttributeListener<T>) - Method in class org.infinispan.commons.configuration.attributes.Attribute
 
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 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.
addListener(T) - Method in interface org.infinispan.counter.api.StrongCounter
Registers a CounterListener to this counter.
addListener(T) - Method in interface org.infinispan.counter.api.WeakCounter
Adds a CounterListener to this counter.
addLocalBias(Object, int) - Method in interface org.infinispan.scattered.BiasManager
Allow reading local data if the topology is still actual.
addLocalValue(ExtendedStatistic, double) - Method in class org.infinispan.stats.CacheStatisticCollector
Adds a value to a local statistic.
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.
 
addLockInformation(Object, boolean, boolean) - Method in class org.infinispan.stats.topK.StreamSummaryContainer
Adds the lock information about the key, namely if the key suffer some contention and if the keys was locked or not.
addMarshalledEntry(Object, MarshalledEntry) - Method in class org.infinispan.persistence.support.BatchModification
 
addMechProperty(String, String) - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
 
addMember(Principal) - Method in class org.infinispan.server.core.security.simple.SimpleGroupPrincipal
 
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
 
addModule(Class<T>) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
addModule(Class<T>) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
addOwner(Address) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
 
addParameter(String, Object) - Method in class org.infinispan.tasks.TaskContext
Adds a named parameter to the task context
addParsingCompleteListener(ParserContextListener) - Method in class org.infinispan.configuration.parsing.AbstractParserContext
 
addParsingCompleteListener(ParserContextListener) - Method in interface org.infinispan.configuration.parsing.ParserContext
 
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
 
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
 
addPut(Object, boolean) - Method in class org.infinispan.stats.topK.StreamSummaryContainer
Adds the key to the put top-key.
addr - Variable in class org.infinispan.transaction.xa.GlobalTransaction
 
addReadKey(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
Deprecated.
since 9.1 Use MVCCEntry.setRead() instead
addRegexps(String...) - Method in class org.infinispan.commons.configuration.ClassWhiteList
 
addRemoteValue(ExtendedStatistic, double) - Method in class org.infinispan.stats.CacheStatisticCollector
Adds a value to a remote statistic.
addRemovalListener(Consumer<Iterable<InternalCacheEntry<WrappedBytes, WrappedBytes>>>) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
addRequestor(Object, Address) - Method in interface org.infinispan.distribution.L1Manager
Records a request that will be cached in another nodes L1
addResponse(Address, Response) - Method in interface org.infinispan.interceptors.distribution.BiasedCollector
 
addResponse(Address, Response) - Method in class org.infinispan.interceptors.distribution.RemoteGetSingleKeyCollector
 
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.query.clustered.NodeTopDocs
 
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
 
addScript(String, String) - Method in interface org.infinispan.scripting.ScriptingManager
Adds a new named script.
addSegments(IntSet) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
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
 
addServer() - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
addServer() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
addServer() - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
Adds a new remote server
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.
addSpecificHeaders(FullHttpResponse) - Method in class org.infinispan.rest.InfinispanCacheResponse
 
addSpecificHeaders(FullHttpResponse) - Method in class org.infinispan.rest.InfinispanResponse
 
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.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.
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.
addStrongCounter() - Method in interface org.infinispan.counter.configuration.CounterConfigurationBuilder
 
addStrongCounter() - Method in class org.infinispan.counter.configuration.CounterManagerConfigurationBuilder
 
addTargetNotFound(Address) - Method in class org.infinispan.remoting.transport.ValidResponseCollector
Process a target leaving the cluster or stopping the cache.
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
 
addUser(String, String, char[], String...) - Method in class org.infinispan.server.core.security.simple.SimpleServerAuthenticationProvider
Add a user to the authentication table.
addValidResponse(Address, ValidResponse) - Method in class org.infinispan.remoting.transport.ValidResponseCollector
Process a valid response from a target.
addValue(ExtendedStatistic, double) - Method in class org.infinispan.stats.container.BaseExtendedStatisticsContainer
 
addValue(ExtendedStatistic, double) - Method in interface org.infinispan.stats.container.ExtendedStatisticsContainer
it adds the value to the statistic.
addValue(ExtendedStatistic, double) - Method in class org.infinispan.stats.TransactionStatistics
Adds a value to a statistic collected for this transaction.
addVersionRead(Object, EntryVersion) - Method in interface org.infinispan.transaction.xa.CacheTransaction
Sets the version read for this key.
addWeakCounter() - Method in interface org.infinispan.counter.configuration.CounterConfigurationBuilder
 
addWeakCounter() - Method in class org.infinispan.counter.configuration.CounterManagerConfigurationBuilder
 
addWriteSkewFailed(Object) - Method in class org.infinispan.stats.topK.StreamSummaryContainer
Adds the key to the write skew failed top-key.
ADMIN - org.infinispan.security.AuthorizationPermission
Allows performing "administrative" operations on a cache
ADMIN_FLAG - Static variable in interface org.infinispan.commons.marshall.Ids
 
ADMIN_OPERATION_HANDLER - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
 
AdminFlagExternalizer - Class in org.infinispan.commons.marshall
 
AdminFlagExternalizer() - Constructor for class org.infinispan.commons.marshall.AdminFlagExternalizer
 
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.
AdminOperation - Enum in org.infinispan.server.core.admin
AdminOperations
AdminOperationParameter - Enum in org.infinispan.server.core.admin
AdminOperationParameters
adminOperationsHandler() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
 
adminOperationsHandler(AdminOperationsHandler) - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
 
adminOperationsHandler(AdminOperationsHandler) - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
 
adminOperationsHandler(AdminOperationsHandler) - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
Indicates the AdminOperationsHandler which will be used to handle admin operations
adminOperationsHandler(AdminOperationsHandler) - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
 
AdminOperationsHandler - Class in org.infinispan.server.core.admin
AdminOperationsHandler is a special TaskEngine which can handle admin tasks
AdminOperationsHandler(Class<? extends AdminServerTask>...) - Constructor for class org.infinispan.server.core.admin.AdminOperationsHandler
 
AdminServerTask<T> - Class in org.infinispan.server.core.admin
Common base for admin server tasks
AdminServerTask() - Constructor for class org.infinispan.server.core.admin.AdminServerTask
 
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
AdvancedExternalizer<T> - Interface in org.infinispan.commons.marshall
AdvancedExternalizer provides an alternative way to provide externalizers for marshalling/unmarshalling user defined classes that overcome the deficiencies of the more user-friendly externalizer definition model explained in Externalizer.
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.
 
AffectedKeysVisitor - Class in org.infinispan.statetransfer
Deprecated.
since 9.1
AffectedKeysVisitor() - Constructor for class org.infinispan.statetransfer.AffectedKeysVisitor
Deprecated.
 
AffinityErrorHandler - Class in org.infinispan.query.affinity
Handles errors occurred in the AffinityIndexManager.
AffinityErrorHandler(ErrorHandler) - Constructor for class org.infinispan.query.affinity.AffinityErrorHandler
 
AffinityIndexManager - Class in org.infinispan.query.affinity
IndexManager that splits the index into shards.
AffinityIndexManager() - Constructor for class org.infinispan.query.affinity.AffinityIndexManager
 
affinityLocationIntoSegment(int) - Method in interface org.infinispan.lucene.directory.BuildContext
When set to a positive integer, this will force a specific data distribution: the hashing function will resolve all keys used to store the various entries for the resulting index to be owned by the specified segment id.
affinitySegmentId() - Method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfiguration
When Index Affinity is enabled, this returns the segment id to which the current index is bound to.
affinitySegmentId(int) - Method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfigurationBuilder
When the index is stored on a per-segment affinity base, set the affinity id for this index instance.
AffinityShardIdentifierProvider - Class in org.infinispan.query.affinity
Dynamic sharding based on the segment associated with the key
AffinityShardIdentifierProvider() - Constructor for class org.infinispan.query.affinity.AffinityShardIdentifierProvider
 
AffinityTaggedKey - Interface in org.infinispan.distribution.ch
 
AffinityUpdateCommand - Class in org.infinispan.query.affinity
Handle index updates forwarded by the AffinityIndexManager, in exceptional cases where an index work ceases to be local to a node due to transient ownership changes.
AffinityUpdateCommand(ByteString) - Constructor for class org.infinispan.query.affinity.AffinityUpdateCommand
 
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
 
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.
afterPropertiesSet() - Method in class org.infinispan.spring.InfinispanDefaultCacheFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.provider.SpringEmbeddedCacheManagerFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.provider.SpringRemoteCacheManagerFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.session.AbstractInfinispanSessionRepository
 
afterPropertiesSet() - Method in class org.infinispan.spring.support.embedded.InfinispanEmbeddedCacheManagerFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.support.remote.InfinispanNamedRemoteCacheFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.support.remote.InfinispanRemoteCacheManagerFactoryBean
 
AggregateBackupResponse - Class in org.infinispan.remoting.transport
 
AggregateBackupResponse(BackupResponse, BackupResponse) - Constructor for class org.infinispan.remoting.transport.AggregateBackupResponse
 
aggregateCompletionStage() - Static method in class org.infinispan.util.concurrent.CompletionStages
Returns a CompletionStage that also can be composed of many other CompletionStages.
aggregateCompletionStage(R) - Static method in class org.infinispan.util.concurrent.CompletionStages
Same as CompletionStages.aggregateCompletionStage() except that when this stage completes normally it will return the value provided.
AggregateCompletionStage<R> - Interface in org.infinispan.util.concurrent
Aggregation of multiple CompletionStage instances where their count is not known or when a large amount of stages are required, as it uses less memory foot print per stage.
AggregatedClassLoader - Class in org.infinispan.commons.util
A ClassLoader that delegates loading of classes and resources to a list of delegate ClassLoaders.
AggregatedClassLoader(Collection<ClassLoader>) - Constructor for class org.infinispan.commons.util.AggregatedClassLoader
Create an aggregated ClassLoader from a Collection of ClassLoaders
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_GET_EXECUTION - org.infinispan.stats.container.ExtendedStatistic
 
ALL_KNOWN_COMPONENT_NAMES - Static variable in class org.infinispan.factories.KnownComponentNames
 
ALL_NODES - org.infinispan.tasks.TaskExecutionMode
 
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.
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(SerializableIntPredicate) - Method in interface org.infinispan.IntCacheStream
Same as IntStream.allMatch(IntPredicate) except that the IntPredicate must also implement Serializable
allMatch(SerializableLongPredicate) - Method in interface org.infinispan.LongCacheStream
Same as LongStream.allMatch(LongPredicate) except that the LongPredicate must also implement Serializable.
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
 
allOf(CompletionStage<?>...) - Static method in class org.infinispan.util.concurrent.CompletionStages
Returns a CompletionStage that completes when all of the provided stages complete, either normally or via exception.
allOf(CompletionStage<Void>, CompletionStage<Void>) - Static method in class org.infinispan.util.concurrent.CompletionStages
Returns a CompletableStage that completes when both of the provides CompletionStages complete.
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.
allowedMechs() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfiguration
 
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.
ALREADY_OFFLINE - org.infinispan.xsite.BackupSender.TakeSiteOfflineResponse
 
ALREADY_ONLINE - org.infinispan.xsite.BackupSender.BringSiteOnlineResponse
 
alwaysTruePredicate() - Static method in class org.infinispan.stream.StreamMarshalling
Predicate taht always returns true irrespective of the value provided
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
 
and() - Method in interface org.infinispan.query.dsl.FilterConditionContext
Creates a new context and connects it with the current one using boolean AND.
and(FilterConditionContext) - Method in interface org.infinispan.query.dsl.FilterConditionContext
Connects a given context with the current one using boolean AND.
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
 
AnyEquivalence<T> - Class in org.infinispan.commons.equivalence
Deprecated. 
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(SerializableIntPredicate) - Method in interface org.infinispan.IntCacheStream
Same as IntStream.anyMatch(IntPredicate) except that the IntPredicate must also implement Serializable
anyMatch(SerializableLongPredicate) - Method in interface org.infinispan.LongCacheStream
Same as LongStream.anyMatch(LongPredicate) except that the LongPredicate must also implement Serializable.
anyMatch(SerializablePredicate<? super R>) - Method in interface org.infinispan.CacheStream
Same as Stream.anyMatch(Predicate) except that the Predicate must also implement Serializable
AnyServerEquivalence - Class in org.infinispan.commons.equivalence
Deprecated. 
AnyServerEquivalence() - Constructor for class org.infinispan.commons.equivalence.AnyServerEquivalence
Deprecated.
 
APPEND_CACHE_NAME_TO_PATH - org.infinispan.persistence.rest.configuration.Attribute
 
APPEND_CACHE_NAME_TO_PATH - Static variable in class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
 
appendCacheNameToPath() - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
 
appendCacheNameToPath(boolean) - Method in class org.infinispan.persistence.rest.configuration.AbstractRestStoreConfigurationChildBuilder
 
appendCacheNameToPath(boolean) - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfigurationBuilder
 
appendCacheNameToPath(boolean) - Method in interface org.infinispan.persistence.rest.configuration.RestStoreConfigurationChildBuilder
Determines whether to append the cache name to the path URI.
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(CommandInterceptor, boolean) - Method in class org.infinispan.interceptors.InterceptorChain
Deprecated.
Appends at the end.
AppendRequest - org.infinispan.server.memcached.MemcachedOperation
 
APPLICATION_INFINISPAN_BINARY - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_INFINISPAN_BINARY_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_INFINISPAN_MARSHALLED - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_INFINISPAN_MARSHALLING - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_INFINISPAN_MARSHALLING_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_JBOSS_MARSHALLING - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_JBOSS_MARSHALLING_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_JSON - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_JSON_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_KRYO - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_KRYO_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_OBJECT - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_OBJECT_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_OCTET_STREAM - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_OCTET_STREAM_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_PDF - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_PDF_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_PROTOSTREAM - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_PROTOSTREAM_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_PROTOSTUFF - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_PROTOSTUFF_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_RTF - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_RTF_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_SERIALIZED_OBJECT - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_SERIALIZED_OBJECT_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_TEXT_STRING - Static variable in class org.infinispan.scripting.utils.ScriptConversions
 
APPLICATION_UNKNOWN - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_UNKNOWN_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_WWW_FORM_URLENCODED - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_XML - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_XML_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_ZIP - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_ZIP_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
applicationEventPublisher - Variable in class org.infinispan.spring.session.AbstractInfinispanSessionRepository
 
apply(Object) - Method in class org.infinispan.compat.FunctionMapper
 
apply(Object) - Method in class org.infinispan.remoting.LocalInvocation
 
apply(Object, Object) - Method in class org.infinispan.compat.BiFunctionMapper
 
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 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 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<CacheXid, TxState>) - Method in class org.infinispan.server.hotrod.tx.table.functions.ConditionalMarkAsRollbackFunction
 
apply(EntryView.ReadWriteEntryView<CacheXid, TxState>) - Method in class org.infinispan.server.hotrod.tx.table.functions.CreateStateFunction
 
apply(EntryView.ReadWriteEntryView<CacheXid, TxState>) - Method in class org.infinispan.server.hotrod.tx.table.functions.PreparingDecisionFunction
 
apply(EntryView.ReadWriteEntryView<CacheXid, TxState>) - Method in class org.infinispan.server.hotrod.tx.table.functions.SetCompletedTransactionFunction
 
apply(EntryView.ReadWriteEntryView<CacheXid, TxState>) - Method in class org.infinispan.server.hotrod.tx.table.functions.SetDecisionFunction
 
apply(EntryView.ReadWriteEntryView<CacheXid, TxState>) - Method in class org.infinispan.server.hotrod.tx.table.functions.SetPreparedFunction
 
APPLY_DELTA - Static variable in interface org.infinispan.commons.marshall.Ids
 
applyAsInt(Object) - Method in interface org.infinispan.distribution.ch.KeyPartitioner
 
applyDelta(K, Delta, Object...) - Method in interface org.infinispan.AdvancedCache
Deprecated.
since 9.1
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
 
applyStreamWork(LuceneWork, IndexingMonitor, IndexManager) - Method in class org.infinispan.query.indexmanager.LazyInitializingBackend
 
applyStreamWork(LuceneWork, IndexingMonitor, IndexManager) - Method in class org.infinispan.query.indexmanager.LockAcquiringBackend
 
applyVersion(Metadata, Metadata) - Static method in class org.infinispan.metadata.Metadatas
Applies version in source metadata to target metadata, if no version in target metadata.
applyWork(List<LuceneWork>, IndexingMonitor, IndexManager) - Method in class org.infinispan.query.indexmanager.LazyInitializingBackend
 
applyWork(List<LuceneWork>, IndexingMonitor, IndexManager) - Method in class org.infinispan.query.indexmanager.LockAcquiringBackend
 
areLocksReleased() - Method in interface org.infinispan.transaction.xa.CacheTransaction
Deprecated.
array(ByteBuf) - Static method in class org.infinispan.server.hotrod.Intrinsics
 
ArrayCollector - Class in org.infinispan.commons.util
 
ArrayCollector(Object[]) - Constructor for class org.infinispan.commons.util.ArrayCollector
 
arrayConcat(T[], T[]...) - Static method in class org.infinispan.commons.util.Util
Concatenates an arbitrary number of arrays returning a new array containing all elements
ArrayMap<K,​V> - Class in org.infinispan.commons.util
Base for classes that implement hash map by storing keys in one array and values in another.
ArrayMap() - Constructor for class org.infinispan.commons.util.ArrayMap
 
ARRAYS - Static variable in interface org.infinispan.commons.marshall.Ids
 
ARRIVAL_RATE - org.infinispan.stats.container.ExtendedStatistic
 
asBytes() - Method in class org.infinispan.query.remote.json.JsonQueryResponse
 
ASC - org.infinispan.query.dsl.SortOrder
 
asCompletionException(Throwable) - Static method in class org.infinispan.util.concurrent.CompletableFutures
 
asCounterManager(EmbeddedCacheManager) - Static method in class org.infinispan.counter.EmbeddedCounterManagerFactory
 
asDoubleStream() - Method in interface org.infinispan.IntCacheStream
asDoubleStream() - Method in interface org.infinispan.LongCacheStream
asError(InfinispanRequest, HttpResponseStatus, String) - Static method in class org.infinispan.rest.InfinispanErrorResponse
 
asList() - Method in class org.infinispan.interceptors.InterceptorChain
Deprecated.
Returns an unmofiable list with all the interceptors in sequence.
asLongStream() - Method in interface org.infinispan.IntCacheStream
asObject() - Method in class org.infinispan.commons.configuration.attributes.Attribute
 
assertBatchingSupported(Configuration) - Static method in class org.infinispan.batch.AutoBatchSupport
 
assertCorrectlyConfigured() - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
 
assertKeyNotNull(Object) - Static method in class org.infinispan.commons.util.AbstractMap
 
assertNotNullEntries(Collection<?>, String) - Static method in class org.infinispan.commons.util.InfinispanCollections
 
assertNotNullEntries(Map<?, ?>, String) - Static method in class org.infinispan.commons.util.InfinispanCollections
 
assertTypeConstructable(Class<?>, Class<?>...) - Method in class org.infinispan.factories.AbstractComponentFactory
 
asSet(T...) - Static method in class org.infinispan.commons.util.Util
 
asString(Object) - Method in interface org.infinispan.rest.operations.mediatypes.OutputPrinter
 
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_COMPLETE_NOTIFY_TIME - org.infinispan.stats.container.ExtendedStatistic
 
ASYNC_EXECUTOR - org.infinispan.configuration.parsing.Attribute
 
ASYNC_EXECUTOR - org.infinispan.persistence.remote.configuration.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 - org.infinispan.persistence.remote.configuration.Element
 
ASYNC_TRANSPORT_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
AsyncCache<K,​V> - Interface in org.infinispan.commons.api
AsyncCache.
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
 
asyncExecutorFactory() - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
asyncExecutorFactory() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
asyncExecutorFactory() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
asyncExecutorFactory() - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
Configuration for the executor service used for asynchronous work on the Transport, including asynchronous marshalling and Cache 'async operations' such as Cache.putAsync().
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.
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.
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.
ATOMIC_FINE_GRAINED_MAP_FUNCTIONS - Static variable in interface org.infinispan.commons.marshall.Ids
 
ATOMIC_KEY_SET - Static variable in interface org.infinispan.commons.marshall.Ids
 
ATOMIC_MAP_FUNCTIONS - Static variable in interface org.infinispan.commons.marshall.Ids
 
AtomicMap<K,​V> - Interface in org.infinispan.atomic
This is a special type of Map geared for use in Infinispan.
AtomicMapLookup - Class in org.infinispan.atomic
A helper that locates or safely constructs and registers atomic maps with a given cache.
AtomicMapLookup() - Constructor for class org.infinispan.atomic.AtomicMapLookup
 
attribute(String) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
Returns the named attribute
attribute(AttributeDefinition<T>) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
Returns the attribute identified by the supplied AttributeDefinition
Attribute<T> - Class in org.infinispan.commons.configuration.attributes
Attribute.
Attribute - Enum in org.infinispan.configuration.parsing
Enumerates the attributes used in Infinispan
Attribute - Enum in org.infinispan.counter.configuration
 
Attribute - Enum in org.infinispan.lock.configuration
 
Attribute - Enum in org.infinispan.persistence.jdbc.configuration
Enumerates the attributes used by the JDBC cache stores configuration
Attribute - Enum in org.infinispan.persistence.jpa.configuration
Enumerates the attributes used by the JPA cache stores configuration
Attribute - Enum in org.infinispan.persistence.leveldb.configuration
Enumerates the attributes used by the LevelDB cache stores configuration
Attribute - Enum in org.infinispan.persistence.remote.configuration
Enumerates the attributes used by the Remote cache store configuration
Attribute - Enum in org.infinispan.persistence.rest.configuration
Enumerates the attributes used by the Remote cache store configuration
attributeChanged(Attribute<Object>, Object) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
 
attributeChanged(Attribute<T>, T) - Method in interface org.infinispan.commons.configuration.attributes.AttributeListener
 
AttributeCopier<T> - Interface in org.infinispan.commons.configuration.attributes
AttributeCopier.
AttributeDefinition<T> - Class in org.infinispan.commons.configuration.attributes
AttributeDefinition.
AttributeDefinition.Builder<T> - Class in org.infinispan.commons.configuration.attributes
 
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
 
attributeDefinitionSet() - Static method in class org.infinispan.counter.configuration.StrongCounterConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.counter.configuration.WeakCounterConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.jpa.configuration.JpaStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfiguration
Deprecated.
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.rest.configuration.RestServerConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.memcached.configuration.MemcachedServerConfiguration
 
AttributeInitializer<T> - Interface in org.infinispan.commons.configuration.attributes
AttributeInitializer.
AttributeListener<T> - Interface in org.infinispan.commons.configuration.attributes
An AttributeListener will be invoked whenever an attribute has been modified.
attributes - Variable in class org.infinispan.commons.configuration.AbstractTypedPropertiesConfiguration
 
attributes - Variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
attributes - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
attributes - Variable in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
attributes - Variable in class org.infinispan.persistence.rest.configuration.AbstractRestStoreConfigurationChildBuilder
 
attributes - Variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
 
attributes - Variable in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
 
attributes() - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
 
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
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
 
attributes() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
 
attributeSet() - Static method in class org.infinispan.commons.configuration.AbstractTypedPropertiesConfiguration
 
AttributeSet - Class in org.infinispan.commons.configuration.attributes
AttributeSet is a container for Attributes.
AttributeSet(Class<?>, AttributeDefinition<?>...) - Constructor for class org.infinispan.commons.configuration.attributes.AttributeSet
 
AttributeSet(Class<?>, AttributeSet, AttributeDefinition<?>...) - Constructor for class org.infinispan.commons.configuration.attributes.AttributeSet
 
AttributeSet(String, AttributeDefinition<?>...) - Constructor for class org.infinispan.commons.configuration.attributes.AttributeSet
 
AttributeSet(String, AttributeSet, AttributeDefinition<?>[]) - Constructor for class org.infinispan.commons.configuration.attributes.AttributeSet
 
AttributeValidator<T> - Interface in org.infinispan.commons.configuration.attributes
AttributeValidator.
audit(Subject, AuditContext, String, AuthorizationPermission, AuditResponse) - Method in interface org.infinispan.security.AuditLogger
 
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.
AuditResponse - Enum in org.infinispan.security
 
auth(HotRodHeader, String, byte[]) - Method in class org.infinispan.server.hotrod.Authentication
 
AUTH - org.infinispan.server.hotrod.HotRodOperation
 
AUTH_DIGEST - org.infinispan.persistence.remote.configuration.Element
 
AUTH_EXTERNAL - org.infinispan.persistence.remote.configuration.Element
 
AUTH_MECH_LIST - org.infinispan.server.hotrod.HotRodOperation
 
AUTH_MECH_LIST_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
AUTH_PLAIN - org.infinispan.persistence.remote.configuration.Element
 
AUTH_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
authenticate(String) - Method in class org.infinispan.rest.InfinispanResponse
Adds www-authenticate header.
authenticate(String, String) - Method in interface org.infinispan.rest.authentication.SecurityDomain
Returns Subject based on user/password combination.
authenticateHeader() - Method in class org.infinispan.rest.InfinispanResponse
 
authentication() - Method in class org.infinispan.persistence.remote.configuration.AbstractSecurityConfigurationChildBuilder
 
authentication() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfiguration
 
authentication() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfigurationBuilder
 
authentication() - Method in class org.infinispan.server.hotrod.configuration.AbstractHotRodServerChildConfigurationBuilder
 
authentication() - Method in interface org.infinispan.server.hotrod.configuration.HotRodServerChildConfigurationBuilder
Configures authentication for this endpoint
authentication() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
 
authentication() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
 
Authentication - Class in org.infinispan.server.hotrod
Handler that when added will make sure authentication is applied to requests.
Authentication(Channel, Executor, HotRodServer) - Constructor for class org.infinispan.server.hotrod.Authentication
 
AUTHENTICATION - org.infinispan.persistence.remote.configuration.Element
 
AuthenticationConfiguration - Class in org.infinispan.persistence.remote.configuration
AuthenticationConfiguration.
AuthenticationConfiguration - Class in org.infinispan.server.hotrod.configuration
AuthenticationConfiguration.
AuthenticationConfiguration(AttributeSet) - Constructor for class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
 
AuthenticationConfigurationBuilder - Class in org.infinispan.persistence.remote.configuration
AuthenticationConfigurationBuilder.
AuthenticationConfigurationBuilder - Class in org.infinispan.server.hotrod.configuration
AuthenticationConfigurationBuilder.
AuthenticationConfigurationBuilder(SecurityConfigurationBuilder) - Constructor for class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
 
AuthenticationException - Exception in org.infinispan.rest.authentication
Exception thrown then authentication fails.
AuthenticationException(Optional<String>) - Constructor for exception org.infinispan.rest.authentication.AuthenticationException
Authenticator - Interface in org.infinispan.rest.authentication
Authentication mechanism.
authMechList(HotRodHeader) - Method in class org.infinispan.server.hotrod.Authentication
 
authMechListResponse(HotRodHeader, HotRodServer, ByteBufAllocator, Set<String>) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
 
authMechListResponse(HotRodHeader, HotRodServer, ByteBufAllocator, Set<String>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
 
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
 
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
 
AuthorizationPermission - Enum in org.infinispan.security
AuthorizationPermission.
AuthorizingCallbackHandler - Interface in org.infinispan.server.core.security
AuthorizingCallbackHandler.
authResponse(HotRodHeader, HotRodServer, ByteBufAllocator, byte[]) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
 
authResponse(HotRodHeader, HotRodServer, ByteBufAllocator, byte[]) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
 
AUTO - org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfiguration.ImplementationType
Deprecated.
 
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
 
autoChunkSize() - Method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfiguration
When the segment size is larger than this number of bytes, separate segments will be created of this particular size.
autoChunkSize(int) - Method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfigurationBuilder
When segment files are larger than this amount of bytes, the segment will be split into multiple chunks of this size.
autoCommit() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
If the cache is transactional (i.e.
autoCommit(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
If the cache is transactional (i.e.
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.
autoPersist(boolean) - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition.Builder
 
AVAILABILITY_INTERVAL - org.infinispan.configuration.parsing.Attribute
 
AVAILABILITY_INTERVAL - Static variable in class org.infinispan.configuration.cache.PersistenceConfiguration
 
AVAILABILITY_MODE - Static variable in interface org.infinispan.commons.marshall.Ids
 
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
 
available() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
 
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.counter.configuration.Reliability
If the cluster splits in multiple partition, all of them are allowed to continue read/update the counter.
AVAILABLE - org.infinispan.lock.configuration.Reliability
 
AVAILABLE - org.infinispan.partitionhandling.AvailabilityMode
Regular operation mode
AVAILABLE - Static variable in class org.infinispan.configuration.cache.JMXStatisticsConfiguration
 
availableProcessors() - Static method in class org.infinispan.commons.util.ProcessorInfo
Returns the number of processors available to this process.
avg(String) - Static method in interface org.infinispan.query.dsl.Expression
 
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
 
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).
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 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
 
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

backArrayOffset() - Method in class org.infinispan.commons.marshall.WrappedByteArray
 
backArrayOffset() - Method in interface org.infinispan.commons.marshall.WrappedBytes
The offset of where data starts in the backed array.
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.
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
 
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
 
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
 
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
 
backupSequencer - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
backupWrite(WriteCommand) - Method in interface org.infinispan.xsite.BackupSender
 
backupWrite(WriteCommand) - Method in class org.infinispan.xsite.BackupSenderImpl
 
badRequest(InfinispanSearchRequest, String, String) - Static method in class org.infinispan.rest.search.InfinispanSearchResponse
 
BALANCING_STRATEGY - org.infinispan.persistence.remote.configuration.Attribute
 
balancingStrategy() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
balancingStrategy(String) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
balancingStrategy(String) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
balancingStrategy(String) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
For replicated (vs distributed) Hot Rod server clusters, the client balances requests to the servers according to this strategy.
Base64 - Class in org.infinispan.commons.util
Deprecated.
Not currently used internally by Infinispan; will be removed in ver. 10. Other users are advised to replace it with Base64.
Base64.InputStream - Class in org.infinispan.commons.util
Deprecated.
A Base64.InputStream will read data from another java.io.InputStream, given in the constructor, and encode/decode to/from Base64 notation on the fly.
Base64.OutputStream - Class in org.infinispan.commons.util
Deprecated.
A Base64.OutputStream will write data to another java.io.OutputStream, given in the constructor, and encode/decode to/from Base64 notation on the fly.
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
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.
baseCfg - Variable in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
 
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
 
BaseExtendedStatisticsContainer - Class in org.infinispan.stats.container
Common logic for the ExtendedStatisticsContainer
BaseExtendedStatisticsContainer(int) - Constructor for class org.infinispan.stats.container.BaseExtendedStatisticsContainer
 
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
 
BaseProtoStreamMarshaller - Class in org.infinispan.query.remote.client
Provides the starting point for implementing a Marshaller that uses Protobuf encoding.
BaseProtoStreamMarshaller() - Constructor for class org.infinispan.query.remote.client.BaseProtoStreamMarshaller
 
BaseQueryResponse - Interface in org.infinispan.query.remote.client
 
BaseRequestProcessor - Class in org.infinispan.server.hotrod
 
BasicCache<K,​V> - Interface in org.infinispan.commons.api
BasicCache provides the common building block for the two different types of caches that Infinispan provides: embedded and remote.
BasicCacheContainer - Interface in org.infinispan.commons.api
BasicCacheContainer defines the methods used to obtain a BasicCache.
basicComponentRegistry - Variable in class org.infinispan.factories.AbstractNamedCacheComponentFactory
 
BasicConfiguration - Interface in org.infinispan.commons.configuration
BasicConfiguration provides the basis for concrete configurations.
BasicMultimapCache<K,​V> - Interface in org.infinispan.multimap.api
BasicMultimapCache provides the common API for the two different types of multimap caches that Infinispan provides: embedded and remote.
BATCH - org.infinispan.configuration.parsing.Parser.TransactionMode
 
BATCH_SIZE - org.infinispan.persistence.jdbc.configuration.Attribute
 
BATCH_SIZE - org.infinispan.persistence.jpa.configuration.Attribute
Deprecated.
BATCH_SIZE - Static variable in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
batchContainer - Variable in class org.infinispan.batch.AutoBatchSupport
 
BatchContainer - Class in org.infinispan.batch
A container for holding thread locals for batching, to be used with the BatchingCache.startBatch() and BatchingCache.endBatch(boolean) calls.
BatchContainer() - Constructor for class org.infinispan.batch.BatchContainer
 
BatchingCache - Interface in org.infinispan.commons.api
The BatchingCache is implemented by all caches which support batching
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() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
Deprecated.
batchSize() - Method in class org.infinispan.persistence.jpa.configuration.JpaStoreConfiguration
 
batchSize(int) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
batchSize(long) - Method in class org.infinispan.persistence.jpa.configuration.JpaStoreConfigurationBuilder
Deprecated.
BeanUtils - Class in org.infinispan.commons.util
Simple JavaBean manipulation helper methods
BeanUtils() - Constructor for class org.infinispan.commons.util.BeanUtils
 
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
 
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.statetransfer.StateConsumerImpl
 
begin() - Method in class org.infinispan.commons.tx.TransactionManagerImpl
 
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
 
beginTransaction(GlobalTransaction, boolean) - Method in class org.infinispan.stats.CacheStatisticManager
Signals the start of a transaction.
between(Object, Object) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Checks that the left argument is between the given range limits.
BI_FUNCTION_MAPPER - Static variable in interface org.infinispan.commons.marshall.Ids
 
BIAS_ACQUISITION - Static variable in class org.infinispan.configuration.cache.ClusteringConfiguration
 
BIAS_LIFESPAN - Static variable in class org.infinispan.configuration.cache.ClusteringConfiguration
 
BIAS_REVOCATION_RESPONSE - Static variable in interface org.infinispan.commons.marshall.Ids
 
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
 
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 - 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
 
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
 
BINARY - Static variable in interface org.infinispan.commons.dataconversion.EncoderIds
 
BINARY_CONVERTER - Static variable in class org.infinispan.server.core.ExternalizerIds
 
BINARY_FILTER - Static variable in class org.infinispan.server.core.ExternalizerIds
 
BINARY_FILTER_CONVERTER - Static variable in class org.infinispan.server.core.ExternalizerIds
 
BINARY_KEYED_JDBC_STORE - org.infinispan.persistence.jdbc.configuration.Element
 
BinaryEncoder - Class in org.infinispan.commons.dataconversion
Encoder for StoreType.BINARY.
BinaryEncoder(StreamingMarshaller) - Constructor for class org.infinispan.commons.dataconversion.BinaryEncoder
 
binaryParam() - Method in interface org.infinispan.filter.ParamKeyValueFilterConverterFactory
 
bind(ChannelHandlerContext, SocketAddress, ChannelPromise) - Method in class org.infinispan.server.core.transport.SaslQopHandler
 
bit() - Method in enum org.infinispan.server.hotrod.tx.ControlByte
 
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
 
bitSetOf(Enum<?>) - Static method in class org.infinispan.commons.util.EnumUtil
 
bitSetOf(Enum<?>[]) - Static method in class org.infinispan.commons.util.EnumUtil
 
bitSetOf(Enum<?>, Enum<?>) - Static method in class org.infinispan.commons.util.EnumUtil
 
bitSetOf(Enum<?>, Enum<?>, Enum<?>...) - Static method in class org.infinispan.commons.util.EnumUtil
 
bitSetOf(Collection<E>) - Static method in class org.infinispan.commons.util.EnumUtil
 
bitSetSize(long) - Static method in class org.infinispan.commons.util.EnumUtil
 
BitShift - Class in org.infinispan.server.hotrod
 
BitShift() - Constructor for class org.infinispan.server.hotrod.BitShift
 
BLOCK_SIZE - org.infinispan.persistence.leveldb.configuration.Attribute
 
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(CompletionStage<T>) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticRpcManager
 
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
 
BlockingThreadPoolExecutorFactory - Class in org.infinispan.commons.executors
 
BlockingThreadPoolExecutorFactory(int, int, int, long) - Constructor for class org.infinispan.commons.executors.BlockingThreadPoolExecutorFactory
 
blockSize(int) - Method in class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfigurationBuilder
Deprecated.
 
BlueprintGenerator - Class in org.infinispan.commons.util
 
BlueprintGenerator() - Constructor for class org.infinispan.commons.util.BlueprintGenerator
 
bool(ByteBuf) - Static method in class org.infinispan.server.hotrod.Intrinsics
 
Boolean(boolean) - Constructor for class org.infinispan.commons.util.ByRef.Boolean
 
BOOLEAN - Static variable in class org.infinispan.commons.equivalence.AnyEquivalence
Deprecated.
 
booleanResponse(HotRodHeader, HotRodServer, ByteBufAllocator, boolean) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
 
booleanResponse(HotRodHeader, HotRodServer, ByteBufAllocator, boolean) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
 
bootstrapComponents() - Method in class org.infinispan.factories.ComponentRegistry
Invoked before any ModuleCommandInitializer.
BORLAND_SUN - org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
 
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
BOUNDED_STRONG - org.infinispan.counter.api.CounterType
A strong consistent and bounded counter.
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
 
boxed() - Method in interface org.infinispan.DoubleCacheStream
boxed() - Method in interface org.infinispan.IntCacheStream
boxed() - Method in interface org.infinispan.LongCacheStream
branchQualifierLength() - Method in class org.infinispan.commons.tx.XidImpl
 
branchQualifierOffset() - Method in class org.infinispan.commons.tx.XidImpl
 
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
 
BROADCAST - org.infinispan.query.dsl.IndexedQueryMode
Query is sent to all nodes, and results are combined before returning to the caller.
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
 
buffer(int) - Static method in class org.infinispan.server.core.transport.ExtendedByteBuf
 
buffer(int) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
 
BUFFER_SIZE - org.infinispan.persistence.rest.configuration.Attribute
 
BUFFER_SIZE - Static variable in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfiguration
 
bufferSize() - Method in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfiguration
 
bufferSize(int) - Method in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfigurationBuilder
 
BufferSizePredictor - Interface in org.infinispan.commons.marshall
Buffer size predictor
build() - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition.Builder
 
build() - Method in interface org.infinispan.commons.marshall.MarshallUtil.UnboundedCollectionBuilder
 
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 class org.infinispan.counter.api.CounterConfiguration.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.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 interface org.infinispan.query.dsl.QueryBuilder
Builds the query object.
build() - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
Deprecated.
 
build() - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
 
build() - Method in class org.infinispan.rest.operations.mime.MimeMetadataBuilder
 
build() - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
 
build() - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
Builds a configuration object
build() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
 
build() - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
 
build() - Method in class org.infinispan.xsite.status.AbstractSiteStatusBuilder
 
build(boolean) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
build(boolean) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
 
build(boolean) - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
 
build(boolean) - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
 
build(int) - Method in interface org.infinispan.commons.marshall.MarshallUtil.ArrayBuilder
 
build(int) - Method in interface org.infinispan.commons.marshall.MarshallUtil.CollectionBuilder
 
build(int) - Method in interface org.infinispan.commons.marshall.MarshallUtil.EnumBuilder
 
build(int) - Method in interface org.infinispan.commons.marshall.MarshallUtil.MapBuilder
 
build(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
BuildContext - Interface in org.infinispan.lucene.directory
Building context to set construction parameters of Infinispan Directory instances
builder - Variable in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
builder - Variable in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
 
builder() - Method in class org.infinispan.container.entries.RemoteMetadata
 
builder() - Method in class org.infinispan.metadata.EmbeddedMetadata
 
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() - Method in class org.infinispan.rest.operations.mime.MimeMetadata
 
builder() - Method in class org.infinispan.server.memcached.MemcachedMetadata
 
builder(String, T) - Static method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
 
builder(String, T, Class<T>) - Static method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
 
builder(CounterType) - Static method in class org.infinispan.counter.api.CounterConfiguration
 
Builder<T> - Interface in org.infinispan.commons.configuration
Builder.
Builder() - Constructor for class org.infinispan.metadata.EmbeddedMetadata.Builder
 
builderFor(B) - Static method in class org.infinispan.commons.configuration.ConfigurationUtils
Returns the builder that was used to build this class.
builderForNonStrict(B) - Static method in class org.infinispan.commons.configuration.ConfigurationUtils
The same as ConfigurationUtils.builderFor(Object) except that it won't throw an exception if no builder class is found.
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
 
buildJmxDomain(String, MBeanServer, String) - Static method in class org.infinispan.commons.jmx.JmxUtil
Build the JMX domain name.
buildMetadata() - Method in class org.infinispan.server.memcached.MemcachedDecoder
 
buildMetadata(String, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.persistence.rest.metadata.EmbeddedMetadataHelper
 
buildMetadata(String, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.persistence.rest.metadata.MetadataHelper
 
buildMetadata(HotRodHeader, long, TimeUnitValue, long, TimeUnitValue) - Method in class org.infinispan.server.hotrod.HotRodServer
 
buildQueryBuilderForClass(Class<?>) - Method in interface org.infinispan.query.SearchManager
Provides the Hibernate Search DSL entrypoint to build full text queries.
buildRegistrar() - Method in class org.infinispan.jmx.AbstractJmxRegistration
 
buildRegistrar() - Method in class org.infinispan.jmx.CacheJmxRegistration
 
buildRegistrar() - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
 
BuiltBy - Annotation Type in org.infinispan.commons.configuration
BuiltBy.
BULK_GET - org.infinispan.server.hotrod.HotRodOperation
 
BULK_GET_KEYS - org.infinispan.server.hotrod.HotRodOperation
 
BULK_GET_KEYS_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
BULK_GET_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
BULK_READ - org.infinispan.security.AuthorizationPermission
Allows bulk-read operations (e.g.
BULK_WRITE - org.infinispan.security.AuthorizationPermission
Allows bulk-write operations (e.g.
bulkGetKeysResponse(HotRodHeader, HotRodServer, ByteBufAllocator, CloseableIterator<byte[]>) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
 
bulkGetKeysResponse(HotRodHeader, HotRodServer, ByteBufAllocator, CloseableIterator<byte[]>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
 
bulkGetResponse(HotRodHeader, HotRodServer, ByteBufAllocator, int, CacheSet<Map.Entry<byte[], byte[]>>) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
 
bulkGetResponse(HotRodHeader, HotRodServer, ByteBufAllocator, int, CacheSet<Map.Entry<byte[], byte[]>>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
 
ByRef<T> - Class in org.infinispan.commons.util
This class can be used to pass an argument by reference.
ByRef(T) - Constructor for class org.infinispan.commons.util.ByRef
 
ByRef.Boolean - Class in org.infinispan.commons.util
Implementation for primitive type
ByRef.Integer - Class in org.infinispan.commons.util
 
BYTE - Static variable in class org.infinispan.commons.equivalence.AnyEquivalence
Deprecated.
 
byte_(ByteBuf) - Static method in class org.infinispan.server.hotrod.Intrinsics
 
BYTE_ARRAY_WRAPPER - Static variable in interface org.infinispan.commons.dataconversion.WrapperIds
 
BYTE_BUFFER - Static variable in interface org.infinispan.commons.marshall.Ids
 
ByteArrayEquivalence - Class in org.infinispan.commons.equivalence
Deprecated. 
ByteArrayEquivalence() - Constructor for class org.infinispan.commons.equivalence.ByteArrayEquivalence
Deprecated.
 
ByteArrayWrapper - Class in org.infinispan.commons.dataconversion
Wraps byte[] on a WrappedByteArray to provide equality and hashCode support, leaving other objects unchanged.
ByteArrayWrapper() - Constructor for class org.infinispan.commons.dataconversion.ByteArrayWrapper
 
ByteBuffer - Interface in org.infinispan.commons.io
A byte buffer that exposes the internal byte array with minimal copying.
ByteBufferFactory - Interface in org.infinispan.commons.io
Used for building instances of ByteBuffer.
ByteBufferFactoryImpl - Class in org.infinispan.commons.io
 
ByteBufferFactoryImpl() - Constructor for class org.infinispan.commons.io.ByteBufferFactoryImpl
 
ByteBufferImpl - Class in org.infinispan.commons.io
A byte buffer that exposes the internal byte array with minimal copying
ByteBufferImpl - Class in org.infinispan.io
Deprecated.
ByteBufferImpl(byte[]) - Constructor for class org.infinispan.commons.io.ByteBufferImpl
 
ByteBufferImpl(byte[], int, int) - Constructor for class org.infinispan.commons.io.ByteBufferImpl
 
ByteBufferImpl(byte[], int, int) - Constructor for class org.infinispan.io.ByteBufferImpl
Deprecated.
 
ByteBufferImpl.Externalizer - Class in org.infinispan.commons.io
 
BYTES - org.infinispan.commons.util.MemoryUnit
 
bytesToHex(byte[]) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
 
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

C3P0ConnectionPool - Class in org.infinispan.persistence.jdbc.connectionfactory
Deprecated.
Support for the C3P0 connection pool will be removed in 10.0
C3P0ConnectionPool(ClassLoader, PooledConnectionFactoryConfiguration) - Constructor for class org.infinispan.persistence.jdbc.connectionfactory.C3P0ConnectionPool
Deprecated.
 
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.spring.session.AbstractInfinispanSessionRepository
 
cache - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
cache - Variable in class org.infinispan.xsite.AbstractCustomFailurePolicy
 
cache - Variable in class org.infinispan.xsite.BaseBackupReceiver
 
cache(String) - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
Deprecated.
cache(Cache<?, ?>) - Method in class org.infinispan.tasks.TaskContext
The cache against which this task will be executed.
cache(HotRodHeader, Subject) - Method in class org.infinispan.server.hotrod.HotRodServer
 
cache(HotRodHeader, Subject, String) - Method in class org.infinispan.server.hotrod.HotRodServer
 
Cache<K,​V> - Interface in org.infinispan
The central interface of Infinispan.
CACHE - org.infinispan.configuration.parsing.ParserScope
The cache scope
CACHE - org.infinispan.persistence.remote.configuration.Element
 
CACHE - org.infinispan.security.AuditContext
 
CACHE_CONTAINER - org.infinispan.configuration.parsing.Element
 
CACHE_CONTAINER - org.infinispan.configuration.parsing.ParserScope
The cache-container scope
CACHE_CREATE - org.infinispan.server.core.admin.AdminOperation
 
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_CREATED_EVENT - org.infinispan.server.hotrod.HotRodOperation
 
CACHE_ENTRY_EVICTED - org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_ENTRY_EXPIRED - org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_ENTRY_EXPIRED_EVENT - org.infinispan.server.hotrod.HotRodOperation
 
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_MODIFIED_EVENT - org.infinispan.server.hotrod.HotRodOperation
 
CACHE_ENTRY_PASSIVATED - org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_ENTRY_REMOVED - org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_ENTRY_REMOVED_EVENT - org.infinispan.server.hotrod.HotRodOperation
 
CACHE_ENTRY_VISITED - org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_EVENT_CONVERTER_AS_CONVERTER - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_EVENT_FILTER_AS_KEY_VALUE_FILTER - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_EVENT_FILTER_CONVERTER_AS_KEY_VALUE_FILTER_CONVERTER - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_FILTERS - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_JMX_GROUP - Static variable in class org.infinispan.jmx.CacheJmxRegistration
 
CACHE_JOIN_INFO - Static variable in interface org.infinispan.commons.marshall.Ids
 
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_NAME - org.infinispan.server.core.admin.AdminOperationParameter
 
CACHE_NAME - Static variable in class org.infinispan.factories.KnownComponentNames
 
CACHE_NAME - Static variable in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
CACHE_NOT_FOUND_RESPONSE - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_REMOVE - org.infinispan.server.core.admin.AdminOperation
 
CACHE_RPC_COMMAND - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_SIZE - org.infinispan.persistence.leveldb.configuration.Attribute
 
CACHE_STARTED - org.infinispan.notifications.cachemanagerlistener.event.Event.Type
 
CACHE_STATE - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_STATUS_RESPONSE - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_STOP_TIMEOUT - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
 
CACHE_STOPPED - org.infinispan.notifications.cachemanagerlistener.event.Event.Type
 
CACHE_TEMPLATE - org.infinispan.configuration.parsing.ParserScope
The cache template scope
CACHE_TEMPLATE - org.infinispan.server.core.admin.AdminOperationParameter
 
CACHE_TOPOLOGY - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_XID - Static variable in class org.infinispan.server.core.ExternalizerIds
 
CacheAware<K,​V> - Interface in org.infinispan.stream
Interface that describes how a cache can be injected into another object.
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
 
cacheConfiguration - Variable in class org.infinispan.server.memcached.MemcachedDecoder
 
CacheConfigurationException - Exception in org.infinispan.commons
An exception that represents an error in the configuration.
CacheConfigurationException(Exception) - Constructor for exception org.infinispan.commons.CacheConfigurationException
 
CacheConfigurationException(String) - Constructor for exception org.infinispan.commons.CacheConfigurationException
 
CacheConfigurationException(String, String) - Constructor for exception org.infinispan.commons.CacheConfigurationException
Deprecated.
CacheConfigurationException(String, Throwable) - Constructor for exception org.infinispan.commons.CacheConfigurationException
 
CacheContainer - Interface in org.infinispan.manager
 
CacheContainerAdmin<C extends CacheContainerAdmin,​A extends BasicConfiguration> - Interface in org.infinispan.commons.api
Administrative cache container operations.
CacheContainerAdmin.AdminFlag - Enum in org.infinispan.commons.api
Flags which affect only administrative operations
CacheContainerStats - Interface in org.infinispan.stats
Similar to Stats but in the scope of a single per node CacheContainer
cacheControl(CacheControl) - Method in class org.infinispan.rest.InfinispanCacheResponse
Adds Cache Control headers.
CacheControl - Class in org.infinispan.rest
A helper class for controlling Cache Control headers.
CacheCreateTask - Class in org.infinispan.server.core.admin.embeddedserver
Admin operation to create a cache Parameters: name the name of the cache to create flags any flags, e.g.
CacheCreateTask() - Constructor for class org.infinispan.server.core.admin.embeddedserver.CacheCreateTask
 
CACHED_THREAD_POOL - org.infinispan.configuration.parsing.Element
 
CACHED_VALUES - Static variable in enum org.infinispan.functional.Param.ReplicationMode
 
CachedThreadPoolExecutorFactory - Enum in org.infinispan.commons.executors
 
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.
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.
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
CacheException - Exception in org.infinispan.commons
Thrown when operations fail unexpectedly.
CacheException() - Constructor for exception org.infinispan.commons.CacheException
 
CacheException(String) - Constructor for exception org.infinispan.commons.CacheException
 
CacheException(String, Throwable) - Constructor for exception org.infinispan.commons.CacheException
 
CacheException(String, Throwable, boolean, boolean) - Constructor for exception org.infinispan.commons.CacheException
 
CacheException(Throwable) - Constructor for exception org.infinispan.commons.CacheException
 
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).
CacheFilters - Class in org.infinispan.filter
Static factory class that contains utility methods that can be used for performing proper transformations from KeyValueFilter, Converter and KeyValueFilterConverter to appropriate distributed stream instances.
CacheFilters.CacheFiltersExternalizer - Class in org.infinispan.filter
 
CacheFiltersExternalizer() - Constructor for class org.infinispan.filter.CacheFilters.CacheFiltersExternalizer
 
CacheGetOrCreateTask - Class in org.infinispan.server.core.admin.embeddedserver
Admin operation to create a cache Parameters: name the name of the cache to create template the name of the template to use configuration the XML configuration to use flags any flags, e.g.
CacheGetOrCreateTask() - Constructor for class org.infinispan.server.core.admin.embeddedserver.CacheGetOrCreateTask
 
CacheHealth - Interface in org.infinispan.health
Cache health information.
CacheIgnoreAware - Interface in org.infinispan.server.core
Defines an interface to be used when a cache is to be ignored by a server implementation.
CacheInvocationBuilder() - Constructor for class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
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
 
CacheListenerException - Exception in org.infinispan.commons
Wraps exceptions produced by listener implementations.
CacheListenerException() - Constructor for exception org.infinispan.commons.CacheListenerException
 
CacheListenerException(String) - Constructor for exception org.infinispan.commons.CacheListenerException
 
CacheListenerException(String, Throwable) - Constructor for exception org.infinispan.commons.CacheListenerException
 
CacheListenerException(Throwable) - Constructor for exception org.infinispan.commons.CacheListenerException
 
CacheLoader<K,​V> - Interface in org.infinispan.persistence.spi
Defines the logic for loading data from an external storage.
cacheManager - Variable in class org.infinispan.query.remote.CompatibilityProtoStreamMarshaller
 
cacheManager - Variable in class org.infinispan.server.core.AbstractProtocolServer
 
cacheManager(EmbeddedCacheManager) - Method in class org.infinispan.tasks.TaskContext
The cache manager with which this task should be executed
CACHEMANAGER - org.infinispan.security.AuditContext
 
CacheManagerJmxRegistration - Class in org.infinispan.jmx
Registers all the components from global component registry to the mbean server.
CacheManagerJmxRegistration() - Constructor for class org.infinispan.jmx.CacheManagerJmxRegistration
 
cacheManagerName() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
 
cacheManagerName(String) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
If JMX statistics are enabled, this property represents the name of this cache manager.
CacheManagerNotifier - Interface in org.infinispan.notifications.cachemanagerlistener
Notifications for the cache manager
CacheManagerNotifierImpl - Class in org.infinispan.notifications.cachemanagerlistener
Global, shared notifications on the cache manager.
CacheManagerNotifierImpl() - Constructor for class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
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
 
cacheManagerStarted(GlobalComponentRegistry) - Method in class org.infinispan.server.hotrod.LifecycleCallbacks
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
Deprecated.
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.lucene.LifecycleCallbacks
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.persistence.remote.LifecycleCallbacks
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.rest.LifecycleCallbacks
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.server.core.LifecycleCallbacks
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.server.hotrod.LifecycleCallbacks
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.server.memcached.LifecycleCallbacks
 
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
 
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.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
 
cacheName() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
cacheName() - Method in annotation type org.infinispan.spring.session.configuration.EnableInfinispanEmbeddedHttpSession
Cache name used for storing session data.
cacheName() - Method in annotation type org.infinispan.spring.session.configuration.EnableInfinispanRemoteHttpSession
Cache name used for storing session data.
CacheNameCollector - Interface in org.infinispan.server.hotrod.tx.table
Used by GlobalTxTable, it collects all the involved cache name when setting a decision for a transaction.
CacheNamesTask - Class in org.infinispan.server.core.admin.embeddedserver
Admin operation to obtain a list of caches
CacheNamesTask() - Constructor for class org.infinispan.server.core.admin.embeddedserver.CacheNamesTask
 
CacheNotFoundException - Exception in org.infinispan.rest.cachemanager.exceptions
 
CacheNotFoundException(String) - Constructor for exception org.infinispan.rest.cachemanager.exceptions.CacheNotFoundException
 
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.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
 
CacheOperations - Class in org.infinispan.rest.operations
REST Operations implementation.
CacheOperations(RestServerConfiguration, RestCacheManager<Object>) - Constructor for class org.infinispan.rest.operations.CacheOperations
Creates new instance of CacheOperations.
CacheOperationsHelper - Class in org.infinispan.rest.operations
 
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
 
CacheQuery<E> - Interface in org.infinispan.query
A cache-query is what will be returned when the getQuery() method is run on SearchManagerImpl.
CacheReindexTask - Class in org.infinispan.server.core.admin.embeddedserver
Admin operation to reindex a cache Parameters: name the name of the cache to reindex flags unused
CacheReindexTask() - Constructor for class org.infinispan.server.core.admin.embeddedserver.CacheReindexTask
 
CacheRemoveTask - Class in org.infinispan.server.core.admin.embeddedserver
Admin operation to remove a cache Parameters: name the name of the cache to remove flags
CacheRemoveTask() - Constructor for class org.infinispan.server.core.admin.embeddedserver.CacheRemoveTask
 
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
 
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
 
cacheSize(long) - Method in class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfigurationBuilder
Deprecated.
 
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
 
cacheStarting(ComponentRegistry, Configuration, String) - Method in class org.infinispan.server.hotrod.LifecycleCallbacks
 
CacheStatisticCollector - Class in org.infinispan.stats
Collects and maintains all the statistics for a cache.
CacheStatisticCollector(TimeService) - Constructor for class org.infinispan.stats.CacheStatisticCollector
 
CacheStatisticManager - Class in org.infinispan.stats
Manages all the statistics for a single cache.
CacheStatisticManager(Configuration, TimeService) - Constructor for class org.infinispan.stats.CacheStatisticManager
 
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(String) - Method in class org.infinispan.server.hotrod.HotRodServer
 
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<R> - Interface in org.infinispan
A Stream that has additional operations to monitor or control behavior when used from a Cache.
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
 
CacheUnavailableException - Exception in org.infinispan.rest.cachemanager.exceptions
 
CacheUnavailableException(String) - Constructor for exception org.infinispan.rest.cachemanager.exceptions.CacheUnavailableException
 
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
 
CacheUsageInterceptor - Class in org.infinispan.stats.topK
Intercepts the VisitableCommands to calculate the corresponding top-key values.
CacheUsageInterceptor() - Constructor for class org.infinispan.stats.topK.CacheUsageInterceptor
 
CacheWriter<K,​V> - Interface in org.infinispan.persistence.spi
Allows persisting data to an external storage, as opposed to the CacheLoader.
CacheXid - Class in org.infinispan.server.hotrod.tx.table
A key used in the global transaction table.
CacheXid(ByteString, XidImpl) - Constructor for class org.infinispan.server.hotrod.tx.table.CacheXid
 
calcCacheControl(Date) - Static method in class org.infinispan.rest.operations.CacheOperationsHelper
 
calcFreshness(Date) - Static method in class org.infinispan.rest.operations.CacheOperationsHelper
 
calculateConflictHash(ConsistentHash, Set<ConsistentHash>, List<Address>) - Method in class org.infinispan.topology.ClusterCacheStatus
 
calculateRank(ViewChangedEvent) - Method in class org.infinispan.container.versioning.NumericVersionGenerator.RankCalculator
 
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 interface org.infinispan.commons.util.EntrySizeCalculator
Method used to calculate how much memory in size the key and value use.
calculateSize(K, V) - Method in class org.infinispan.marshall.core.WrappedByteArraySizeCalculator
 
calculateSize(K, V, Metadata) - Method in class org.infinispan.container.entries.CacheEntrySizeCalculator
 
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
 
calculateState(long, long, long) - Static method in class org.infinispan.counter.util.Utils
Calculates the CounterState to use based on the value and the boundaries.
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.persistence.remote.upgrade.MigrationTask
 
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
callAsync() - Method in class org.infinispan.remoting.LocalInvocation
 
callbackHandler() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
 
callbackHandler(CallbackHandler) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
Specifies a CallbackHandler to be used during the authentication handshake.
CALLTIME - org.infinispan.jmx.annotations.DataType
 
canBlock() - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
 
canBlock() - Method in class org.infinispan.query.indexmanager.AbstractUpdateCommand
 
canBlock() - Method in class org.infinispan.server.hotrod.command.tx.ForwardCommitCommand
 
canBlock() - Method in class org.infinispan.server.hotrod.command.tx.ForwardRollbackCommand
 
canBlock() - Method in class org.infinispan.statetransfer.StateRequestCommand
 
canBlock() - Method in class org.infinispan.statetransfer.StateResponseCommand
 
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(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
 
CANCELED - org.infinispan.remoting.inboundhandler.action.ActionStatus
The action is completed unsuccessfully.
CANCELED - org.infinispan.remoting.inboundhandler.action.BaseLockingAction.InternalState
 
cancellationService - Variable in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
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
 
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.
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
 
canExpireMaxIdle() - Method in interface org.infinispan.container.entries.InternalCacheEntry
 
canExpireMaxIdle() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
canExpireMaxIdle() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
canExpireMaxIdle() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
canExpireMaxIdle() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
CANNOT_ASSUME_DENOM_IS_POWER_OF_TWO - Static variable in class org.infinispan.io.ModularArithmetic
 
canRead() - Method in class org.infinispan.io.GridFile
 
canWrite() - Method in class org.infinispan.io.GridFile
 
capacity() - Method in class org.infinispan.commons.util.SmallIntSet
Deprecated.
 
capacity() - Method in interface org.infinispan.container.DataContainer
Returns the capacity of the underlying container.
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.
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.
CAUSE - Static variable in interface org.infinispan.query.remote.json.JSONConstants
 
cdl - Variable in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
cdl - Variable in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
 
CERTIFICATE_PASSWORD - org.infinispan.persistence.remote.configuration.Attribute
 
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
 
challenge(InfinispanRequest) - Method in interface org.infinispan.rest.authentication.Authenticator
Challenges specific InfinispanRequest for authentication.
CHANGED - org.infinispan.container.entries.ReadCommittedEntry.Flags
 
channel - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
channel - Variable in class org.infinispan.server.hotrod.BaseRequestProcessor
 
CHANNEL_LOOKUP - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
channelActive(Channel) - Method in class org.infinispan.server.hotrod.counter.listener.ClientCounterManagerNotificationManager
 
channelActive(ChannelHandlerContext) - Method in class org.infinispan.server.core.transport.StatsChannelHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.infinispan.rest.cors.CorsHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.infinispan.server.core.transport.StatsChannelHandler
 
channelRead0(ChannelHandlerContext, FullHttpRequest) - Method in class org.infinispan.rest.Http11RequestHandler
 
channelRead0(ChannelHandlerContext, FullHttpRequest) - Method in class org.infinispan.rest.Http20RequestHandler
 
characteristics() - Method in class org.infinispan.commons.util.ArrayCollector
 
characteristics() - Method in class org.infinispan.commons.util.FilterSpliterator
 
characteristics() - Method in class org.infinispan.commons.util.FlattenSpliterator
 
characteristics() - Method in class org.infinispan.commons.util.SpliteratorMapper
 
charset(Charset) - Method in class org.infinispan.rest.InfinispanResponse
Adds a charset.
Charset - Class in org.infinispan.rest.operations.mediatypes
Represents Charset.
CHARSET - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
 
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
 
CheckedClassResolver - Class in org.infinispan.commons.marshall.jboss
 
CheckedClassResolver(ClassWhiteList, ClassLoader) - Constructor for class org.infinispan.commons.marshall.jboss.CheckedClassResolver
 
CheckedInputStream - Class in org.infinispan.commons.marshall
 
CheckedInputStream(InputStream, ClassWhiteList) - Constructor for class org.infinispan.commons.marshall.CheckedInputStream
 
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 interface org.infinispan.util.concurrent.locks.PendingLockManager
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, String) - Method in interface org.infinispan.security.AuthorizationManager
Verifies that the Subject has the requested permission and role.
checkPermission(AuthorizationPermission) - Method in interface org.infinispan.security.AuthorizationManager
Verifies that the Subject associated with the current AccessControlContext has the requested permission.
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(CachePermission) - Static method in class org.infinispan.security.Security
 
checkProtection() - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
 
checkResponse(Object, Address, boolean) - Method in class org.infinispan.remoting.transport.AbstractTransport
Deprecated.
 
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
 
CHUNK_CACHE_KEY - Static variable in interface org.infinispan.lucene.ExternalizerIds
 
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
 
ChunkCacheKey - Class in org.infinispan.lucene
Used as a key to distinguish file chunk in cache.
ChunkCacheKey(String, String, int, int, int) - Constructor for class org.infinispan.lucene.ChunkCacheKey
 
ChunkCacheKey.Externalizer - Class in org.infinispan.lucene
 
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.
chunkSize(int) - Method in interface org.infinispan.lucene.directory.BuildContext
Sets the chunkSize option for the Directory being created.
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
 
classBuilder(String, Class<T>) - Static method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
 
classes() - Method in annotation type org.infinispan.factories.annotations.DefaultFactoryFor
Components that may be constructed by a factory annotated with this annotation.
ClassFinder - Class in org.infinispan.commons.util
Find infinispan classes utility
ClassFinder() - Constructor for class org.infinispan.commons.util.ClassFinder
 
classLoader - Variable in class org.infinispan.factories.GlobalComponentRegistry
 
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
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.
ClassWhiteList - Class in org.infinispan.commons.configuration
The ClassWhiteList maintains classes definitions either by name or regular expression and is used for permissioning.
ClassWhiteList() - Constructor for class org.infinispan.commons.configuration.ClassWhiteList
 
ClassWhiteList(List<String>) - Constructor for class org.infinispan.commons.configuration.ClassWhiteList
 
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 interface org.infinispan.transaction.xa.CacheTransaction
It cleans up the backup locks for this transaction.
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 interface org.infinispan.Cache
Removes all mappings from the cache.
clear() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
Deprecated.
 
clear() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap.EntrySet
Deprecated.
 
clear() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap.Values
Deprecated.
 
clear() - Method in class org.infinispan.commons.equivalence.EquivalentHashSet
Deprecated.
Removes all of the elements from this set.
clear() - Method in class org.infinispan.commons.equivalence.EquivalentLinkedHashMap
Deprecated.
 
clear() - Method in class org.infinispan.commons.marshall.MarshallableTypeHints
Clear the cached marshallable type hints.
clear() - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
 
clear() - Method in class org.infinispan.commons.util.AbstractDelegatingMap
 
clear() - Method in class org.infinispan.commons.util.ArrayMap
 
clear() - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
 
clear() - Method in class org.infinispan.commons.util.concurrent.ConcurrentHashSet
 
clear() - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
Removes all of the mappings from this map.
clear() - Method in class org.infinispan.commons.util.FastCopyHashMap
 
clear() - Method in class org.infinispan.commons.util.FastCopyHashMap.EntrySet
 
clear() - Method in class org.infinispan.commons.util.FastCopyHashMap.KeySet
 
clear() - Method in class org.infinispan.commons.util.FastCopyHashMap.Values
 
clear() - Method in class org.infinispan.commons.util.ForwardingList
 
clear() - Method in class org.infinispan.commons.util.ImmutableHopscotchHashSet
 
clear() - Method in class org.infinispan.commons.util.RangeSet
Deprecated.
 
clear() - Method in class org.infinispan.commons.util.SmallIntSet
Deprecated.
 
clear() - Method in class org.infinispan.commons.util.WeakValueHashMap
 
clear() - Method in interface org.infinispan.container.DataContainer
Removes all entries in the container
clear() - Method in class org.infinispan.container.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 class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
clear() - Method in class org.infinispan.persistence.jpa.JpaStore
 
clear() - Method in class org.infinispan.persistence.remote.RemoteStore
 
clear() - Method in class org.infinispan.persistence.rest.RestStore
Deprecated.
 
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.spring.provider.SpringCache
 
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.persistence.jdbc.stringbased.JdbcStringBasedStore
 
clear(IntSet) - Method in class org.infinispan.persistence.remote.RemoteStore
 
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 - org.infinispan.server.hotrod.HotRodOperation
 
CLEAR_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
CLEAR_STATUS - org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand.StateTransferControl
 
CLEAR_THRESHOLD - org.infinispan.persistence.leveldb.configuration.Attribute
 
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 interface org.infinispan.commons.api.AsyncCache
Asynchronous version of Map.clear().
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
 
clearCounters() - Method in class org.infinispan.counter.configuration.CounterManagerConfigurationBuilder
Clears all the configured counters.
clearEntireCache(InfinispanCacheAPIRequest) - Method in class org.infinispan.rest.operations.CacheOperations
Implementation of HTTP DELETE request invoked on root context.
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 interface org.infinispan.scattered.ScatteredVersionManager
Forget all non-processed invalidations scheduled through ScatteredVersionManager.scheduleKeyInvalidation(Object, EntryVersion, boolean)
clearLockedKeys() - Method in interface org.infinispan.context.InvocationContext
 
clearLockedKeys() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
Deprecated.
 
clearLockedKeys() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
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
 
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
 
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.
 
clearThreshold(int) - Method in class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfigurationBuilder
Deprecated.
 
CLIENT_ADDRESS - Static variable in class org.infinispan.server.core.ExternalizerIds
 
CLIENT_ENCODING - Static variable in class org.infinispan.server.memcached.configuration.MemcachedServerConfiguration
 
CLIENT_ERROR_BAD_FORMAT - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
 
ClientAddress - Class in org.infinispan.server.hotrod.tx.table
A Address implementation for a client transaction.
ClientAddress(Address) - Constructor for class org.infinispan.server.hotrod.tx.table.ClientAddress
 
ClientCounterEvent - Class in org.infinispan.server.hotrod.counter.listener
A counter event to send to a client.
ClientCounterManagerNotificationManager - Class in org.infinispan.server.hotrod.counter.listener
The CounterManager notification manager.
ClientCounterManagerNotificationManager(CounterManager) - Constructor for class org.infinispan.server.hotrod.counter.listener.ClientCounterManagerNotificationManager
 
clientEncoding() - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfiguration
 
clientEncoding(MediaType) - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
The encoding to be used by clients of the memcached text protocol.
clientSubject() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
 
clientSubject(Subject) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
Sets the client subject, necessary for those SASL mechanisms which require it to access client credentials (i.e.
clone() - Method in class org.infinispan.commons.configuration.attributes.Attribute
 
clone() - Method in class org.infinispan.commons.util.FastCopyHashMap
 
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 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.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
 
clone() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
clone(Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
Deprecated.
 
cloneWithMarshaller(Marshaller, T) - Static method in class org.infinispan.commons.util.Util
Clones parameter x of type T with a given Marshaller reference;
close() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
 
close() - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
 
close() - Method in class org.infinispan.commons.util.Base64.OutputStream
Deprecated.
Flushes and closes (I think, in the superclass) the stream.
close() - Method in interface org.infinispan.commons.util.CloseableIterable
 
close() - Method in interface org.infinispan.commons.util.CloseableIterator
 
close() - Method in class org.infinispan.commons.util.CloseableIteratorMapper
Deprecated.
 
close() - Method in interface org.infinispan.commons.util.CloseableSpliterator
 
close() - Method in class org.infinispan.commons.util.CloseableSpliteratorMapper
Deprecated.
 
close() - Method in class org.infinispan.commons.util.ConcatIterator
 
close() - Method in class org.infinispan.commons.util.FilterIterator
 
close() - Method in class org.infinispan.commons.util.FilterSpliterator
 
close() - Method in class org.infinispan.commons.util.IteratorMapper
 
close() - Method in class org.infinispan.commons.util.RemovableCloseableIterator
 
close() - Method in class org.infinispan.commons.util.SpliteratorMapper
 
close() - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
 
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.persistence.jdbc.connectionfactory.C3P0ConnectionPool
Deprecated.
 
close() - Method in interface org.infinispan.persistence.jdbc.connectionfactory.ConnectionPool
 
close() - Method in class org.infinispan.persistence.jdbc.connectionfactory.HikariConnectionPool
 
close() - Method in class org.infinispan.persistence.util.PersistenceManagerCloseableSupplier
Deprecated.
 
close() - Method in interface org.infinispan.query.ResultIterator
This method must be called on your iterator once you have finished so that any local or remote resources can be freed up.
close() - Method in class org.infinispan.util.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(ChannelHandlerContext, ChannelPromise) - Method in class org.infinispan.server.core.transport.SaslQopHandler
 
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(AutoCloseable) - Static method in class org.infinispan.commons.util.Util
 
close(AutoCloseable...) - Static method in class org.infinispan.commons.util.Util
 
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.
close(String) - Method in class org.infinispan.server.hotrod.iteration.DefaultIterationManager
 
close(String) - Method in interface org.infinispan.server.hotrod.iteration.IterationManager
 
close(Socket) - Static method in class org.infinispan.commons.util.Util
 
close(Context) - Static method in class org.infinispan.commons.util.Util
 
CloseableIterable<E> - Interface in org.infinispan.commons.util
Interface that provides semantics of a Iterable and AutoCloseable interfaces.
CloseableIterator<E> - Interface in org.infinispan.commons.util
Interface that provides semantics of a Iterator and AutoCloseable interfaces.
CloseableIteratorCollection<E> - Interface in org.infinispan.commons.util
A collection that defines an iterator method that returns a CloseableIterator instead of a non closeable one.
CloseableIteratorCollectionAdapter<E> - Class in org.infinispan.commons.util
CloseableIteratorCollectionAdapter(Collection<E>) - Constructor for class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
 
CloseableIteratorMapper<E,​S> - Class in org.infinispan.commons.util
Deprecated.
since 9.3 users can just use IteratorMapper as it handles CloseableIterators now
CloseableIteratorMapper(Iterator<? extends E>, Function<? super E, ? extends S>) - Constructor for class org.infinispan.commons.util.CloseableIteratorMapper
Deprecated.
 
CloseableIteratorSet<E> - Interface in org.infinispan.commons.util
A set that defines an iterator method that returns a CloseableIterator instead of a non closeable one.
CloseableIteratorSetAdapter<E> - Class in org.infinispan.commons.util
CloseableIteratorSetAdapter(Set<E>) - Constructor for class org.infinispan.commons.util.CloseableIteratorSetAdapter
 
Closeables - Class in org.infinispan.commons.util
This class consists exclusively of static methods that operate on or return closeable interfaces.
Closeables - Class in org.infinispan.util
This class is used solely for the purpose of converting classes only in core to corresponding closeable variants.
CloseableSpliterator<T> - Interface in org.infinispan.commons.util
Interface that provides semantics of a Spliterator and AutoCloseable interfaces.
CloseableSpliteratorMapper<E,​S> - Class in org.infinispan.commons.util
Deprecated.
since 9.3 users can just use SpliteratorMapper as it handles CloseableSpliterators now
CloseableSpliteratorMapper(Spliterator<E>, Function<? super E, ? extends S>) - Constructor for class org.infinispan.commons.util.CloseableSpliteratorMapper
Deprecated.
 
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
 
closeMarshaller() - Method in interface org.infinispan.commons.marshall.jboss.RiverCloseListener
 
closeUnmarshaller() - Method in interface org.infinispan.commons.marshall.jboss.RiverCloseListener
 
CLUSTER - org.infinispan.configuration.parsing.Attribute
 
CLUSTER_EVENT - Static variable in interface org.infinispan.commons.marshall.Ids
 
CLUSTER_EVENT_CALLABLE - Static variable in interface org.infinispan.commons.marshall.Ids
 
CLUSTER_LISTENER_REMOVE_CALLABLE - Static variable in interface org.infinispan.commons.marshall.Ids
 
CLUSTER_LISTENER_REPLICATE_CALLABLE - Static variable in interface org.infinispan.commons.marshall.Ids
 
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.
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
clustered - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
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
 
CLUSTERED_GET_COMMAND_SIZE - org.infinispan.stats.container.ExtendedStatistic
 
CLUSTERED_LOCK - org.infinispan.lock.configuration.Element
 
CLUSTERED_LOCKS - org.infinispan.lock.configuration.Element
 
ClusteredCacheBackupReceiver - Class in org.infinispan.xsite
BackupReceiver implementation for clustered caches.
ClusteredCacheQueryImpl<E> - Class in org.infinispan.query.clustered
An extension of CacheQueryImpl used for distributed queries.
ClusteredCacheQueryImpl(Query, SearchIntegrator, ExecutorService, AdvancedCache<?, ?>, KeyTransformationHandler, Class<?>...) - Constructor for class org.infinispan.query.clustered.ClusteredCacheQueryImpl
 
ClusteredCacheQueryImpl(QueryDefinition, ExecutorService, AdvancedCache<?, ?>, KeyTransformationHandler, IndexedTypeMap<CustomTypeMetadata>) - Constructor for class org.infinispan.query.clustered.ClusteredCacheQueryImpl
 
clusteredDefault() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
Helper method that gets you a default constructed GlobalConfiguration, preconfigured to use the default clustering stack.
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
 
ClusteredLock - Interface in org.infinispan.lock.api
ClusteredLock is a data structure used for concurrent programming between Infinispan instances in cluster mode.
ClusteredLockConfiguration - Class in org.infinispan.lock.api
A Clustered Lock can be reentrant and there are different ownership levels.
ClusteredLockConfiguration - Class in org.infinispan.lock.configuration
ClusteredLock configuration.
ClusteredLockConfiguration() - Constructor for class org.infinispan.lock.api.ClusteredLockConfiguration
Default lock is non reentrant and the ownership level is OwnershipLevel.NODE
ClusteredLockConfigurationBuilder - Class in org.infinispan.lock.configuration
ClusteredLock configuration builder.
ClusteredLockConfigurationBuilder() - Constructor for class org.infinispan.lock.configuration.ClusteredLockConfigurationBuilder
 
ClusteredLockConfigurationParser - Class in org.infinispan.lock.configuration
Clustered Locks configuration parser
ClusteredLockConfigurationParser() - Constructor for class org.infinispan.lock.configuration.ClusteredLockConfigurationParser
 
ClusteredLockException - Exception in org.infinispan.lock.exception
Exception used to handle errors on clustered locks
ClusteredLockException(String) - Constructor for exception org.infinispan.lock.exception.ClusteredLockException
 
ClusteredLockException(Throwable) - Constructor for exception org.infinispan.lock.exception.ClusteredLockException
 
ClusteredLockManager - Interface in org.infinispan.lock.api
Provides the API to define, create and remove ClusteredLocks.
ClusteredLockManagerConfiguration - Class in org.infinispan.lock.configuration
The ClusteredLockManager configuration.
ClusteredLockManagerConfigurationBuilder - Class in org.infinispan.lock.configuration
The ClusteredLockManager configuration builder.
ClusteredLockManagerConfigurationBuilder(GlobalConfigurationBuilder) - Constructor for class org.infinispan.lock.configuration.ClusteredLockManagerConfigurationBuilder
 
ClusteredQueryCommand - Class in org.infinispan.query.clustered
Encapsulates all rpc calls for distributed queries actions.
ClusteredQueryCommand(ByteString) - Constructor for class org.infinispan.query.clustered.ClusteredQueryCommand
For CommandFactory only.
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
 
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.
ClusterHealth - Interface in org.infinispan.health
Cluster health information.
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
 
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.
clusterNodeName(String) - Method in class org.infinispan.rest.InfinispanCacheResponse
Adds Cluster-Node-Name header.
clusterPrimaryOwner(String) - Method in class org.infinispan.rest.InfinispanCacheResponse
Adds Cluster-Primary-Owner header.
clusterServerAddress(String) - Method in class org.infinispan.rest.InfinispanCacheResponse
Adds Cluster-Server-Address header.
clusterStatus() - Method in class org.infinispan.xsite.XSiteAdminOperations
 
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
 
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<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<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.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<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>, 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>, 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<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
CollectionAttributeCopier<T> - Class in org.infinispan.commons.configuration.attributes
CollectionAttributeCopier.
CollectionAttributeCopier() - Constructor for class org.infinispan.commons.configuration.attributes.CollectionAttributeCopier
 
CollectionExternalizer - Class in org.infinispan.marshall.exts
 
CollectionExternalizer() - Constructor for class org.infinispan.marshall.exts.CollectionExternalizer
 
CollectionFactory - Class in org.infinispan.commons.util
A factory for ConcurrentMaps.
CollectionFactory() - Constructor for class org.infinispan.commons.util.CollectionFactory
 
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
 
COLLECTIONS - Static variable in interface org.infinispan.commons.marshall.Ids
 
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
 
combiner() - Method in class org.infinispan.commons.util.ArrayCollector
 
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.query.affinity.AffinityUpdateCommand
 
COMMAND_ID - Static variable in class org.infinispan.query.clustered.ClusteredQueryCommand
 
COMMAND_ID - Static variable in class org.infinispan.query.indexmanager.IndexUpdateCommand
 
COMMAND_ID - Static variable in class org.infinispan.query.indexmanager.IndexUpdateStreamCommand
 
COMMAND_ID - Static variable in class org.infinispan.statetransfer.StateRequestCommand
 
COMMAND_ID - Static variable in class org.infinispan.statetransfer.StateResponseCommand
 
COMMAND_ID - Static variable in class org.infinispan.topology.CacheTopologyControlCommand
 
COMMAND_ID - Static variable in class org.infinispan.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.
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.
 
commandsFactory - Variable in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
 
commandsFactory - Variable in class org.infinispan.statetransfer.StateConsumerImpl
 
commandsFactory - Variable in class org.infinispan.statetransfer.StateProviderImpl
 
commandTopologyId - Variable in class org.infinispan.remoting.inboundhandler.DefaultTopologyRunnable
 
comment() - Method in annotation type org.infinispan.commons.util.Experimental
 
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.commons.tx.TransactionImpl
Attempt to commit this transaction.
commit() - Method in class org.infinispan.commons.tx.TransactionManagerImpl
 
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 class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
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_COMMAND_SIZE - org.infinispan.stats.container.ExtendedStatistic
 
COMMIT_EXECUTION_TIME - org.infinispan.stats.container.ExtendedStatistic
 
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.
COMMIT_TX - org.infinispan.server.hotrod.HotRodOperation
 
COMMIT_TX - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
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
 
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
 
commitLocalTransaction(AdvancedCache<?, ?>, XidImpl, long) - Static method in class org.infinispan.server.hotrod.tx.operation.Util
 
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.server.hotrod.tx.table.Status
The client transaction is committed.
CommitTransactionOperation - Class in org.infinispan.server.hotrod.tx.operation
It commits a transaction in all involved caches.
CommitTransactionOperation(HotRodHeader, HotRodServer, Subject, XidImpl, BiConsumer<HotRodHeader, Integer>) - Constructor for class org.infinispan.server.hotrod.tx.operation.CommitTransactionOperation
 
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
 
compare(byte[], byte[]) - Method in class org.infinispan.commons.equivalence.ByteArrayEquivalence
Deprecated.
 
compare(Object, Object) - Method in class org.infinispan.commons.equivalence.AnyServerEquivalence
Deprecated.
 
compare(T, T) - Method in class org.infinispan.commons.equivalence.AnyEquivalence
Deprecated.
 
compare(T, T) - Method in interface org.infinispan.commons.equivalence.Equivalence
Deprecated.
Compares the two given objects for order.
compare(T, T) - Method in class org.infinispan.commons.equivalence.IdentityEquivalence
Deprecated.
 
compareAndSet(long, long) - Method in interface org.infinispan.counter.api.StrongCounter
Atomically sets the value to the given updated value if the current value == the expected value.
compareAndSet(long, long) - Method in interface org.infinispan.counter.api.SyncStrongCounter
 
compareAndSwap(long, long) - Method in interface org.infinispan.counter.api.StrongCounter
Atomically sets the value to the given updated value if the current value == the expected value.
compareAndSwap(long, long) - Method in interface org.infinispan.counter.api.SyncStrongCounter
 
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.server.hotrod.ServerAddress
 
compareTo(Address) - Method in class org.infinispan.server.hotrod.tx.table.ClientAddress
 
compareTo(Address) - Method in class org.infinispan.topology.PersistentUUID
 
COMPAT - Static variable in interface org.infinispan.commons.dataconversion.EncoderIds
 
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
CompatibilityProtoStreamMarshaller - Class in org.infinispan.query.remote
A per EmbeddedCacheManager marshaller that should be used as compatibility mode marshaller in server.
CompatibilityProtoStreamMarshaller() - Constructor for class org.infinispan.query.remote.CompatibilityProtoStreamMarshaller
 
CompletableFutures - Class in org.infinispan.util.concurrent
Utility methods connecting CompletableFuture futures.
CompletableFutures() - Constructor for class org.infinispan.util.concurrent.CompletableFutures
 
complete() - Method in interface org.infinispan.scattered.BiasManager.Revocation
 
complete(T) - Method in class org.infinispan.remoting.transport.AbstractRequest
 
COMPLETE - org.infinispan.topology.RebalancingStatus
 
COMPLETE_FUNCTION - Static variable in class org.infinispan.server.core.ExternalizerIds
 
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.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.
completionQueue - Variable in class org.infinispan.distexec.DistributedExecutionCompletionService
 
CompletionStages - Class in org.infinispan.util.concurrent
Utility methods for handling CompletionStage instances.
COMPONENT_KEY - Static variable in class org.infinispan.jmx.ComponentsJmxRegistration
 
ComponentFactory - Interface in org.infinispan.factories
Factory for Infinispan components.
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 Stop
ComponentMetadataPersister - Class in org.infinispan.factories.components
A utility class used by the Infinispan build process to scan metadata and persist it.
ComponentMetadataPersister() - Constructor for class org.infinispan.factories.components.ComponentMetadataPersister
 
ComponentMetadataRepo - Class in org.infinispan.factories.components
This is a repository of component metadata, which is populated when the Infinispan core jar is loaded up.
ComponentMetadataRepo() - Constructor for class org.infinispan.factories.components.ComponentMetadataRepo
 
ComponentName - Annotation Type in org.infinispan.factories.annotations
Mechanism for specifying the name of components to retrieve
componentRegistry - Variable in class org.infinispan.factories.AbstractNamedCacheComponentFactory
Deprecated.
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.Completabl