Index

A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

ABORT_RATE - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
 
ABORTED - Enum constant in enum org.infinispan.transaction.impl.TransactionTable.CompletedTransactionStatus
 
AbstractApplicationPublisherBridge - Class in org.infinispan.spring.common.session
A bridge for passing events between Infinispan (both embedded and remote) and Spring.
AbstractApplicationPublisherBridge(SpringCache) - Constructor for class org.infinispan.spring.common.session.AbstractApplicationPublisherBridge
 
AbstractAsyncPublisherHandler<Target,Output,InitialResponse,NextResponse> - Class in org.infinispan.commons.reactive
Abstract handler that handles request and cancellation of a given non blocking resource.
AbstractAsyncPublisherHandler(int, Supplier<Target>, Target) - Constructor for class org.infinispan.commons.reactive.AbstractAsyncPublisherHandler
 
AbstractBytesObjectInput - Class in org.infinispan.marshall.core
Array backed ObjectInput implementation.
AbstractBytesObjectInput(byte[], int) - Constructor for class org.infinispan.marshall.core.AbstractBytesObjectInput
 
AbstractCacheBackedSet<K,V,E> - Class in org.infinispan.cache.impl
Entry or key set backed by a cache.
AbstractCacheBackedSet(CacheImpl<K, V>, Object, long) - Constructor for class org.infinispan.cache.impl.AbstractCacheBackedSet
 
AbstractCacheEventFilterConverter<K,V,C> - Class in org.infinispan.notifications.cachelistener.filter
AbstractCacheEventFilterConverter() - Constructor for class org.infinispan.notifications.cachelistener.filter.AbstractCacheEventFilterConverter
 
AbstractCacheStream<Original,T,S extends BaseStream<T,S>,S2 extends S> - Class in org.infinispan.stream.impl
Abstract stream that provides all of the common functionality required for all types of Streams including the various primitive types.
AbstractCacheStream(Address, boolean, InvocationContext, long, int, Executor, ComponentRegistry, Function<? super Original, ?>, ClusterPublisherManager<?, ?>) - Constructor for class org.infinispan.stream.impl.AbstractCacheStream
 
AbstractCacheStream(AbstractCacheStream<Original, T, S, S2>) - Constructor for class org.infinispan.stream.impl.AbstractCacheStream
 
AbstractCacheTransaction - Class in org.infinispan.transaction.impl
Base class for local and remote transaction.
AbstractCacheTransaction(GlobalTransaction, int, long) - Constructor for class org.infinispan.transaction.impl.AbstractCacheTransaction
 
AbstractClientEvent - Class in org.infinispan.client.hotrod.event.impl
 
AbstractClientEvent(byte[]) - Constructor for class org.infinispan.client.hotrod.event.impl.AbstractClientEvent
 
AbstractClusterStats - Class in org.infinispan.stats.impl
 
AbstractComponentFactory - Class in org.infinispan.factories
Factory that creates components used internally within Infinispan, and also wires dependencies into the components.
AbstractComponentFactory() - Constructor for class org.infinispan.factories.AbstractComponentFactory
 
AbstractComponentRegistry - Class in org.infinispan.factories
Deprecated.
Since 9.4, please use BasicComponentRegistry instead.
AbstractConfigurationChildBuilder - Class in org.infinispan.client.hotrod.configuration
AbstractConfigurationChildBuilder.
AbstractConfigurationChildBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
AbstractConfigurationReader - Class in org.infinispan.commons.configuration.io
 
AbstractConfigurationReader(ConfigurationResourceResolver, Properties, PropertyReplacer, NamingStrategy) - Constructor for class org.infinispan.commons.configuration.io.AbstractConfigurationReader
 
AbstractConfigurationWriter - Class in org.infinispan.commons.configuration.io
 
AbstractConfigurationWriter(Writer, int, boolean, boolean, NamingStrategy) - Constructor for class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
 
AbstractConfigurationWriter.Tag - Class in org.infinispan.commons.configuration.io
 
AbstractConsistentHash - Class in org.infinispan.distribution.ch.impl
 
AbstractConsistentHash(int, List<Address>, float[]) - Constructor for class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
AbstractConsistentHash(int, List<Address>, Map<Address, Float>) - Constructor for class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
AbstractConsistentHash(ScopedPersistentState) - Constructor for class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
AbstractConsistentHashFactory<CH extends ConsistentHash> - Class in org.infinispan.distribution.ch.impl
 
AbstractConsistentHashFactory() - Constructor for class org.infinispan.distribution.ch.impl.AbstractConsistentHashFactory
 
AbstractContainerStats - Class in org.infinispan.stats.impl
An abstract class to expose statistics of the local JVM.
AbstractCounterConfiguration - Class in org.infinispan.counter.configuration
Base counter configuration with its name, initial value and Storage mode.
AbstractCustomInterceptorsConfigurationChildBuilder - Class in org.infinispan.configuration.cache
Deprecated.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
AbstractCustomInterceptorsConfigurationChildBuilder(CustomInterceptorsConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractCustomInterceptorsConfigurationChildBuilder
Deprecated.
 
AbstractDelegatingAdvancedCache<K,V> - Class in org.infinispan.cache.impl
AbstractDelegatingAdvancedCache(AdvancedCache<K, V>) - Constructor for class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
AbstractDelegatingCache<K,V> - Class in org.infinispan.cache.impl
This is a convenient base class for implementing a cache delegate.
AbstractDelegatingCache(Cache<K, V>) - Constructor for class org.infinispan.cache.impl.AbstractDelegatingCache
 
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
 
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.impl
This is a convenient base class for implementing a cache manager delegate.
AbstractDelegatingEmbeddedCacheManager(EmbeddedCacheManager) - Constructor for class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
AbstractDelegatingInternalDataContainer<K,V> - Class in org.infinispan.container.impl
Delegating data container that delegates all calls to the container returned from AbstractDelegatingInternalDataContainer.delegate()
AbstractDelegatingInternalDataContainer() - Constructor for class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
AbstractDelegatingMap<K,V> - Class in org.infinispan.commons.util
 
AbstractDelegatingMap() - Constructor for class org.infinispan.commons.util.AbstractDelegatingMap
 
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.embedded
An abstract base class for factories creating cache managers that are backed by an EmbeddedCacheManager.
AbstractEmbeddedCacheManagerFactory() - Constructor for class org.infinispan.spring.embedded.AbstractEmbeddedCacheManagerFactory
 
AbstractEnlistmentAdapter - Class in org.infinispan.transaction.impl
Base class for both Sync and XAResource enlistment adapters.
AbstractEnlistmentAdapter() - Constructor for class org.infinispan.transaction.impl.AbstractEnlistmentAdapter
 
AbstractEnlistmentAdapter(CacheTransaction) - Constructor for class org.infinispan.transaction.impl.AbstractEnlistmentAdapter
 
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
 
AbstractFlagAffectedCommand - Class in org.infinispan.commands
Base class for those commands that can carry flags.
AbstractFlagAffectedCommand() - Constructor for class org.infinispan.commands.AbstractFlagAffectedCommand
 
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.common.session
Infinispan implementation for Spring Session with basic functionality.
AbstractInfinispanSessionRepository(SpringCache, AbstractApplicationPublisherBridge) - Constructor for class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository
 
AbstractInfinispanSessionRepository.InfinispanSession - Class in org.infinispan.spring.common.session
A custom implementation of Session that uses a MapSession as the basis for its mapping.
AbstractInternalCacheEntry - Class in org.infinispan.container.entries
An abstract internal cache entry that is typically stored in the data container
AbstractInternalCacheEntry(Object, Object, PrivateMetadata) - Constructor for class org.infinispan.container.entries.AbstractInternalCacheEntry
 
AbstractInternalDataContainer<K,V> - Class in org.infinispan.container.impl
Abstract class implemenation for a segmented data container.
AbstractInternalDataContainer() - Constructor for class org.infinispan.container.impl.AbstractInternalDataContainer
 
AbstractInternalDataContainer.EntryIterator - Class in org.infinispan.container.impl
 
AbstractInvocationBuilder() - Constructor for class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
AbstractInvocationContext - Class in org.infinispan.context.impl
Common features of transaction and invocation contexts
AbstractInvocationContext(Address) - Constructor for class org.infinispan.context.impl.AbstractInvocationContext
 
AbstractInvocationContextFactory - Class in org.infinispan.context.impl
Base class for InvocationContextFactory implementations.
AbstractInvocationContextFactory() - Constructor for class org.infinispan.context.impl.AbstractInvocationContextFactory
 
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.jboss.marshalling.commons
Deprecated.
since 11.0. To be removed in 14.0 ISPN-11947.
AbstractJBossMarshaller() - Constructor for class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller
Deprecated.
 
AbstractJBossMarshaller.DebuggingExceptionListener - Class in org.infinispan.jboss.marshalling.commons
Deprecated.
 
AbstractJdbcStoreConfiguration - Class in org.infinispan.persistence.jdbc.common.configuration
 
AbstractJdbcStoreConfiguration(AttributeSet, AsyncStoreConfiguration, ConnectionFactoryConfiguration) - Constructor for class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfiguration
 
AbstractJdbcStoreConfigurationBuilder<T extends AbstractJdbcStoreConfiguration,S extends AbstractJdbcStoreConfigurationBuilder<T,S>> - Class in org.infinispan.persistence.jdbc.common.configuration
 
AbstractJdbcStoreConfigurationBuilder(PersistenceConfigurationBuilder, AttributeSet) - Constructor for class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
 
AbstractJdbcStoreConfigurationChildBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,S>> - Class in org.infinispan.persistence.jdbc.common.configuration
AbstractJdbcStoreConfigurationChildBuilder.
AbstractJdbcStoreConfigurationChildBuilder(AbstractJdbcStoreConfigurationBuilder<?, S>) - Constructor for class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationChildBuilder
 
AbstractJdbcStoreConfigurationParser - Class in org.infinispan.persistence.jdbc.common.configuration
 
AbstractJdbcStoreConfigurationParser() - Constructor for class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationParser
 
AbstractJdbcStoreConfigurationSerializer - Class in org.infinispan.persistence.jdbc.common.configuration
AbstractJdbcStoreConfigurationSerializer.
AbstractJdbcStoreConfigurationSerializer() - Constructor for class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationSerializer
 
AbstractJGroupsChannelConfigurator - Class in org.infinispan.remoting.transport.jgroups
 
AbstractJGroupsChannelConfigurator() - Constructor for class org.infinispan.remoting.transport.jgroups.AbstractJGroupsChannelConfigurator
 
AbstractKeyValueFilterConverter<K,V,C> - Class in org.infinispan.filter
This is a base class that should be used when implementing a KeyValueFilterConverter that provides default implementations for the KeyValueFilter.accept(Object, Object, org.infinispan.metadata.Metadata) and Converter.convert(Object, Object, org.infinispan.metadata.Metadata) methods so they just call the KeyValueFilterConverter.filterAndConvert(Object, Object, org.infinispan.metadata.Metadata) method and then do the right thing.
AbstractKeyValueFilterConverter() - Constructor for class org.infinispan.filter.AbstractKeyValueFilterConverter
 
AbstractListenerImpl<T,L extends ListenerInvocation<T>> - Class in org.infinispan.notifications.impl
Functionality common to both CacheManagerNotifierImpl and CacheNotifierImpl
AbstractListenerImpl() - Constructor for class org.infinispan.notifications.impl.AbstractListenerImpl
 
AbstractListenerImpl.AbstractInvocationBuilder - Class in org.infinispan.notifications.impl
 
AbstractListenerImpl.ListenerInvocationImpl<A> - Class in org.infinispan.notifications.impl
Class that encapsulates a valid invocation for a given registered listener - containing a reference to the method to be invoked as well as the target object.
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
 
AbstractNamedCacheComponentFactory - Class in org.infinispan.factories
A component factory for creating components scoped per-cache.
AbstractNamedCacheComponentFactory() - Constructor for class org.infinispan.factories.AbstractNamedCacheComponentFactory
 
AbstractPassivationManager - Class in org.infinispan.eviction.impl
A passivation manager
AbstractPassivationManager() - Constructor for class org.infinispan.eviction.impl.AbstractPassivationManager
 
AbstractPersistenceConfigurationChildBuilder - Class in org.infinispan.configuration.cache
AbstractPersistenceConfigurationChildBuilder.
AbstractPersistenceConfigurationChildBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractPersistenceConfigurationChildBuilder
 
AbstractProtocolServer<C 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.remote
An abstract base class for factories creating cache manager that are backed by an Infinispan RemoteCacheManager.
AbstractRemoteCacheManagerFactory() - Constructor for class org.infinispan.spring.remote.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
 
AbstractSchemaJdbcConfiguration - Class in org.infinispan.persistence.sql.configuration
 
AbstractSchemaJdbcConfiguration(AttributeSet, AsyncStoreConfiguration, ConnectionFactoryConfiguration, SchemaJdbcConfiguration) - Constructor for class org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfiguration
 
AbstractSchemaJdbcConfigurationBuilder<T extends AbstractSchemaJdbcConfiguration,S extends AbstractSchemaJdbcConfigurationBuilder<T,S>> - Class in org.infinispan.persistence.sql.configuration
 
AbstractSchemaJdbcConfigurationBuilder(PersistenceConfigurationBuilder, AttributeSet) - Constructor for class org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfigurationBuilder
 
AbstractSchemaJdbcStore<K,V,C extends AbstractSchemaJdbcConfiguration> - Class in org.infinispan.persistence.sql
 
AbstractSchemaJdbcStore() - Constructor for class org.infinispan.persistence.sql.AbstractSchemaJdbcStore
 
AbstractSchemaJdbcStore.Parameter - Class in org.infinispan.persistence.sql
 
AbstractSchemaJdbcStore.ProtoSchemaOptions<K,V,C extends AbstractSchemaJdbcConfiguration> - Class in org.infinispan.persistence.sql
 
AbstractSchemaJdbcStore.ProtostreamFieldType - Enum in org.infinispan.persistence.sql
 
AbstractSchemaJdbcStore.SchemaTableOperations<K,V,C extends AbstractSchemaJdbcConfiguration> - Class in org.infinispan.persistence.sql
 
AbstractSecurityConfigurationChildBuilder - Class in org.infinispan.client.hotrod.configuration
AbstractSecurityConfigurationChildBuilder.
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) - 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(AttributeSet, AsyncStoreConfiguration) - 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, AttributeSet) - Constructor for class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
AbstractStoreConfigurationBuilder(PersistenceConfigurationBuilder, AttributeSet, 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
 
AbstractThreadPoolExecutorFactory<T extends ExecutorService> - Class in org.infinispan.factories.threads
Abstract ThreadPoolExecutorFactory that contains commons variables for configuring a thread pool
AbstractThreadPoolExecutorFactory(int, int, int, long) - Constructor for class org.infinispan.factories.threads.AbstractThreadPoolExecutorFactory
 
AbstractTopologyAffectedCommand - Class in org.infinispan.commands
Base class for commands that carry topology id.
AbstractTopologyAffectedCommand() - Constructor for class org.infinispan.commands.AbstractTopologyAffectedCommand
 
AbstractTranscoder - Class in org.infinispan.commons.dataconversion
Class to inherit when implementing transcoders, will handle pre and post processing of the content.
AbstractTranscoder() - Constructor for class org.infinispan.commons.dataconversion.AbstractTranscoder
 
AbstractTransport - Class in org.infinispan.remoting.transport
Deprecated.
Since 9.1, please implement Transport directly.
AbstractTransport() - Constructor for class org.infinispan.remoting.transport.AbstractTransport
Deprecated.
 
AbstractTransportConfigurationChildBuilder - Class in org.infinispan.configuration.cache
 
AbstractTransportConfigurationChildBuilder(TransactionConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractTransportConfigurationChildBuilder
 
AbstractTxInvocationContext<T extends AbstractCacheTransaction> - Class in org.infinispan.context.impl
Support class for TxInvocationContext.
AbstractTxInvocationContext(T, Address) - Constructor for class org.infinispan.context.impl.AbstractTxInvocationContext
 
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
 
AbstractUnmanagedConnectionFactoryConfiguration - Class in org.infinispan.persistence.jdbc.common.configuration
 
AbstractUnmanagedConnectionFactoryConfiguration(AttributeSet) - Constructor for class org.infinispan.persistence.jdbc.common.configuration.AbstractUnmanagedConnectionFactoryConfiguration
 
AbstractVisitor - Class in org.infinispan.commands
An abstract implementation of a Visitor that delegates all visit calls to a default handler which can be overridden.
AbstractVisitor() - Constructor for class org.infinispan.commands.AbstractVisitor
 
accept(long) - Method in class org.infinispan.commons.reactive.AbstractAsyncPublisherHandler
This method is invoked every time a new request is sent to the underlying publisher.
accept(long) - Method in class org.infinispan.reactive.publisher.impl.InnerPublisherSubscription
This method is invoked every time a new request is sent to the underlying publisher.
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(Void) - Method in class org.infinispan.client.hotrod.event.impl.ReconnectTask
 
accept(InetSocketAddress) - Method in class org.infinispan.server.core.transport.AccessControlFilter
 
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, 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 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, C, Object) - Method in interface org.infinispan.interceptors.InvocationSuccessAction
Process the result from a successful invocation stage and possibly throw an exception.
accept(InvocationContext, C, 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, Object, Metadata, Object, Metadata, EventType) - Method in class org.infinispan.globalstate.ScopeFilter
 
accept(EmbeddedCacheManager, Cache<K, V>) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerReplicateCallable
 
accept(LogAppender.WriteOperation) - Method in class org.infinispan.persistence.sifs.LogAppender
 
accept(ValidResponse, Throwable) - Method in class org.infinispan.remoting.transport.impl.XSiteResponseImpl
 
accept(T, U, V) - Method in interface org.infinispan.util.function.TriConsumer
Performs this operation on the given arguments.
ACCEPT_ALL_KEY_VALUE_FILTER - Static variable in interface org.infinispan.commons.marshall.Ids
 
ACCEPT_HEADER - Enum constant in enum org.infinispan.rest.RequestHeader
 
AcceptAllKeyValueFilter - Class in org.infinispan.filter
A key value filter that accepts all entries found.
AcceptAllKeyValueFilter.Externalizer - Class in org.infinispan.filter
 
acceptResponse(ByteBuf, short, HeaderDecoder) - Method in class org.infinispan.client.hotrod.counter.operation.AddListenerOperation
 
acceptResponse(ByteBuf, short, HeaderDecoder) - Method in class org.infinispan.client.hotrod.counter.operation.AddOperation
 
acceptResponse(ByteBuf, short, HeaderDecoder) - Method in class org.infinispan.client.hotrod.counter.operation.CompareAndSwapOperation
 
acceptResponse(ByteBuf, short, HeaderDecoder) - Method in class org.infinispan.client.hotrod.counter.operation.DefineCounterOperation
 
acceptResponse(ByteBuf, short, HeaderDecoder) - Method in class org.infinispan.client.hotrod.counter.operation.GetConfigurationOperation
 
acceptResponse(ByteBuf, short, HeaderDecoder) - Method in class org.infinispan.client.hotrod.counter.operation.GetCounterNamesOperation
 
acceptResponse(ByteBuf, short, HeaderDecoder) - Method in class org.infinispan.client.hotrod.counter.operation.GetValueOperation
 
acceptResponse(ByteBuf, short, HeaderDecoder) - Method in class org.infinispan.client.hotrod.counter.operation.IsDefinedOperation
 
acceptResponse(ByteBuf, short, HeaderDecoder) - Method in class org.infinispan.client.hotrod.counter.operation.RemoveListenerOperation
 
acceptResponse(ByteBuf, short, HeaderDecoder) - Method in class org.infinispan.client.hotrod.counter.operation.RemoveOperation
 
acceptResponse(ByteBuf, short, HeaderDecoder) - Method in class org.infinispan.client.hotrod.counter.operation.ResetOperation
 
acceptVisitor(InvocationContext, Visitor) - Method in interface org.infinispan.commands.VisitableCommand
Accept a visitor, and return the result of accepting this visitor.
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.expiration.impl.TouchCommand
 
ACCESS - Enum constant in enum org.infinispan.persistence.jdbc.common.DatabaseType
 
AccessControlFilter<A extends ProtocolServerConfiguration> - Class in org.infinispan.server.core.transport
This class provides the functionality to either accept or reject new Channels based on their IP address.
AccessControlFilter(A) - Constructor for class org.infinispan.server.core.transport.AccessControlFilter
 
AccessControlFilter(A, boolean) - Constructor for class org.infinispan.server.core.transport.AccessControlFilter
 
AccessControlFilter.AccessControlFilterEvent - Class in org.infinispan.server.core.transport
 
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
 
accumulate(BiConsumer<E, E>) - Static method in class org.infinispan.reactive.publisher.PublisherReducers
 
accumulator() - Method in class org.infinispan.commons.dataconversion.internal.JsonArrayCollector
 
accumulator() - Method in class org.infinispan.commons.util.ArrayCollector
 
ACCURATE_SIZE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
ACCURATE_SIZE - Static variable in class org.infinispan.configuration.global.GlobalMetricsConfiguration
 
accurateSize() - Method in class org.infinispan.configuration.global.GlobalMetricsConfiguration
Whether cache sizes should be computed
accurateSize(boolean) - Method in class org.infinispan.configuration.global.GlobalMetricsConfigurationBuilder
Enables accurate size computation for numberOfEntries statistics.
acquire(Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.InfinispanLock
It tries to acquire this lock.
acquire(Object, Object, long, TimeUnit) - Method in interface org.infinispan.util.concurrent.locks.impl.LockContainer
 
acquire(Object, Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.PerKeyLockContainer
 
acquire(Object, Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.StripedLockContainer
 
ACQUIRE_TIMEOUT - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
ACQUIRED - Enum constant in enum org.infinispan.util.concurrent.locks.LockState
The lock owner left the queue and it is available to acquire the lock.
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(Executor, 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) - Constructor for class org.infinispan.remoting.inboundhandler.action.ActionState
 
ActionStatus - Enum in org.infinispan.remoting.inboundhandler.action
The status for an Action.
activateAsync(Object, int) - Method in interface org.infinispan.eviction.impl.ActivationManager
Activates an entry, effectively removing it from the underlying persistence store.
activateAsync(Object, int) - Method in class org.infinispan.eviction.impl.ActivationManagerImpl
 
activateAsync(Object, int) - Method in class org.infinispan.eviction.impl.ActivationManagerStub
 
ActivationManager - Interface in org.infinispan.eviction.impl
Controls activation of cache entries that have been passivated.
ActivationManagerImpl - Class in org.infinispan.eviction.impl
Concrete implementation of activation logic manager.
ActivationManagerImpl() - Constructor for class org.infinispan.eviction.impl.ActivationManagerImpl
 
ActivationManagerStub - Class in org.infinispan.eviction.impl
 
ActivationManagerStub() - Constructor for class org.infinispan.eviction.impl.ActivationManagerStub
 
ACTIVE - Enum constant in enum 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
 
actual - Variable in class org.infinispan.persistence.support.DelegatingCacheLoader
 
actual - Variable in class org.infinispan.persistence.support.DelegatingCacheWriter
 
actual - Variable in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
actual() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
Deprecated.
 
actualCreateTableOperations(AbstractSchemaJdbcStore.ProtoSchemaOptions<K, V, C>) - Method in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore
Implementation specific method to return a table operations which will then be used appropriately for store operations.
actualCreateTableOperations(AbstractSchemaJdbcStore.ProtoSchemaOptions<K, V, QueriesJdbcStoreConfiguration>) - Method in class org.infinispan.persistence.sql.QueriesJdbcStore
 
actualCreateTableOperations(AbstractSchemaJdbcStore.ProtoSchemaOptions<K, V, TableJdbcStoreConfiguration>) - Method in class org.infinispan.persistence.sql.TableJdbcStore
 
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() - Static method in class org.infinispan.reactive.publisher.PublisherReducers
 
add(int) - Method in class org.infinispan.commons.util.ImmutableIntSet
 
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(long) - Method in class org.infinispan.counter.impl.SyncWeakCounterAdapter
 
add(E) - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
Adding new cache entries via a set is not allowed.
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.ForwardingList
 
add(E) - Method in class org.infinispan.commons.util.ImmutableHopscotchHashSet
 
add(E) - Method in class org.infinispan.commons.util.ImmutableListCopy
 
add(E) - Method in class org.infinispan.InternalCacheSet
 
add(Integer) - Method in class org.infinispan.commons.util.ImmutableIntSet
 
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.dataconversion.internal.Json
Add an arbitrary Java object to this Json array.
add(Object) - Method in class org.infinispan.commons.util.ArrayCollector
 
add(Object, String, Object) - Method in class org.infinispan.search.mapper.work.impl.SearchIndexerImpl
 
add(Object, String, Object) - Method in interface org.infinispan.search.mapper.work.SearchIndexer
 
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<CorsConfig>) - Method in class org.infinispan.rest.configuration.CorsConfigurationBuilder
 
add(List<XidImpl>) - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
 
add(Map.Entry<K, V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySet
 
add(Json) - Method in class org.infinispan.commons.dataconversion.internal.Json
Add the specified Json element to this array.
add(Json) - Method in class org.infinispan.commons.dataconversion.internal.JsonArrayCollector
 
add(CacheEntry<K, V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntrySet
 
add(ExtendedStatistic, double, boolean) - Method in class org.infinispan.extendedstats.container.ConcurrentGlobalContainer
 
add(ExtendedStatistic, double, GlobalTransaction, boolean) - Method in class org.infinispan.extendedstats.CacheStatisticManager
Adds a value to a statistic.
add(Listeners.ReadWriteListeners.ReadWriteListener<K, V>) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
 
add(Listeners.ReadWriteListeners.ReadWriteListener<K, V>) - Method in interface org.infinispan.functional.Listeners.ReadWriteListeners
Add a read-write listener, and return an AutoCloseable instance that can be used to remove the listener registration.
add(Listeners.WriteListeners.WriteListener<K, V>) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
 
add(Listeners.WriteListeners.WriteListener<K, V>) - Method in interface org.infinispan.functional.Listeners.WriteListeners
Add a write-only listener, and return an AutoCloseable instance that can be used to remove the listener registration.
add(MetaParam) - Method in class org.infinispan.functional.impl.MetaParams
 
add(MetaParam<?>) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata.Builder
 
add(Param<?>) - Method in class org.infinispan.functional.impl.Params
 
add(R) - Method in class org.infinispan.util.CollectionMapper
 
add(R) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
 
add(V, boolean) - Method in class org.infinispan.multimap.impl.Bucket
 
ADD_BLOOM_FILTER_CLIENT_LISTENER - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
ADD_BLOOM_FILTER_NEAR_CACHE_LISTENER_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
ADD_CLIENT_LISTENER - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
ADD_CLIENT_LISTENER_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
ADD_REMOTE_STORE - Static variable in interface org.infinispan.persistence.remote.ExternalizerIds
 
addAdvancedExternalizer(int, AdvancedExternalizer<T>) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
Deprecated.
since 10.0, AdvancedExternalizer's will be removed in a future release. Please utilise ProtoStream annotations on Java objects instead by configuring a SerializationContextInitializer via SerializationConfigurationBuilder.addContextInitializer(SerializationContextInitializer), or specifying a custom marshaller for user types via SerializationConfigurationBuilder.marshaller(Marshaller).
addAdvancedExternalizer(AdvancedExternalizer<T>) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
Deprecated.
since 10.0, AdvancedExternalizer's will be removed in a future release. Please utilise ProtoStream annotations on Java objects instead by configuring a SerializationContextInitializer via SerializationConfigurationBuilder.addContextInitializer(SerializationContextInitializer), or specifying a custom marshaller for user types via SerializationConfigurationBuilder.marshaller(Marshaller).
addAdvancedExternalizer(AdvancedExternalizer<T>...) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
Deprecated.
since 10.0, AdvancedExternalizer's will be removed in a future release. Please utilise ProtoStream annotations on Java objects instead by configuring a SerializationContextInitializer via SerializationConfigurationBuilder.addContextInitializer(SerializationContextInitializer), or specifying a custom marshaller for user types via SerializationConfigurationBuilder.marshaller(Marshaller).
addAffectedKey(Object) - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
addAffectedKey(Object) - Method in interface org.infinispan.context.impl.TxInvocationContext
 
addAffectedKey(Object) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
addAll(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<? extends E>) - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
Adding new cache entries via a set is not allowed.
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.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 E>) - Method in class org.infinispan.InternalCacheSet
 
addAll(Collection<? extends Integer>) - Method in class org.infinispan.commons.util.ImmutableIntSet
 
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 Map.Entry<K, V>>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySet
 
addAll(Collection<? extends CacheEntry<K, V>>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntrySet
 
addAll(Collection<? extends R>) - Method in class org.infinispan.util.CollectionMapper
 
addAll(Collection<? extends R>) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
 
addAll(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.
 
addAll(Params) - Method in class org.infinispan.functional.impl.Params
 
addAll(Param<?>...) - Method in class org.infinispan.functional.impl.Params
Adds all parameters and returns a new parameter collection.
addAllAffectedKeys(Collection<?>) - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
addAllAffectedKeys(Collection<?>) - Method in interface org.infinispan.context.impl.TxInvocationContext
Registers a new participant with the transaction.
addAllAffectedKeys(Collection<?>) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
addAllowedMech(String) - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
 
addAllowedMech(String) - Method in class org.infinispan.server.hotrod.configuration.SaslConfigurationBuilder
 
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
 
addAndGet(long) - Method in class org.infinispan.counter.impl.SyncStrongCounterAdapter
 
addBackup() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
addBackupLockForKey(Object) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
addBackupLockForKey(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
addBackupOwners(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
 
addBackupOwners(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.TopologyAwareConsistentHashFactory
 
addBoundedThreadPool(String) - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
 
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.
addCacheConfigurations(String...) - Method in class org.infinispan.server.core.backup.BackupManagerResources.Builder
 
addCacheDependency(String, String) - Method in class org.infinispan.manager.DefaultCacheManager
 
addCacheDependency(String, String) - Method in interface org.infinispan.manager.EmbeddedCacheManager
Add a dependency between two caches.
addCacheDependency(String, String) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
AddCacheDependencyAction - Class in org.infinispan.security.actions
AddCacheDependencyAction.
AddCacheDependencyAction(EmbeddedCacheManager, String, String) - Constructor for class org.infinispan.security.actions.AddCacheDependencyAction
 
addCachedThreadPool(String) - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
 
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
 
AddCacheManagerListenerAsyncAction - Class in org.infinispan.security.actions
CacheManagerAddListenerAction.
AddCacheManagerListenerAsyncAction(EmbeddedCacheManager, Object) - Constructor for class org.infinispan.security.actions.AddCacheManagerListenerAsyncAction
 
addCacheName(String, SiteStatus) - Method in class org.infinispan.xsite.status.ContainerSiteStatusBuilder
Adds the cache with the SiteStatus connection to the site.
addCaches(String...) - Method in class org.infinispan.server.core.backup.BackupManagerResources.Builder
 
addCallback(InvocationContext, C, InvocationCallback<C>) - Method in class org.infinispan.interceptors.InvocationStage
After the current stage completes, invoke function and return its result.
addCallback(InvocationContext, C, InvocationCallback<C>) - Method in class org.infinispan.interceptors.SyncInvocationStage
 
addCallback(InvocationContext, VisitableCommand, InvocationCallback) - Method in class org.infinispan.interceptors.ExceptionSyncInvocationStage
 
addChannelListener(ChannelListener) - Method in class org.infinispan.remoting.transport.jgroups.AbstractJGroupsChannelConfigurator
 
addChannelListener(ChannelListener) - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelConfigurator
 
addClass(String) - Method in class org.infinispan.configuration.global.AllowListConfigurationBuilder
Helper method that allows for registration of a class to the ClassAllowList.
addClass(String) - Method in class org.infinispan.configuration.global.WhiteListConfigurationBuilder
Deprecated.
Helper method that allows for registration of a class to the ClassAllowList.
addClasses(Class...) - Method in class org.infinispan.configuration.global.AllowListConfigurationBuilder
Helper method that allows for registration of classes to the ClassAllowList.
addClasses(Class...) - Method in class org.infinispan.configuration.global.WhiteListConfigurationBuilder
Deprecated.
Helper method that allows for registration of classes to the ClassAllowList.
addClasses(Class<?>...) - Method in class org.infinispan.commons.configuration.ClassAllowList
 
addClasses(String...) - Method in class org.infinispan.commons.configuration.ClassAllowList
 
addClasses(String...) - Method in class org.infinispan.configuration.global.AllowListConfigurationBuilder
Helper method that allows for registration of classes to the ClassAllowList.
addClientListener(Object) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
addClientListener(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
addClientListener(Object) - Method in interface org.infinispan.client.hotrod.RemoteCache
Add a client listener to receive events that happen in the remote cache.
addClientListener(Object, Object[], Object[]) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
addClientListener(Object, Object[], Object[]) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
addClientListener(Object, Object[], Object[]) - Method in interface org.infinispan.client.hotrod.RemoteCache
Add a client listener to receive events that happen in the remote cache.
addClientQueryListener(RemoteCache<?, ?>, Object, Query<?>) - Static method in class org.infinispan.client.hotrod.event.ClientEvents
Register a client listener that uses a query DSL based filter.
addCluster(String) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
addCluster(String) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
addCluster(String) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Adds a new remote server cluster
addClusteredLock() - Method in class org.infinispan.lock.configuration.ClusteredLockManagerConfigurationBuilder
 
addClusterLoader() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
Deprecated.
since 11.0. To be removed in 14.0 ISPN-11864 with no direct replacement.
addClusterNode(String, int) - Method in class org.infinispan.client.hotrod.configuration.ClusterConfigurationBuilder
 
addClusterNodes(String) - Method in class org.infinispan.client.hotrod.configuration.ClusterConfigurationBuilder
 
addContextInitializer(String) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
addContextInitializer(String) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
addContextInitializer(String) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Supply a SerializationContextInitializer implementation to register classes with the ProtoStreamMarshaller's SerializationContext.
addContextInitializer(SerializationContextInitializer) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
addContextInitializer(SerializationContextInitializer) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
addContextInitializer(SerializationContextInitializer) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Supply a SerializationContextInitializer implementation to register classes with the ProtoStreamMarshaller's SerializationContext.
addContextInitializer(SerializationContextInitializer) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
addContextInitializers(List<SerializationContextInitializer>) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
addContextInitializers(SerializationContextInitializer...) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
addContextInitializers(SerializationContextInitializer...) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
addContextInitializers(SerializationContextInitializer...) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Convenience method to supply multiple SerializationContextInitializer implementations.
addContextInitializers(SerializationContextInitializer...) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
addContinuousQueryListener(String, Map<String, Object>, ContinuousQueryListener<K, C>) - Method in class org.infinispan.client.hotrod.event.impl.ContinuousQueryImpl
 
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 class org.infinispan.client.hotrod.event.impl.ContinuousQueryImpl
 
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 class org.infinispan.client.hotrod.event.impl.ContinuousQueryImpl
Registers a continuous query listener that uses a query DSL based filter.
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
 
addCounters(String...) - Method in class org.infinispan.server.core.backup.BackupManagerResources.Builder
 
addCustomCacheConfiguration(ConfigurationBuilder) - Method in class org.infinispan.spring.embedded.AbstractEmbeddedCacheManagerFactory
Sets the ConfigurationBuilder to use when creating an EmbeddedCacheManager.
addCustomConfiguration(ConfigurationBuilder) - Method in class org.infinispan.spring.embedded.support.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.embedded.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
addDispatcher(EventDispatcher<?>) - Method in class org.infinispan.client.hotrod.event.impl.ClientListenerNotifier
 
addDynamicDependency(String, String) - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
Add a dynamic dependency between two components.
addDynamicDependency(String, String) - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
 
addEntityType(Class<?>) - Method in class org.infinispan.search.mapper.mapping.SearchMappingBuilder
Register a type as an entity type with the default name, its class name.
addEntityType(Class<?>, String) - Method in class org.infinispan.search.mapper.impl.InfinispanMappingInitiator
 
addEntityType(Class<?>, String) - Method in class org.infinispan.search.mapper.mapping.SearchMappingBuilder
Register a type as an entity type with the given name.
addEntityTypes(Set<Class<?>>) - Method in class org.infinispan.search.mapper.mapping.SearchMappingBuilder
 
addErroneousAttribute(String) - Method in exception org.infinispan.commons.CacheConfigurationException
Deprecated.
addEvents(Object, Address, UUID, Collection<ClusterEvent<K, V>>, boolean) - Method in interface org.infinispan.notifications.cachelistener.cluster.ClusterEventManager
Adds additional cluster events that need to be sent remotely for an event originating locally.
addEvents(Object, Address, UUID, Collection<ClusterEvent<K, V>>, boolean) - Method in class org.infinispan.notifications.cachelistener.cluster.impl.BatchingClusterEventManagerImpl
 
addEvents(Object, Address, UUID, Collection<ClusterEvent<K, V>>, boolean) - Method in class org.infinispan.notifications.cachelistener.cluster.impl.ClusterEventManagerStub
 
addException(Address, Exception) - Method in class org.infinispan.remoting.transport.impl.FilterMapResponseCollector
 
addException(Address, Exception) - Method in class org.infinispan.remoting.transport.impl.MapResponseCollector
 
addException(Address, Exception) - Method in class org.infinispan.remoting.transport.impl.VoidResponseCollector
 
addException(Address, Exception) - Method in class org.infinispan.remoting.transport.ValidResponseCollector
Process an exception from a target.
addExecutorProperty(String, String) - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfigurationBuilder
Add key/value property pair to this executor factory configuration
addExecutorProperty(String, String) - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
Add key/value property pair to this executor factory configuration
addFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
addFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.EncoderCache
 
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 interface org.infinispan.notifications.DataConversionAwareListenable
 
addFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
addFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.CacheImpl
 
addFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
addFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.EncoderCache
 
addFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
addFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in interface org.infinispan.notifications.FilteringListenable
addFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
addFilteredListenerAsync(ListenerHolder, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addFilteredListenerAsync(ListenerHolder, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in interface org.infinispan.notifications.DataConversionAwareListenable
 
addFlag(Flag) - Method in interface org.infinispan.commands.FlagAffectedCommand
Deprecated.
Since 9.0, please use FlagAffectedCommand.addFlags(long) with a FlagBitSets constant instead.
addFlags(long) - Method in interface org.infinispan.commands.FlagAffectedCommand
Add a set of flags to the command.
addFlags(Set<Flag>) - Method in interface org.infinispan.commands.FlagAffectedCommand
Deprecated.
Since 9.0, please use FlagAffectedCommand.addFlags(long) with a FlagBitSets constant instead.
addGet(Object, boolean) - Method in class org.infinispan.extendedstats.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
 
addIndexedEntities(Class<?>...) - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
 
addIndexedEntities(Class<?>...) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
addIndexedEntities(Class<?>...) - Method in interface org.infinispan.configuration.cache.IndexingConfigurationChildBuilder
 
addIndexedEntities(String...) - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
 
addIndexedEntities(String...) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
addIndexedEntities(String...) - Method in interface org.infinispan.configuration.cache.IndexingConfigurationChildBuilder
 
addIndexedEntity(Class<?>) - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
 
addIndexedEntity(Class<?>) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
addIndexedEntity(Class<?>) - Method in interface org.infinispan.configuration.cache.IndexingConfigurationChildBuilder
 
addIndexedEntity(String) - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
 
addIndexedEntity(String) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
addIndexedEntity(String) - Method in interface org.infinispan.configuration.cache.IndexingConfigurationChildBuilder
 
AddIndexingOperation - Class in org.infinispan.search.mapper.work.impl
 
addInterceptor() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
Deprecated.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
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
 
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
 
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
 
addIntermediateOperation(Queue<IntermediateOperation>, IntermediateOperation<T, S, ?, ?>) - Method in class org.infinispan.stream.impl.AbstractCacheStream
 
addIntermediateOperation(IntermediateOperation<T, S, T, S>) - Method in class org.infinispan.stream.impl.AbstractCacheStream
 
addIntermediateOperationMap(IntermediateOperation<T, S, ?, ?>) - Method in class org.infinispan.stream.impl.AbstractCacheStream
 
addInternalListener(InternalExpirationManager.ExpirationConsumer<K, V>) - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
addInternalListener(InternalExpirationManager.ExpirationConsumer<K, V>) - Method in interface org.infinispan.expiration.impl.InternalExpirationManager
Adds an InternalExpirationManager.ExpirationConsumer to be invoked when an entry is expired.
addInUseBackupSite(String) - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
Deprecated.
Since 14.0. To be removed without replacement.
addJavaSerialAllowList(String...) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
addJavaSerialAllowList(String...) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
addJavaSerialAllowList(String...) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
List of regular expressions for classes that can be deserialized using standard Java deserialization when reading data that might have been stored with a different endpoint, e.g.
addJavaSerialWhiteList(String...) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
Deprecated.
addJavaSerialWhiteList(String...) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
Deprecated.
addJavaSerialWhiteList(String...) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Deprecated.
addJGroupsStack(EmbeddedJGroupsChannelConfigurator, String) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
addJGroupsStack(FileJGroupsChannelConfigurator) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
addKeyTransformer(Class<?>, Class<?>) - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
 
addKeyTransformer(Class<?>, Class<?>) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
Registers a transformer for a key class.
addKeyTransformer(Class<?>, Class<?>) - Method in interface org.infinispan.configuration.cache.IndexingConfigurationChildBuilder
 
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(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
addListener(Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
addListener(Object) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
addListener(Object) - Method in interface org.infinispan.notifications.Listenable
Adds a listener to the component.
addListener(Object, ClassLoader) - Method in interface org.infinispan.notifications.ClassLoaderAwareListenable
Adds a listener along with a class loader to use for the invocation
addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.cache.impl.EncoderCache
 
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 interface org.infinispan.notifications.ClassLoaderAwareFilteringListenable
Adds a listener with the provided filter and converter and using a given classloader when invoked.
addListener(String, T) - Method in class org.infinispan.client.hotrod.counter.impl.NotificationManager
 
addListener(AttributeListener<T>) - Method in class org.infinispan.commons.configuration.attributes.Attribute
 
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.DefaultReadyAction
 
addListener(ActionListener) - Method in interface org.infinispan.remoting.inboundhandler.action.ReadyAction
It adds a listener that is invoked when this action is ready.
addListener(CacheTransaction.TransactionCompletedListener) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
addListener(CacheTransaction.TransactionCompletedListener) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
addListener(KeyAwareLockListener) - Method in interface org.infinispan.util.concurrent.locks.KeyAwareLockPromise
It adds the listener to this LockPromise.
addListener(LockListener) - Method in interface org.infinispan.util.concurrent.locks.LockPromise
Adds a LockListener to be invoked when the lock is available.
addListener(PendingLockListener) - Method in interface org.infinispan.util.concurrent.locks.PendingLockPromise
Adds a listener to this promise.
addListener(T) - Method in class org.infinispan.client.hotrod.counter.impl.BaseCounter
 
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.
addListenerAsync(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
addListenerAsync(Object) - Method in class org.infinispan.cache.impl.CacheImpl
 
addListenerAsync(Object) - Method in class org.infinispan.cache.impl.DecoratedCache
 
addListenerAsync(Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
addListenerAsync(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
addListenerAsync(Object) - Method in class org.infinispan.manager.DefaultCacheManager
 
addListenerAsync(Object) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
addListenerAsync(Object) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addListenerAsync(Object) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
addListenerAsync(Object) - Method in interface org.infinispan.notifications.Listenable
Asynchronous version of Listenable.addListener(Object)
addListenerAsync(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
addListenerAsync(Object, ClassLoader) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addListenerAsync(Object, ClassLoader) - Method in interface org.infinispan.notifications.ClassLoaderAwareListenable
addListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
addListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.cache.impl.CacheImpl
 
addListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
addListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.cache.impl.EncoderCache
 
addListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
addListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in interface org.infinispan.notifications.FilteringListenable
addListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
addListenerAsync(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.
addListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, ClassLoader) - Method in interface org.infinispan.notifications.ClassLoaderAwareFilteringListenable
 
addListenerAsync(ListenerHolder, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, ClassLoader) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addListenerAsync(ListenerHolder, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, ClassLoader) - Method in interface org.infinispan.notifications.DataConversionAwareListenable
 
AddListenerOperation - Class in org.infinispan.client.hotrod.counter.operation
AddListenerOperation(ChannelFactory, AtomicReference<ClientTopology>, Configuration, String, byte[], SocketAddress) - Constructor for class org.infinispan.client.hotrod.counter.operation.AddListenerOperation
 
addLocalBias(Object, int) - Method in interface org.infinispan.scattered.BiasManager
Allow reading local data if the topology is still actual.
addLocalBias(Object, int) - Method in class org.infinispan.scattered.impl.BiasManagerImpl
 
addLocalValue(ExtendedStatistic, double) - Method in class org.infinispan.extendedstats.CacheStatisticCollector
Adds a value to a local statistic.
addLockedKey(Object) - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
addLockedKey(Object) - Method in class org.infinispan.context.impl.ClearInvocationContext
 
addLockedKey(Object) - Method in class org.infinispan.context.impl.ImmutableContext
 
addLockedKey(Object) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
addLockedKey(Object) - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
 
addLockedKey(Object) - Method in interface org.infinispan.context.InvocationContext
Tracks the given key as locked by this invocation context.
addLockedKeys(Collection<?>) - Method in interface org.infinispan.context.InvocationContext
 
addLockInformation(Object, boolean, boolean) - Method in class org.infinispan.extendedstats.topK.StreamSummaryContainer
Adds the lock information about the key, namely if the key suffer some contention and if the keys was locked or not.
AddLoggerListenerAsyncAction - Class in org.infinispan.security.actions
Add logger listener action.
AddLoggerListenerAsyncAction(EmbeddedCacheManager, Object) - Constructor for class org.infinispan.security.actions.AddLoggerListenerAsyncAction
 
addMany(MetaParam...) - Method in class org.infinispan.functional.impl.MetaParams
 
addMarshalledEntry(Object, MarshallableEntry<Object, Object>) - Method in class org.infinispan.persistence.support.BatchModification
 
addMechanisms(String...) - Method in class org.infinispan.rest.configuration.AuthenticationConfigurationBuilder
 
addMechanisms(String...) - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
 
addMechanisms(String...) - Method in class org.infinispan.server.hotrod.configuration.SaslConfigurationBuilder
 
addMechProperty(String, String) - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
 
addMember(Address, boolean) - Method in class org.infinispan.xsite.status.CacheSiteStatusBuilder
Adds a member with an online/offline connection to the server based on the online parameter.
addMergePolicyFactory(EntryMergePolicyFactory) - Method in class org.infinispan.conflict.EntryMergePolicyFactoryRegistry
 
addModification(WriteCommand) - Method in class org.infinispan.transaction.impl.LocalTransaction
 
addModule(Class<T>) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
addModule(Class<T>) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
addNearCacheListener(Object, int) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
addNearCacheListener(Object, int) - Method in interface org.infinispan.client.hotrod.impl.InternalRemoteCache
Add a client listener to handle near cache with bloom filter optimization The listener object must be annotated with @ClientListener annotation.
addNearCacheListener(Object, int) - Method in class org.infinispan.client.hotrod.impl.InvalidatedNearRemoteCache
 
addNearCacheListener(Object, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
addNewRule() - Method in class org.infinispan.rest.configuration.CorsConfigurationBuilder
 
AddOperation - Class in org.infinispan.client.hotrod.counter.operation
Add operation.
AddOperation(ChannelFactory, AtomicReference<ClientTopology>, Configuration, String, long, boolean) - Constructor for class org.infinispan.client.hotrod.counter.operation.AddOperation
 
addOptionalParameter(String, Object) - Method in class org.infinispan.tasks.TaskContext
Adds a named parameter to the task context only if it is non-null
addOrUpdate(Object, String, Object) - Method in class org.infinispan.search.mapper.work.impl.SearchIndexerImpl
 
addOrUpdate(Object, String, Object) - Method in interface org.infinispan.search.mapper.work.SearchIndexer
 
AddOrUpdateIndexingOperation - Class in org.infinispan.search.mapper.work.impl
 
addOwner(int, Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
addOwner(Address) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfo
Adds owner as a node where this transaction information is maintained.
addOwners(int, Collection<Address>) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
addParameter(String, Object) - Method in class org.infinispan.tasks.TaskContext
Adds a named parameter to the task context
addParams(StringBuilder) - Method in class org.infinispan.client.hotrod.counter.operation.RemoveListenerOperation
 
addParserListener(ConfigurationParserListener) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
addPartialCommit1PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, List<WriteCommand>) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
addPartialCommit1PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, List<WriteCommand>) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
Adds a partially committed transaction.
addPartialCommit1PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, List<WriteCommand>) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
addPartialCommit2PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, Map<Object, IncrementableEntryVersion>) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
addPartialCommit2PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, Map<Object, IncrementableEntryVersion>) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
Adds a partially committed transaction.
addPartialCommit2PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, Map<Object, IncrementableEntryVersion>) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
addPartialRollbackTransaction(GlobalTransaction, Collection<Address>, Collection<Object>) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
addPartialRollbackTransaction(GlobalTransaction, Collection<Address>, Collection<Object>) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
Adds a partially aborted transaction.
addPartialRollbackTransaction(GlobalTransaction, Collection<Address>, Collection<Object>) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
addPersistenceInterceptors(AsyncInterceptorChain, Configuration, List<StoreConfiguration>) - Method in class org.infinispan.factories.InterceptorChainFactory
Adds all the interceptors related to persistence to the stack.
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
 
addPolicy(String) - Method in class org.infinispan.server.hotrod.configuration.SaslConfigurationBuilder
 
addPrimaryOwner(int, Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
addPrimaryOwner(int, Address) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
addPrimaryOwners(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
 
addProcessedDate(Date) - Method in interface org.infinispan.rest.framework.impl.RestResponseBuilder
 
addProcessedDate(Date) - Method in class org.infinispan.rest.framework.impl.SimpleRestResponse.Builder
 
addProcessedDate(Date) - Method in class org.infinispan.rest.NettyRestResponse.Builder
 
addProperty(String, Object) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
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.IndexingConfigurationBuilder
Deprecated.
Since 12.0, please use IndexingConfigurationBuilder.writer() and IndexingConfigurationBuilder.reader() to define indexing behavior.
addProperty(String, String) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
Deprecated.
 
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.GlobalJmxConfigurationBuilder
 
addProperty(String, String) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
Deprecated.
 
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.server.hotrod.configuration.SaslConfigurationBuilder
 
addProtoSchemas(String...) - Method in class org.infinispan.server.core.backup.BackupManagerResources.Builder
 
addPut(Object, boolean) - Method in class org.infinispan.extendedstats.topK.StreamSummaryContainer
Adds the key to the put top-key.
addQOP(String) - Method in class org.infinispan.server.hotrod.configuration.SaslConfigurationBuilder
 
addRegexp(String) - Method in class org.infinispan.configuration.global.AllowListConfigurationBuilder
Helper method that allows for registration of a regexp to the ClassAllowList.
addRegexp(String) - Method in class org.infinispan.configuration.global.WhiteListConfigurationBuilder
Deprecated.
Helper method that allows for registration of a regexp to the ClassAllowList.
addRegexps(String...) - Method in class org.infinispan.commons.configuration.ClassAllowList
 
addRegexps(String...) - Method in class org.infinispan.configuration.global.AllowListConfigurationBuilder
Helper method that allows for registration of regexps to the ClassAllowList.
addRegexps(String...) - Method in class org.infinispan.configuration.global.WhiteListConfigurationBuilder
Deprecated.
Helper method that allows for registration of regexps to the ClassAllowList.
addRemoteCache(String, Consumer<RemoteCacheConfigurationBuilder>) - Method in class org.infinispan.client.hotrod.configuration.Configuration
addRemoteSite(String, String, String, String) - Method in class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.RemoteSites
 
addRemoteValue(ExtendedStatistic, double) - Method in class org.infinispan.extendedstats.CacheStatisticCollector
Adds a value to a remote statistic.
addRemovalListener(Consumer<Iterable<InternalCacheEntry<K, V>>>) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
addRemovalListener(Consumer<Iterable<InternalCacheEntry<K, V>>>) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
addRemovalListener(Consumer<Iterable<InternalCacheEntry<K, V>>>) - Method in interface org.infinispan.container.impl.InternalDataContainer
Adds a listener that is invoked whenever InternalDataContainer.removeSegments(IntSet) is invoked providing a way for the listener to see what actual entries were removed from the container.
addRemovalListener(Consumer<Iterable<InternalCacheEntry<WrappedBytes, WrappedBytes>>>) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
addRequest(Request<?>) - Method in class org.infinispan.remoting.transport.impl.RequestRepository
 
addRequestor(Object, Address) - Method in class org.infinispan.distribution.impl.L1ManagerImpl
 
addRequestor(Object, Address) - Method in interface org.infinispan.distribution.L1Manager
Records a request that will be cached in another nodes L1
addResources(BackupManager.Resources.Type, String...) - Method in class org.infinispan.server.core.backup.BackupManagerResources.Builder
 
addResources(BackupManager.Resources.Type, Collection<String>) - Method in class org.infinispan.server.core.backup.BackupManagerResources.Builder
 
addResponse(long, Address, Response) - Method in class org.infinispan.remoting.transport.impl.RequestRepository
 
addResponse(Address, Response) - Method in class org.infinispan.remoting.transport.impl.PassthroughMapResponseCollector
 
addResponse(Address, Response) - Method in class org.infinispan.remoting.transport.impl.PassthroughSingleResponseCollector
 
addResponse(Address, Response) - Method in 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
 
addResponse(Address, Response) - Method in class org.infinispan.xsite.response.AutoStateTransferResponseCollector
 
address - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
address - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
address() - Method in class org.infinispan.client.hotrod.event.impl.EventDispatcher
 
Address - Interface in org.infinispan.remoting.transport
A destination for an Infinispan command or operation.
ADDRESS_COUNT - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
addresses() - Method in class org.infinispan.rest.distribution.CacheDistributionInfo
 
addresses() - Method in interface org.infinispan.rest.distribution.NodeDataDistribution
 
addresses() - Method in class org.infinispan.rest.distribution.NodeDistributionInfo
 
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
 
addRole(Role) - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
addRole(Role) - Method in class org.infinispan.security.mappers.ClusterPermissionMapper
 
addRole(Role) - Method in interface org.infinispan.security.MutableRolePermissionMapper
Adds a new role
addScheduledThreadPool(String) - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
 
addScript(String, String) - Method in interface org.infinispan.scripting.ScriptingManager
Adds a new named script.
addScripts(String...) - Method in class org.infinispan.server.core.backup.BackupManagerResources.Builder
 
addSegments(IntSet) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
addSegments(IntSet) - Method in class org.infinispan.container.impl.DefaultDataContainer
 
addSegments(IntSet) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
addSegments(IntSet) - Method in interface org.infinispan.container.impl.InternalDataContainer
Sets what segments this data container should be using.
addSegments(IntSet) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
addSegments(IntSet) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
addSegments(IntSet) - Method in class org.infinispan.persistence.async.AsyncNonBlockingStore
 
addSegments(IntSet) - Method in class org.infinispan.persistence.file.SingleFileStore
 
addSegments(IntSet) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
addSegments(IntSet) - Method in class org.infinispan.persistence.remote.RemoteStore
 
addSegments(IntSet) - Method in class org.infinispan.persistence.rocksdb.RocksDBStore
 
addSegments(IntSet) - Method in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
 
addSegments(IntSet) - Method in class org.infinispan.persistence.sifs.TemporaryTable
 
addSegments(IntSet) - Method in interface org.infinispan.persistence.spi.NonBlockingStore
Invoked when a node becomes an owner of the given segments.
addSegments(IntSet) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
Deprecated.
Invoked when a node becomes an owner of the given segments.
addSegments(IntSet) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
addSegments(IntSet) - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
 
addSegments(IntSet) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
 
addSegments(IntSet) - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
 
addServer() - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
addServer() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
addServer() - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Adds a new remote server
addServer() - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
addServer() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
addServer() - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
Adds a new remote server
addServers(String) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
addServers(String) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
addServers(String) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Adds a list of remote servers in the form: host1[:port][;host2[:port]]...
addShutdownHook() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
addShutdownHook() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
addSingleFileStore() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
Deprecated.
since 13.0. To be removed in 14.0 has been replaced by PersistenceConfigurationBuilder.addSoftIndexFileStore()
addSni() - Method in class org.infinispan.server.core.configuration.EncryptionConfigurationBuilder
 
addSoftIndexFileStore() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
Adds a soft index file cache store.
AddSourceRemoteStoreTask - Class in org.infinispan.persistence.remote.upgrade
Task to add a remote store to the cache.
AddSourceRemoteStoreTask(String, RemoteStoreConfiguration) - Constructor for class org.infinispan.persistence.remote.upgrade.AddSourceRemoteStoreTask
 
AddSourceRemoteStoreTask.Externalizer - Class in org.infinispan.persistence.remote.upgrade
 
addStack(String) - Method in class org.infinispan.configuration.global.JGroupsConfigurationBuilder
 
addStackFile(String) - Method in class org.infinispan.configuration.global.JGroupsConfigurationBuilder
 
addStats(String, String) - Method in class org.infinispan.client.hotrod.impl.ServerStatisticsImpl
 
addStorageFormatFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
addStorageFormatFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.EncoderCache
 
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.
addStorageFormatFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
addStorageFormatFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.CacheImpl
 
addStorageFormatFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
addStorageFormatFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.EncoderCache
 
addStorageFormatFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
addStorageFormatFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addStorageFormatFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in interface org.infinispan.notifications.FilteringListenable
addStorageFormatFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
addStore(Class<T>) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
Adds a cache loader that uses the specified builder class to build its configuration.
addStore(StoreConfiguration) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
 
addStore(StoreConfigurationBuilder<?, ?>) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
Adds a cache loader that uses the specified builder instance to build its configuration.
addStoreListener(PersistenceManager.StoreChangeListener) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
 
addStrength(String) - Method in class org.infinispan.server.hotrod.configuration.SaslConfigurationBuilder
 
addStrongCounter() - Method in class org.infinispan.counter.configuration.WeakCounterConfigurationBuilder
 
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.impl.FilterMapResponseCollector
 
addTargetNotFound(Address) - Method in class org.infinispan.remoting.transport.impl.VoidResponseCollector
 
addTargetNotFound(Address) - Method in class org.infinispan.remoting.transport.ValidResponseCollector
Process a target leaving the cluster or stopping the cache.
addTargets(Address, UUID, Collection<ClusterEvent<K, V>>, boolean) - Method in class org.infinispan.notifications.cachelistener.cluster.impl.BatchingClusterEventManagerImpl.UnicastEventContext
 
addThreadFactory(String) - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
 
addToFilter(E) - Method in class org.infinispan.commons.util.BloomFilter
Adds a value to the filter setting up to a number of bits equal to the number of hash functions.
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.impl.FilterMapResponseCollector
 
addValidResponse(Address, ValidResponse) - Method in class org.infinispan.remoting.transport.impl.MapResponseCollector
 
addValidResponse(Address, ValidResponse) - Method in class org.infinispan.remoting.transport.impl.VoidResponseCollector
 
addValidResponse(Address, ValidResponse) - Method in class org.infinispan.remoting.transport.ValidResponseCollector
Process a valid response from a target.
addValue(ExtendedStatistic, double) - Method in class org.infinispan.extendedstats.container.BaseExtendedStatisticsContainer
 
addValue(ExtendedStatistic, double) - Method in interface org.infinispan.extendedstats.container.ExtendedStatisticsContainer
it adds the value to the statistic.
addValue(ExtendedStatistic, double) - Method in class org.infinispan.extendedstats.TransactionStatistics
Adds a value to a statistic collected for this transaction.
addVersionRead(Object, EntryVersion) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
addVersionRead(Object, EntryVersion) - Method in interface org.infinispan.transaction.xa.CacheTransaction
Sets the version read for this key.
addVersionRead(TxInvocationContext<?>, CacheEntry<?, ?>, Object, VersionGenerator, Log) - Static method in class org.infinispan.transaction.impl.WriteSkewHelper
 
addWeakCounter() - Method in class org.infinispan.counter.configuration.WeakCounterConfigurationBuilder
 
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.extendedstats.topK.StreamSummaryContainer
Adds the key to the write skew failed top-key.
ADMIN - Enum constant in enum 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
 
adminEndpoint - Variable in class org.infinispan.server.core.AbstractProtocolServer
 
AdminFlagExternalizer - Class in org.infinispan.commons.marshall
 
AdminFlagExternalizer() - Constructor for class org.infinispan.commons.marshall.AdminFlagExternalizer
 
administration() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
Access to administration operations (cache creation, removal, etc)
administration() - Method in interface org.infinispan.manager.CacheContainer
Provides access to administrative methods which affect the underlying cache container, such as cache creation and removal.
administration() - Method in class org.infinispan.manager.DefaultCacheManager
 
administration() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Provides an EmbeddedCacheManagerAdmin whose methods affect the entire cluster as opposed to a single node.
administration() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
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(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 - Enum constant in enum org.infinispan.configuration.parsing.Element
 
ADVANCED_EXTERNALIZERS - Enum constant in enum org.infinispan.configuration.parsing.Element
 
ADVANCED_EXTERNALIZERS - Static variable in class org.infinispan.configuration.global.SerializationConfiguration
 
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
Deprecated.
since 11.0 replaced by NonBlockingStore
AdvancedCacheExpirationWriter.ExpirationPurgeListener<K,V> - Interface in org.infinispan.persistence.spi
Deprecated.
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
Deprecated.
since 11.0 replaced by NonBlockingStore
AdvancedCacheWriter<K,V> - Interface in org.infinispan.persistence.spi
Deprecated.
since 11.0 replaced by NonBlockingStore
AdvancedCacheWriter.PurgeListener<K> - Interface in org.infinispan.persistence.spi
Deprecated.
AdvancedExternalizer<T> - Interface in org.infinispan.commons.marshall
Deprecated.
since 10.0, will be removed in a future release. Please configure a SerializationContextInitializer and utilise ProtoStream annotations on Java objects instead, or specify a custom Marshaller implementation via the SerializationConfiguration.
advancedExternalizers() - Method in class org.infinispan.configuration.global.SerializationConfiguration
Deprecated.
since 10.0, AdvancedExternalizer's will be removed in a future release.
advancedLoader() - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
 
AdvancedLoadWriteStore<K,V> - Interface in org.infinispan.persistence.spi
Deprecated.
since 11.0 replaced by NonBlockingStore
advancedWriter() - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
 
affectedKeys - Variable in class org.infinispan.transaction.impl.AbstractCacheTransaction
Holds all the locked keys that were acquired by the transaction allover the cluster.
AffinityPartitioner - Class in org.infinispan.distribution.ch.impl
Key partitioner that maps keys to segments using information contained in AffinityTaggedKey.
AffinityPartitioner() - Constructor for class org.infinispan.distribution.ch.impl.AffinityPartitioner
 
AffinityTaggedKey - Interface in org.infinispan.distribution.ch
 
after() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
after(Class<? extends AsyncInterceptor>) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
Deprecated.
Dictates that the custom interceptor appears immediately after the specified interceptor.
AFTER - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
AFTER - Enum constant in enum 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
 
AFTER_FAILURES_FIELD - Static variable in class org.infinispan.rest.resources.XSiteResource
 
afterCompletion(int) - Method in class org.infinispan.transaction.synchronization.SynchronizationAdapter
 
afterCompletion(LocalTransaction, int) - Method in class org.infinispan.transaction.impl.TransactionTable
 
afterFailures() - Method in class org.infinispan.configuration.cache.TakeOfflineConfiguration
 
afterFailures(int) - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
The number of consecutive failed request operations after which this site should be taken offline.
afterPropertiesSet() - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository
 
afterPropertiesSet() - Method in class org.infinispan.spring.embedded.InfinispanDefaultCacheFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.embedded.provider.SpringEmbeddedCacheManagerFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.embedded.support.InfinispanEmbeddedCacheManagerFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.embedded.support.InfinispanNamedEmbeddedCacheFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.remote.provider.SpringRemoteCacheManagerFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.remote.support.InfinispanNamedRemoteCacheFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.remote.support.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
aggregation() - Method in class org.infinispan.search.mapper.scope.impl.SearchScopeImpl
 
aggregation() - Method in interface org.infinispan.search.mapper.scope.SearchScope
Initiate the building of a search aggregation that will be valid for the indexes in this scope.
ALIASES - Enum constant in enum 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 - Enum constant in enum org.infinispan.configuration.cache.Index
Deprecated.
All cluster nodes will add the entry to the index.
ALL - Enum constant in enum 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 - Enum constant in enum org.infinispan.manager.ClusterExecutionPolicy
The command can be executed on any node in the cluster
ALL - Enum constant in enum org.infinispan.security.AuthorizationPermission
Aggregate permission which implies all the others
ALL_GET_EXECUTION - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
 
ALL_NODES - Enum constant in enum org.infinispan.tasks.TaskExecutionMode
 
ALL_READ - Enum constant in enum org.infinispan.security.AuthorizationPermission
Aggregate permission which implies all read permissions
ALL_WRITE - Enum constant in enum 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.
allBackupsStream() - Method in class org.infinispan.configuration.cache.SitesConfiguration
 
allIndexedEntities() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
 
allIndexedEntities() - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
 
allIndexedEntityJavaClasses() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
 
allIndexedEntityJavaClasses() - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
 
allIndexedEntityNames() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
 
allIndexedEntityNames() - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
 
allMatch(DoublePredicate) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
allMatch(DoublePredicate) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
allMatch(IntPredicate) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
allMatch(IntPredicate) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
allMatch(LongPredicate) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
allMatch(LongPredicate) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
allMatch(Predicate<? super E>) - Static method in class org.infinispan.reactive.publisher.PublisherReducers
 
allMatch(Predicate<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
allMatch(Predicate<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
allMatch(Predicate<? super R>) - Method in class org.infinispan.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
 
allocList(int) - Method in class org.infinispan.server.hotrod.HotRodDecoder
 
allocMap(int) - Method in class org.infinispan.server.hotrod.HotRodDecoder
We usually know the size of the map ahead, and we want to return static empty map if we're not going to add anything.
allocSet(int) - Method in class org.infinispan.server.hotrod.HotRodDecoder
 
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 - Enum constant in enum org.infinispan.security.AuditResponse
 
ALLOW_CREDENTIALS - Static variable in class org.infinispan.rest.configuration.CorsRuleConfiguration
 
ALLOW_DUPLICATE_DOMAINS - Enum constant in enum org.infinispan.configuration.parsing.Attribute
Deprecated.
ALLOW_HEADERS - Static variable in class org.infinispan.rest.configuration.CorsRuleConfiguration
 
ALLOW_LIST - Enum constant in enum org.infinispan.configuration.parsing.Element
 
ALLOW_METHODS - Static variable in class org.infinispan.rest.configuration.CorsRuleConfiguration
 
ALLOW_ORIGINS - Static variable in class org.infinispan.rest.configuration.CorsRuleConfiguration
 
ALLOW_READ_WRITES - Enum constant in enum org.infinispan.partitionhandling.PartitionHandling
Allow entries on each partition to diverge, with conflicts resolved during merge.
ALLOW_READS - Enum constant in enum 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.
allowCredentials(boolean) - Method in class org.infinispan.rest.configuration.CorsRuleConfigurationBuilder
 
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
 
allowFrom(String) - Method in class org.infinispan.server.core.configuration.IpFilterConfigurationBuilder
 
allowHeaders(String[]) - Method in class org.infinispan.rest.configuration.CorsRuleConfigurationBuilder
 
allowInvocations() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
allowList() - Method in class org.infinispan.client.hotrod.event.impl.ClientListenerNotifier
 
allowList() - Method in class org.infinispan.configuration.global.SerializationConfiguration
 
allowList() - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
AllowListConfiguration - Class in org.infinispan.configuration.global
 
AllowListConfigurationBuilder - Class in org.infinispan.configuration.global
allowMethods(String[]) - Method in class org.infinispan.rest.configuration.CorsRuleConfigurationBuilder
 
allowMethodsToBlock(BlockHound.Builder, Class<?>, boolean) - Static method in class org.infinispan.commons.internal.CommonsBlockHoundIntegration
 
allowOrigins(String[]) - Method in class org.infinispan.rest.configuration.CorsRuleConfigurationBuilder
 
allowPublicMethodsToBlock(BlockHound.Builder, Class<?>) - Static method in class org.infinispan.commons.internal.CommonsBlockHoundIntegration
 
allStringsInterned - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
Implementation notice: the is instance variable that controls if newString() is interning.
allSubmissionExecutor(Predicate<? super Address>, EmbeddedCacheManager, Transport, long, TimeUnit, Executor, ScheduledExecutorService) - Static method in class org.infinispan.manager.impl.ClusterExecutors
 
allTypeIdentifiers() - Method in interface org.infinispan.search.mapper.session.impl.InfinispanTypeContextProvider
 
ALPNHandler - Class in org.infinispan.rest
Handler responsible for TLS/ALPN negotiation.
ALPNHandler(RestServer) - Constructor for class org.infinispan.rest.ALPNHandler
 
ALREADY_HAS_LOCK - Enum constant in enum org.infinispan.context.Flag
Flag to designate that this operation was performed on behalf of another that already has the lock for the given key.
ALREADY_HAS_LOCK - Static variable in class org.infinispan.context.impl.FlagBitSets
 
ALREADY_OFFLINE - Enum constant in enum org.infinispan.xsite.status.TakeSiteOfflineResponse
 
ALREADY_ONLINE - Enum constant in enum org.infinispan.xsite.status.BringSiteOnlineResponse
 
ALWAYS_REMOVE - Enum constant in enum org.infinispan.xsite.spi.XSiteMergePolicy
Always remove the key if there is a conflict.
ALWAYS_TRUE_LOGIC - Static variable in class org.infinispan.transaction.impl.WriteSkewHelper
 
AlwaysRemoveXSiteEntryMergePolicy<K,V> - Class in org.infinispan.xsite.spi
A XSiteEntryMergePolicy that removes the key if a conflict is detected.
alwaysTruePredicate() - Static method in class org.infinispan.stream.StreamMarshalling
Predicate taht always returns true irrespective of the value provided
amendChannel(JChannel) - Method in class org.infinispan.remoting.transport.jgroups.AbstractJGroupsChannelConfigurator
 
amendConfiguration(String, Integer, Long) - Method in class org.infinispan.xsite.status.DefaultTakeOfflineManager
 
amendConfiguration(String, Integer, Long) - Method in class org.infinispan.xsite.status.NoOpTakeOfflineManager
 
amendConfiguration(String, Integer, Long) - Method in interface org.infinispan.xsite.status.TakeOfflineManager
It changes the TakeOfflineConfiguration for site siteName.
and() - Method in interface org.infinispan.query.dsl.FilterConditionContext
Deprecated.
Creates a new context and connects it with the current one using boolean AND.
and() - Static method in class org.infinispan.reactive.publisher.PublisherReducers
 
and(FilterConditionContext) - Method in interface org.infinispan.query.dsl.FilterConditionContext
Deprecated.
Connects a given context with the current one using boolean AND.
andExceptionally(InvocationContext, C, InvocationExceptionFunction<C>) - Method in class org.infinispan.interceptors.InvocationStage
After the current stage completes exceptionally, invoke function and return its result.
andExceptionally(InvocationContext, C, InvocationExceptionFunction<C>) - Method in class org.infinispan.interceptors.SyncInvocationStage
 
andExceptionally(InvocationContext, VisitableCommand, InvocationExceptionFunction) - Method in class org.infinispan.interceptors.ExceptionSyncInvocationStage
 
andExceptionallyMakeStage(InvocationContext, C, InvocationExceptionFunction<C>) - Method in class org.infinispan.interceptors.InvocationStage
After the current stage completes exceptionally, invoke function and return its result.
andExceptionallyMakeStage(InvocationContext, C, InvocationExceptionFunction<C>) - Method in class org.infinispan.interceptors.SyncInvocationStage
 
andFinally(InvocationContext, C, InvocationFinallyAction<C>) - Method in class org.infinispan.interceptors.InvocationStage
After the current stage completes, invoke action.
andFinally(InvocationContext, C, InvocationFinallyAction<C>) - Method in class org.infinispan.interceptors.SyncInvocationStage
 
andFinally(InvocationContext, VisitableCommand, InvocationFinallyAction) - Method in class org.infinispan.interceptors.ExceptionSyncInvocationStage
 
andFinallyMakeStage(InvocationContext, C, InvocationFinallyAction<C>) - Method in class org.infinispan.interceptors.InvocationStage
After the current stage completes, invoke action.
andFinallyMakeStage(InvocationContext, C, InvocationFinallyAction<C>) - Method in class org.infinispan.interceptors.SyncInvocationStage
 
andHandle(InvocationContext, C, InvocationFinallyFunction<C>) - Method in class org.infinispan.interceptors.InvocationStage
After the current stage completes, invoke function and return its result.
andHandle(InvocationContext, C, InvocationFinallyFunction<C>) - Method in class org.infinispan.interceptors.SyncInvocationStage
 
andHandle(InvocationContext, VisitableCommand, InvocationFinallyFunction) - Method in class org.infinispan.interceptors.ExceptionSyncInvocationStage
 
andHandleMakeStage(InvocationContext, C, InvocationFinallyFunction<C>) - Method in class org.infinispan.interceptors.InvocationStage
After the current stage completes, invoke function and return its result.
andHandleMakeStage(InvocationContext, C, InvocationFinallyFunction<C>) - Method in class org.infinispan.interceptors.SyncInvocationStage
 
annotation - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
annotation - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
annotationValueReadHandleFactory() - Method in class org.infinispan.search.mapper.model.impl.InfinispanBootstrapIntrospector
 
anonymous() - Method in class org.infinispan.rest.framework.impl.InvocationImpl
 
anonymous() - Method in class org.infinispan.rest.framework.impl.InvocationImpl.Builder
 
anonymous() - Method in interface org.infinispan.rest.framework.Invocation
 
anonymous(boolean) - Method in class org.infinispan.rest.framework.impl.InvocationImpl.Builder
 
anyMatch(DoublePredicate) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
anyMatch(DoublePredicate) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
anyMatch(IntPredicate) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
anyMatch(IntPredicate) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
anyMatch(LongPredicate) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
anyMatch(LongPredicate) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
anyMatch(Predicate<? super E>) - Static method in class org.infinispan.reactive.publisher.PublisherReducers
 
anyMatch(Predicate<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
anyMatch(Predicate<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
anyMatch(Predicate<? super R>) - Method in class org.infinispan.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
AnyScopeComponentFactory - Class in org.infinispan.factories
 
AnyScopeComponentFactory() - Constructor for class org.infinispan.factories.AnyScopeComponentFactory
 
append(char) - Method in class org.infinispan.commons.io.StringBuilderWriter
 
append(CharSequence) - Method in class org.infinispan.commons.io.StringBuilderWriter
 
append(CharSequence, int, int) - Method in class org.infinispan.commons.io.StringBuilderWriter
 
append(WriteCommand) - Method in class org.infinispan.transaction.impl.ModificationList
Appends the WriteCommand to this list.
APPEND - Enum constant in enum org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.StackCombine
 
appendErrors(ErrorWriter) - Method in class org.infinispan.server.core.dataconversion.xml.MXParserReader
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheEntry
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.MortalCacheEntry
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.MortalCacheValue
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.TransientCacheEntry
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.TransientCacheValue
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
appendInterceptor(AsyncInterceptor, boolean) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Appends at the end.
appendInterceptor(AsyncInterceptor, boolean) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
AppendRequest - Enum constant in enum org.infinispan.server.memcached.MemcachedOperation
 
APPLICATION_INFINISPAN_BINARY - Static variable in class org.infinispan.commons.dataconversion.MediaType
Deprecated.
Since 11.0, will be removed in 14.0. No longer used for BINARY storage.
APPLICATION_INFINISPAN_BINARY_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
Deprecated.
Since 11.0, will be removed in 14.0. No longer used for BINARY storage.
APPLICATION_INFINISPAN_MARSHALLED - Static variable in class org.infinispan.commons.dataconversion.MediaType
Deprecated.
Since 11.0, will be removed with ISPN-9622
APPLICATION_INFINISPAN_MARSHALLING - Static variable in class org.infinispan.commons.dataconversion.MediaType
Deprecated.
Since 11.0, will be removed with ISPN-9622
APPLICATION_INFINISPAN_MARSHALLING_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
Deprecated.
Since 11.0, will be removed with ISPN-9622
APPLICATION_JAVASCRIPT - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_JAVASCRIPT_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_OPENMETRICS - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_OPENMETRICS_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
Deprecated.
Since 11.0, without replacement.
APPLICATION_UNKNOWN_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
Deprecated.
Since 11.0, without replacement.
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_YAML - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_YAML_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.common.session.AbstractInfinispanSessionRepository
 
apply(Object) - Method in class org.infinispan.cache.impl.FunctionMapper
 
apply(Object) - Method in class org.infinispan.remoting.LocalInvocation
 
apply(Object, Object) - Method in class org.infinispan.cache.impl.BiFunctionMapper
 
apply(String, MapSession) - Method in class org.infinispan.spring.common.session.SessionUpdateRemappingFunction
 
apply(Void) - Method in class org.infinispan.xsite.irac.IracExecutor
apply(Consumer<T>) - Method in class org.infinispan.commons.configuration.attributes.Attribute
 
apply(K) - Method in class org.infinispan.cache.impl.EncoderKeyMapper
 
apply(K, V) - Method in class org.infinispan.persistence.remote.upgrade.MigrationTask.EntryWriter
 
apply(CacheMode) - Method in enum org.infinispan.configuration.parsing.CacheParser.Mode
 
apply(InvocationContext, C, 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, C, 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, C, Object, Throwable) - Method in interface org.infinispan.interceptors.InvocationExceptionFunction
 
apply(InvocationContext, C, Object, Throwable) - Method in interface org.infinispan.interceptors.InvocationFinallyAction
 
apply(InvocationContext, C, Object, Throwable) - Method in interface org.infinispan.interceptors.InvocationSuccessAction
 
apply(InvocationContext, C, Object, Throwable) - Method in interface org.infinispan.interceptors.InvocationSuccessFunction
 
apply(InvocationContext, C, 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(EmbeddedCacheManager) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerRemoveCallable
 
apply(EmbeddedCacheManager) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerReplicateCallable
 
apply(EmbeddedCacheManager) - Method in class org.infinispan.persistence.remote.upgrade.AddSourceRemoteStoreTask
 
apply(EmbeddedCacheManager) - Method in class org.infinispan.persistence.remote.upgrade.CheckRemoteStoreTask
 
apply(EmbeddedCacheManager) - Method in class org.infinispan.persistence.remote.upgrade.DisconnectRemoteStoreTask
 
apply(EmbeddedCacheManager) - Method in class org.infinispan.persistence.remote.upgrade.MigrationTask
 
apply(EmbeddedCacheManager) - Method in class org.infinispan.rest.distribution.CacheDistributionRunnable
 
apply(SegmentPublisherSupplier.Notification<CacheEntry<K, V>>) - Method in interface org.infinispan.notifications.cachelistener.QueueingSegmentListener
This should be invoked on a notification before actually processing the data.
apply(Publisher<Object>) - Method in class org.infinispan.stream.impl.CacheIntermediatePublisher
 
apply(Publisher<Object>) - Method in class org.infinispan.stream.impl.CacheStreamIntermediateReducer
 
apply(T) - Method in class org.infinispan.cache.impl.EncoderEntryMapper
 
apply(T) - Method in interface org.infinispan.commons.dataconversion.internal.Json.Function
Applies this function to the given argument.
apply(V) - Method in class org.infinispan.cache.impl.EncoderValueMapper
 
APPLY_DELTA - Static variable in interface org.infinispan.commons.marshall.Ids
 
applyAsInt(Object) - Method in interface org.infinispan.distribution.ch.KeyPartitioner
 
applyListener(Caffeine<K, InternalCacheEntry<K, V>>, AbstractInternalDataContainer.DefaultEvictionListener) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
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
 
applyTo(BlockHound.Builder) - Method in class org.infinispan.commons.internal.CommonsBlockHoundIntegration
 
applyTo(BlockHound.Builder) - Method in class org.infinispan.lock.impl.ClusteredLockBlockHoundIntegration
 
applyTo(BlockHound.Builder) - Method in class org.infinispan.persistence.remote.internal.RemoteStoreBlockHoundIntegration
 
applyTo(BlockHound.Builder) - Method in class org.infinispan.persistence.rocksdb.internal.RocksDBBlockHoundIntegration
 
applyTo(BlockHound.Builder) - Method in class org.infinispan.query.internal.QueryBlockHoundIntegration
 
applyTo(BlockHound.Builder) - Method in class org.infinispan.rest.ServerRestBlockHoundIntegration
 
applyTo(BlockHound.Builder) - Method in class org.infinispan.server.core.ServerCoreBlockHoundIntegration
 
applyTo(BlockHound.Builder) - Method in class org.infinispan.server.hotrod.ServerHotRodBlockHoundIntegration
 
applyTo(BlockHound.Builder) - Method in class org.infinispan.util.CoreBlockHoundIntegration
 
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.
APPROXIMATE_ENTRIES - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Approximate current number of entry replicas in the cache on the server that receives the request.
APPROXIMATE_ENTRIES_UNIQUE - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Approximate current number of entries for which the server that receives the request is the primary owner.
approximateSize(Predicate<? super StoreConfiguration>, IntSet) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
 
approximateSize(IntSet) - Method in class org.infinispan.persistence.async.AsyncNonBlockingStore
 
approximateSize(IntSet) - Method in class org.infinispan.persistence.file.SingleFileStore
 
approximateSize(IntSet) - Method in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
 
approximateSize(IntSet) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
approximateSize(IntSet) - Method in class org.infinispan.persistence.remote.RemoteStore
 
approximateSize(IntSet) - Method in class org.infinispan.persistence.rocksdb.RocksDBStore
 
approximateSize(IntSet) - Method in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
 
approximateSize(IntSet) - Method in interface org.infinispan.persistence.spi.NonBlockingStore
Returns an estimation of the amount of entries that map to the given segments in the store.
approximateSize(IntSet) - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
 
approximateSize(IntSet) - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
 
array() - Static method in class org.infinispan.commons.dataconversion.internal.Json
 
array() - Method in class org.infinispan.commons.dataconversion.internal.Json.DefaultFactory
 
array() - Method in interface org.infinispan.commons.dataconversion.internal.Json.Factory
Construct and return a JSON object.
array(ByteBuf) - Static method in class org.infinispan.server.hotrod.Intrinsics
 
array(Object...) - Static method in class org.infinispan.commons.dataconversion.internal.Json
Return a new JSON array filled up with the list of arguments.
ArrayCollector - Class in org.infinispan.commons.util
 
ArrayCollector(Object[]) - Constructor for class org.infinispan.commons.util.ArrayCollector
 
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
 
arraysEqual(byte[], int, int, byte[], int, int) - Static method in class org.infinispan.commons.util.Util
This method is to be replaced by Java 9 Arrays#equals with the same arguments.
ARRIVAL_RATE - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
 
asBoolean() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
asByte() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
asBytes() - Method in class org.infinispan.query.remote.json.JsonQueryErrorResult
 
ASC - Enum constant in enum org.infinispan.query.dsl.SortOrder
Deprecated.
 
asChar() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
asCompletionException(Throwable) - Static method in class org.infinispan.commons.util.concurrent.CompletableFutures
 
asCounterManager(RemoteCacheManager) - Static method in class org.infinispan.client.hotrod.RemoteCounterManagerFactory
 
asCounterManager(EmbeddedCacheManager) - Static method in class org.infinispan.counter.EmbeddedCounterManagerFactory
 
asDouble() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
asDoubleStream() - Method in interface org.infinispan.IntCacheStream
asDoubleStream() - Method in interface org.infinispan.LongCacheStream
asDoubleStream() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
asDoubleStream() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
asDoubleStream() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
asDoubleStream() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
asExecutor(String) - Method in interface org.infinispan.util.concurrent.BlockingManager
Returns an executor that will run the given tasks on a blocking thread as required.
asExecutor(String) - Method in class org.infinispan.util.concurrent.BlockingManagerImpl
 
asFloat() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
asInteger() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
asIterator(Traversable<T>) - Static method in class org.infinispan.functional.impl.Traversables
 
asJsonList() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
asJsonMap() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
asList() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
asLong() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
asLongStream() - Method in interface org.infinispan.IntCacheStream
asLongStream() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
asLongStream() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
asMap() - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader
 
asMap() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
asPrepareResponse(Object) - Static method in class org.infinispan.remoting.responses.PrepareResponse
 
assertBatchingSupported(Configuration) - Static method in class org.infinispan.batch.AutoBatchSupport
 
assertCorrectlyConfigured() - Method in class org.infinispan.spring.remote.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
 
assertRemoteCacheManagerIsStarted() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
asSet(T...) - Static method in class org.infinispan.commons.util.Util
 
asShort() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
assignOwner(int, int, int, int[]) - Method in class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory.Builder
 
asString() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
asString() - Method in class org.infinispan.rest.ByteBufContentSource
 
asString() - Method in interface org.infinispan.rest.framework.ContentSource
 
asThreadPoolConfigurationBuilder() - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
 
asThreadPoolConfigurationBuilder() - Method in class org.infinispan.configuration.global.CachedThreadPoolConfigurationBuilder
 
asThreadPoolConfigurationBuilder() - Method in class org.infinispan.configuration.global.ScheduledThreadPoolConfigurationBuilder
 
asThreadPoolConfigurationBuilder() - Method in interface org.infinispan.configuration.global.ThreadPoolBuilderAdapter
 
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 - Enum constant in enum org.infinispan.configuration.cache.BackupConfiguration.BackupStrategy
 
ASYNC - Enum constant in enum org.infinispan.configuration.parsing.CacheParser.Mode
 
ASYNC - Enum constant in enum org.infinispan.configuration.parsing.Element
 
ASYNC - Enum constant in enum org.infinispan.expiration.TouchMode
Send touch commands to other owners, but do not wait for their confirmation.
ASYNC - Enum constant in enum org.infinispan.functional.Param.ReplicationMode
Invoking node does not know when the owners are updated nor if the command fails.
ASYNC_COMPLETE_NOTIFY_TIME - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
 
ASYNC_EXECUTOR - Enum constant in enum org.infinispan.configuration.parsing.Attribute
Deprecated.
ASYNC_EXECUTOR - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
 
ASYNC_EXECUTOR_FACTORY - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
ASYNC_MARSHALLING - Enum constant in enum org.infinispan.configuration.parsing.Attribute
Deprecated.
ASYNC_NOTIFICATION_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
ASYNC_TRANSPORT_EXECUTOR - Enum constant in enum org.infinispan.persistence.remote.configuration.Element
 
asyncAfterCompletion(int) - Method in interface org.infinispan.commons.tx.AsyncSynchronization
 
asyncAfterCompletion(int) - Method in class org.infinispan.transaction.synchronization.SynchronizationAdapter
 
asyncBackOff() - Method in interface org.infinispan.util.ExponentialBackOff
It returns a CompletionStage which is completed a certain amount of time before retries the request.
asyncBackOff() - Method in class org.infinispan.util.ExponentialBackOffImpl
 
asyncBackups(Configuration) - Static method in class org.infinispan.xsite.irac.DefaultIracManager
 
asyncBackupsStream() - Method in class org.infinispan.configuration.cache.SitesConfiguration
 
asyncBeforeCompletion() - Method in interface org.infinispan.commons.tx.AsyncSynchronization
 
asyncBeforeCompletion() - Method in class org.infinispan.transaction.synchronization.SynchronizationAdapter
 
AsyncCache<K,V> - Interface in org.infinispan.commons.api
AsyncCache.
asyncCommit(XidImpl, boolean) - Method in interface org.infinispan.commons.tx.AsyncXaResource
 
asyncCommit(XidImpl, boolean) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
asyncEnd(XidImpl, int) - Method in interface org.infinispan.commons.tx.AsyncXaResource
 
asyncEnd(XidImpl, int) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
asyncExecutor(String) - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
 
asyncExecutorFactory() - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
asyncExecutorFactory() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
asyncExecutorFactory() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
asyncExecutorFactory() - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Configuration for the executor service used for asynchronous work on the Transport, including asynchronous marshalling and Cache 'async operations' such as Cache.putAsync().
asyncExecutorFactory() - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
asyncExecutorFactory() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
asyncExecutorFactory() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
asyncExecutorFactory() - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
Configuration for the executor service used for asynchronous work on the Transport, including asynchronous marshalling and Cache 'async operations' such as Cache.putAsync().
ASYNCHRONOUS - Enum constant in enum 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.
asyncMassIndexerStarted() - Method in interface org.infinispan.rest.logging.Log
 
asyncMassIndexerSuccess() - Method in interface org.infinispan.rest.logging.Log
 
AsyncNonBlockingStore<K,V> - Class in org.infinispan.persistence.async
A delegating NonBlockingStore implementation that batches write operations and runs the resulting batches on the delegate store in a non overlapping manner.
AsyncNonBlockingStore(NonBlockingStore<K, V>) - Constructor for class org.infinispan.persistence.async.AsyncNonBlockingStore
 
asyncPrepare(XidImpl) - Method in interface org.infinispan.commons.tx.AsyncXaResource
 
asyncPrepare(XidImpl) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
asyncProcessor - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl
 
AsyncProviderState - Class in org.infinispan.xsite.statetransfer
A XSiteStateProviderState for asynchronous cross-site replication state transfer (IRAC).
asyncRollback(XidImpl) - Method in interface org.infinispan.commons.tx.AsyncXaResource
 
asyncRollback(XidImpl) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
AsyncStoreConfiguration - Class in org.infinispan.configuration.cache
Configuration for the async cache store.
AsyncStoreConfiguration(AttributeSet) - Constructor for class org.infinispan.configuration.cache.AsyncStoreConfiguration
 
AsyncStoreConfigurationBuilder<S> - Class in org.infinispan.configuration.cache
Configuration for the async cache store.
AsyncSynchronization - Interface in org.infinispan.commons.tx
Non-blocking Synchronization.
asyncThreadPool() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfiguration
Deprecated.
Since 11.0, no longer used.
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
asyncThreadPool() - Method in class org.infinispan.configuration.global.ThreadsConfiguration
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
 
asyncThreadPoolName() - Method in class org.infinispan.configuration.global.GlobalConfiguration
Deprecated.
Since 11.0, no longer used.
asyncThreadPoolName(String) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
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.
AsyncXaResource - Interface in org.infinispan.commons.tx
Non-blocking XAResource.
at(int) - Method in class org.infinispan.commons.dataconversion.internal.Json
Return the Json element at the specified index of this Json array.
at(String) - Method in class org.infinispan.commons.dataconversion.internal.Json
Return the specified property of a Json object or null if there's no such property.
at(String, Object) - Method in class org.infinispan.commons.dataconversion.internal.Json
Return the specified property of a Json object if it exists.
at(String, Json) - Method in class org.infinispan.commons.dataconversion.internal.Json
Return the specified property of a Json object if it exists.
AT_LEAST_ONCE - Enum constant in enum org.infinispan.reactive.publisher.impl.DeliveryGuarantee
The in between guarantee that provides a view of all data, but may return duplicates during a toplogy change.
AT_MOST_ONCE - Enum constant in enum org.infinispan.reactive.publisher.impl.DeliveryGuarantee
The least strict guarantee that ensures that data is never read more than once, but may be missed.
atDel(int) - Method in class org.infinispan.commons.dataconversion.internal.Json
Remove the element at the specified index from a Json array and return that element.
atDel(String) - Method in class org.infinispan.commons.dataconversion.internal.Json
Remove the specified property from a Json object and return that property.
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
 
attachFactory(Json.Factory) - Static method in class org.infinispan.commons.dataconversion.internal.Json
Attach a thread-local Json Json.Factory to be used specifically by this thread.
attachTo(Json) - Method in class org.infinispan.commons.dataconversion.internal.Json
Explicitly set the parent of this element.
attribute(Enum<?>) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
Returns the named attribute
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.common.configuration
Enumerates the attributes used by the JDBC cache stores configuration
Attribute - Enum in org.infinispan.persistence.remote.configuration
Enumerates the attributes used by the Remote cache store configuration
Attribute - Enum in org.infinispan.persistence.rocksdb.configuration
Enumerates the attributes used by the LevelDB cache stores configuration
Attribute - Enum in org.infinispan.server.hotrod.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.
attributeCount - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
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.AsyncStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.ClusterLoaderConfiguration
Deprecated.
 
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.InterceptorConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.MemoryStorageConfiguration
Deprecated.
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.ExecutorFactoryConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.GlobalStateConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.GlobalStatePathConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.GlobalStorageConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.JGroupsConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.PrincipalRoleMapperConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.RolePermissionMapperConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.StackConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.StackFileConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.TemporaryGlobalStatePathConfiguration
 
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.persistence.jdbc.common.configuration.AbstractJdbcStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfiguration
 
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.rocksdb.configuration.RocksDBExpirationConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.sifs.configuration.DataConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.sifs.configuration.IndexConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.rest.configuration.AuthenticationConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.rest.configuration.CorsRuleConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.rest.configuration.RestServerConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.core.configuration.EncryptionConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.core.configuration.SniConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.core.configuration.SslConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.hotrod.configuration.AuthenticationConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.hotrod.configuration.SaslConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.hotrod.configuration.TopologyCacheConfiguration
 
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.
AttributeMetadata(String, String, boolean, boolean, String, boolean, Function<?, ?>, BiConsumer<?, ?>) - Constructor for class org.infinispan.factories.impl.MBeanMetadata.AttributeMetadata
 
attributeName - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
attributeNameHash - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
AttributeParser<T> - Interface in org.infinispan.commons.configuration.attributes
AttributeParser.
attributePrefix - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
attributeRemoved(ConfigurationReader, int) - Static method in class org.infinispan.configuration.parsing.ParseUtils
 
attributeRemoved(ConfigurationReader, int, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
 
attributes - Variable in class org.infinispan.commons.configuration.AbstractTypedPropertiesConfiguration
 
attributes - Variable in class org.infinispan.commons.configuration.attributes.ConfigurationElement
 
attributes - Variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
attributes - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
attributes - Variable in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
attributes - Variable in class org.infinispan.persistence.jdbc.common.configuration.AbstractUnmanagedConnectionFactoryConfiguration
 
attributes - Variable in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
attributes - Variable in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.ClusterConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.NearCacheConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.SecurityConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.ServerConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.StatisticsConfiguration
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.StatisticsConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.TransactionConfigurationBuilder
Deprecated.
 
attributes() - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
 
attributes() - Method in class org.infinispan.commons.configuration.attributes.ConfigurationElement
 
attributes() - Method in interface org.infinispan.commons.configuration.Builder
 
attributes() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.ClusterLoaderConfiguration
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfiguration
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.IndexReaderConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.MemoryStorageConfiguration
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.cache.MemoryStorageConfigurationBuilder
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.QueryConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.QueryConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.SecurityConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.SecurityConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.StatisticsConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.AllowListConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.AllowListConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.CachedThreadPoolConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.GlobalJmxConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.GlobalJmxConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.GlobalMetricsConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.GlobalMetricsConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.GlobalSecurityConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.GlobalStatePathConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.GlobalStatePathConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.GlobalStorageConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.GlobalStorageConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.JGroupsConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.JGroupsConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.PrincipalRoleMapperConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.PrincipalRoleMapperConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.RolePermissionMapperConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.RolePermissionMapperConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.ScheduledThreadPoolConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.SerializationConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.ShutdownConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.global.StackConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.StackConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.StackFileConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.TemporaryGlobalStatePathConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.TemporaryGlobalStatePathConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.ThreadFactoryConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.WhiteListConfiguration
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.global.WhiteListConfigurationBuilder
Deprecated.
 
attributes() - Method in class org.infinispan.counter.configuration.AbstractCounterConfiguration
 
attributes() - Method in class org.infinispan.counter.configuration.CounterManagerConfigurationBuilder
 
attributes() - Method in class org.infinispan.counter.configuration.StrongCounterConfigurationBuilder
 
attributes() - Method in class org.infinispan.counter.configuration.WeakCounterConfigurationBuilder
 
attributes() - Method in class org.infinispan.lock.configuration.ClusteredLockConfigurationBuilder
 
attributes() - Method in class org.infinispan.lock.configuration.ClusteredLockManagerConfigurationBuilder
 
attributes() - Method in class org.infinispan.metrics.config.MicrometerMeterRegisterConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.jdbc.common.configuration.ManagedConnectionFactoryConfiguration
 
attributes() - Method in class org.infinispan.persistence.jdbc.common.configuration.ManagedConnectionFactoryConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfiguration
 
attributes() - Method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfiguration
 
attributes() - Method in class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.jdbc.configuration.DataColumnConfiguration
 
attributes() - Method in class org.infinispan.persistence.jdbc.configuration.DataColumnConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.jdbc.configuration.IdColumnConfiguration
 
attributes() - Method in class org.infinispan.persistence.jdbc.configuration.IdColumnConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder.StringTableManipulationConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.jdbc.configuration.SegmentColumnConfiguration
 
attributes() - Method in class org.infinispan.persistence.jdbc.configuration.SegmentColumnConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
attributes() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.jdbc.configuration.TimestampColumnConfiguration
 
attributes() - Method in class org.infinispan.persistence.jdbc.configuration.TimestampColumnConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfiguration
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfiguration
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.MechanismConfiguration
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.MechanismConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfiguration
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.SslConfiguration
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.TrustStoreConfiguration
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.TrustStoreConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBExpirationConfiguration
 
attributes() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBExpirationConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfiguration
 
attributes() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.sifs.configuration.DataConfiguration
 
attributes() - Method in class org.infinispan.persistence.sifs.configuration.DataConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.sifs.configuration.IndexConfiguration
 
attributes() - Method in class org.infinispan.persistence.sifs.configuration.IndexConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfigurationBuilder
 
attributes() - Method in class org.infinispan.rest.configuration.AuthenticationConfigurationBuilder
 
attributes() - Method in class org.infinispan.rest.configuration.CorsConfigurationBuilder
 
attributes() - Method in class org.infinispan.rest.configuration.CorsRuleConfigurationBuilder
 
attributes() - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
 
attributes() - Method in class org.infinispan.security.impl.CreatePermissionConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.core.configuration.EncryptionConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.core.configuration.IpFilterConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.core.configuration.SniConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.core.configuration.SslEngineConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfiguration
 
attributes() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.hotrod.configuration.SaslConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.hotrod.configuration.TopologyCacheConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
 
AttributeSerializer<T> - Interface in org.infinispan.commons.configuration.attributes
AttributeSerializer.
attributeSet() - Static method in class org.infinispan.commons.configuration.AbstractTypedPropertiesConfiguration
 
attributeSet() - Static method in class org.infinispan.persistence.jdbc.common.configuration.AbstractUnmanagedConnectionFactoryConfiguration
 
attributeSet() - Static method in class org.infinispan.persistence.jdbc.common.configuration.ManagedConnectionFactoryConfiguration
 
attributeSet() - Static method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfiguration
 
AttributeSet - Class in org.infinispan.commons.configuration.attributes
AttributeSet is a container for Attributes.
AttributeSet(Class<?>, Enum<?>, AttributeDefinition<?>...) - Constructor for class org.infinispan.commons.configuration.attributes.AttributeSet
 
AttributeSet(Class<?>, String, AttributeSet, AttributeDefinition<?>[]) - Constructor for class org.infinispan.commons.configuration.attributes.AttributeSet
 
AttributeSet(Class<?>, String, AttributeSet, AttributeDefinition<?>[], AttributeSet.RemovedAttribute[]) - Constructor for class org.infinispan.commons.configuration.attributes.AttributeSet
 
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
 
AttributeSet.RemovedAttribute - Class in org.infinispan.commons.configuration.attributes
 
attributeUri - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
AttributeValidator<T> - Interface in org.infinispan.commons.configuration.attributes
AttributeValidator.
attributeValue - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
audit(Subject, AuditContext, String, AuthorizationPermission, AuditResponse) - Method in class org.infinispan.security.audit.LoggingAuditLogger
 
audit(Subject, AuditContext, String, AuthorizationPermission, AuditResponse) - Method in class org.infinispan.security.audit.NullAuditLogger
 
audit(Subject, AuditContext, String, AuthorizationPermission, AuditResponse) - Method in interface org.infinispan.security.AuditLogger
 
AUDIT_LOGGER - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
AUDIT_LOGGER - Static variable in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
auditContext() - Method in class org.infinispan.rest.framework.impl.InvocationImpl
 
auditContext() - Method in interface org.infinispan.rest.framework.Invocation
 
auditContext(AuditContext) - Method in class org.infinispan.rest.framework.impl.InvocationImpl.Builder
 
AuditContext - Enum in org.infinispan.security
AuditContext.
auditLogger() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
auditLogger(AuditLogger) - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
The instance of an AuditLogger to be used to track operations performed on caches and cachemanagers.
AuditLogger - Interface in org.infinispan.security
AuditLogger.
auditMessage(AuditResponse, Principal, AuthorizationPermission, AuditContext, String) - Method in interface org.infinispan.security.impl.AuditMessages
 
AuditMessages - Interface in org.infinispan.security.impl
AuditMessages.
AuditResponse - Enum in org.infinispan.security
 
auth - Variable in class org.infinispan.server.hotrod.HotRodDecoder
 
auth(HotRodHeader, String, byte[]) - Method in class org.infinispan.server.hotrod.Authentication
 
AUTH - Enum constant in enum org.infinispan.client.hotrod.configuration.SaslQop
 
AUTH - Enum constant in enum org.infinispan.server.hotrod.configuration.QOP
 
AUTH - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
AUTH_CALLBACK_HANDLER - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
AUTH_CLIENT_SUBJECT - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
AUTH_CONF - Enum constant in enum org.infinispan.client.hotrod.configuration.SaslQop
 
AUTH_CONF - Enum constant in enum org.infinispan.server.hotrod.configuration.QOP
 
AUTH_DIGEST - Enum constant in enum org.infinispan.persistence.remote.configuration.Element
 
AUTH_EXTERNAL - Enum constant in enum org.infinispan.persistence.remote.configuration.Element
 
AUTH_INT - Enum constant in enum org.infinispan.client.hotrod.configuration.SaslQop
 
AUTH_INT - Enum constant in enum org.infinispan.server.hotrod.configuration.QOP
 
AUTH_MECH_LIST - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
AUTH_MECH_LIST_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
AUTH_PASSWORD - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
AUTH_PLAIN - Enum constant in enum org.infinispan.persistence.remote.configuration.Element
 
AUTH_REALM - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
AUTH_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
AUTH_SERVER_NAME - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
AUTH_TOKEN - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
AUTH_USERNAME - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
authenticate(String) - Method in class org.infinispan.rest.NettyRestResponse.Builder
 
authenticate(String, String) - Method in interface org.infinispan.rest.authentication.SecurityDomain
Returns Subject based on user/password combination.
authentication() - Method in class org.infinispan.client.hotrod.configuration.AbstractSecurityConfigurationChildBuilder
 
authentication() - Method in class org.infinispan.client.hotrod.configuration.SecurityConfiguration
 
authentication() - Method in class org.infinispan.client.hotrod.configuration.SecurityConfigurationBuilder
 
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.rest.configuration.RestServerConfiguration
 
authentication() - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
 
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 - Enum constant in enum org.infinispan.persistence.remote.configuration.Element
 
AUTHENTICATION - Enum constant in enum org.infinispan.server.hotrod.configuration.Element
 
AuthenticationConfiguration - Class in org.infinispan.client.hotrod.configuration
AuthenticationConfiguration.
AuthenticationConfiguration - Class in org.infinispan.persistence.remote.configuration
AuthenticationConfiguration.
AuthenticationConfiguration - Class in org.infinispan.rest.configuration
AuthenticationConfiguration.
AuthenticationConfiguration - Class in org.infinispan.server.hotrod.configuration
AuthenticationConfiguration.
AuthenticationConfiguration(CallbackHandler, Subject, boolean, String, Map<String, String>, String) - Constructor for class org.infinispan.client.hotrod.configuration.AuthenticationConfiguration
 
AuthenticationConfiguration(AttributeSet, MechanismConfiguration) - Constructor for class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
 
AuthenticationConfigurationBuilder - Class in org.infinispan.client.hotrod.configuration
AuthenticationConfigurationBuilder.
AuthenticationConfigurationBuilder - Class in org.infinispan.persistence.remote.configuration
AuthenticationConfigurationBuilder.
AuthenticationConfigurationBuilder - Class in org.infinispan.rest.configuration
AuthenticationConfigurationBuilder.
AuthenticationConfigurationBuilder - Class in org.infinispan.server.hotrod.configuration
AuthenticationConfigurationBuilder.
AuthenticationConfigurationBuilder(SecurityConfigurationBuilder) - Constructor for class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
 
AuthenticationConfigurationBuilder(SecurityConfigurationBuilder) - Constructor for class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
 
authenticationException(Throwable) - Method in interface org.infinispan.server.hotrod.logging.Log
 
authenticationWithoutAuthenticator() - Method in interface org.infinispan.rest.logging.Log
 
authenticator() - Method in class org.infinispan.rest.configuration.AuthenticationConfiguration
 
authenticator(Authenticator) - Method in class org.infinispan.rest.configuration.AuthenticationConfigurationBuilder
 
Authenticator - Interface in org.infinispan.rest.authentication
Authentication mechanism.
authMechList(HotRodHeader) - Method in class org.infinispan.server.hotrod.Authentication
 
authMechListResponse(HotRodHeader, HotRodServer, Channel, Set<String>) - Method in class org.infinispan.server.hotrod.Encoder4x
 
authMechListResponse(HotRodHeader, HotRodServer, Channel, Set<String>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
 
authorization() - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
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 - Enum constant in enum org.infinispan.configuration.parsing.Element
 
AUTHORIZATION - Enum constant in enum org.infinispan.rest.RequestHeader
 
AUTHORIZATION_PERMISSION - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
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
 
AuthorizationManagerImpl - Class in org.infinispan.security.impl
AuthorizationManagerImpl.
AuthorizationManagerImpl() - Constructor for class org.infinispan.security.impl.AuthorizationManagerImpl
 
AuthorizationMapperContext - Interface in org.infinispan.security
 
AuthorizationMapperContextImpl - Class in org.infinispan.security.impl
PrincipalRoleMapperContextImpl.
AuthorizationMapperContextImpl(EmbeddedCacheManager) - Constructor for class org.infinispan.security.impl.AuthorizationMapperContextImpl
 
authorizationNotEnabled() - Method in interface org.infinispan.rest.logging.Log
 
AuthorizationPermission - Enum in org.infinispan.security
AuthorizationPermission.
AuthorizationPermission$___Marshaller_e4a67ef18a1f2ebc30b0d1e396f24e2098535911da768fa734361c9903b14240 - Class in org.infinispan.security
 
AuthorizationPermission$___Marshaller_e4a67ef18a1f2ebc30b0d1e396f24e2098535911da768fa734361c9903b14240() - Constructor for class org.infinispan.security.AuthorizationPermission$___Marshaller_e4a67ef18a1f2ebc30b0d1e396f24e2098535911da768fa734361c9903b14240
 
Authorizer - Class in org.infinispan.security.impl
Authorizer.
Authorizer(GlobalSecurityConfiguration, AuditContext, String, Map<CacheSubjectPair, SubjectACL>) - Constructor for class org.infinispan.security.impl.Authorizer
 
AuthorizingCallbackHandler - Interface in org.infinispan.server.core.security
AuthorizingCallbackHandler.
authResponse(HotRodHeader, HotRodServer, Channel, byte[]) - Method in class org.infinispan.server.hotrod.Encoder4x
 
authResponse(HotRodHeader, HotRodServer, Channel, byte[]) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
 
AUTO - Enum constant in enum org.infinispan.configuration.cache.IndexStartupMode
With this configuration Infinispan will try to run the right action to align cache data and indexes.
AUTO - Enum constant in enum org.infinispan.configuration.cache.XSiteStateTransferMode
Cross-site state transfer is triggered automatically.
AUTO_COMMIT - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
AUTO_COMMIT - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
 
AUTO_CONFIG - Enum constant in enum org.infinispan.configuration.parsing.Attribute
Deprecated.
AUTO_CONFIG - Static variable in class org.infinispan.configuration.cache.IndexingConfiguration
Deprecated.
since 11.0
AutoBatchSupport - Class in org.infinispan.batch
Enables for automatic batching.
AutoBatchSupport() - Constructor for class org.infinispan.batch.AutoBatchSupport
 
autoCommit - Variable in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations.FlowableConnection
 
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
Deprecated.
Since 11.0, with no replacement.
autoConfig() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
Deprecated.
Since 11.0, with no replacement.
autoConfig(boolean) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
Deprecated.
Since 11.0 with no replacement.
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
 
AutoStateTransferResponse - Class in org.infinispan.xsite.response
A Response implementation for command XSiteAutoTransferStatusCommand.
AutoStateTransferResponse(boolean, XSiteStateTransferMode) - Constructor for class org.infinispan.xsite.response.AutoStateTransferResponse
 
AutoStateTransferResponseCollector - Class in org.infinispan.xsite.response
AutoStateTransferResponseCollector(boolean, XSiteStateTransferMode) - Constructor for class org.infinispan.xsite.response.AutoStateTransferResponseCollector
 
AVAILABILITY_INTERVAL - Enum constant in enum 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
 
AvailabilityException - Exception in org.infinispan.partitionhandling
Thrown when a partition happened and the key that an operation tries to access is not available.
AvailabilityException() - Constructor for exception org.infinispan.partitionhandling.AvailabilityException
 
AvailabilityException(String) - Constructor for exception org.infinispan.partitionhandling.AvailabilityException
 
AvailabilityException(String, Throwable) - Constructor for exception org.infinispan.partitionhandling.AvailabilityException
 
AvailabilityException(Throwable) - Constructor for exception org.infinispan.partitionhandling.AvailabilityException
 
availabilityInterval() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
 
availabilityInterval(int) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
AvailabilityMode - Enum in org.infinispan.partitionhandling
 
AvailabilityMode.Externalizer - Class in org.infinispan.partitionhandling
 
AvailabilityStrategy - Interface in org.infinispan.partitionhandling.impl
Implementations decide what to do when the cache membership changes, either because new nodes joined, nodes left, or there was a merge.
AvailabilityStrategyContext - Interface in org.infinispan.partitionhandling.impl
Contains information about the current state of the cache.
available() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
 
available() - Method in interface org.infinispan.configuration.cache.JMXStatisticsConfiguration
Deprecated.
since 10.1.3. This method will be removed in a future version.
available() - Method in class org.infinispan.configuration.cache.StatisticsConfiguration
Deprecated.
since 10.1.3. This method will be removed in a future version.
available() - Method in class org.infinispan.io.GridInputStream
Deprecated.
 
available() - Method in class org.infinispan.io.UnclosableObjectInputStream
Deprecated.
 
available() - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
 
available(boolean) - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
Deprecated.
since 10.1.3. This method will be removed in a future version.
available(boolean) - Method in class org.infinispan.configuration.cache.StatisticsConfigurationBuilder
Deprecated.
since 10.1.3. This method will be removed in a future version.
AVAILABLE - Enum constant in enum org.infinispan.counter.configuration.Reliability
If the cluster splits in multiple partition, all of them are allowed to continue read/update the counter.
AVAILABLE - Enum constant in enum org.infinispan.lock.configuration.Reliability
 
AVAILABLE - Enum constant in enum org.infinispan.partitionhandling.AvailabilityMode
Regular operation mode
AVAILABLE - Static variable in class org.infinispan.configuration.cache.StatisticsConfiguration
 
AvailablePartitionHandlingManager - Class in org.infinispan.partitionhandling.impl
PartitionHandlingManager implementation when the cluster is always available.
availableProcessors() - Static method in class org.infinispan.commons.jdkspecific.ProcessorInfo
 
availableProcessors() - Static method in class org.infinispan.commons.util.ProcessorInfo
Returns the number of processors available to this process.
average() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
average() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
average() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
average() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
average() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
average() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
avg(String) - Static method in interface org.infinispan.query.dsl.Expression
Deprecated.
 
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.commons.util.concurrent.CompletableFutures
It waits until the CompletableFuture is completed.
await(CompletableFuture<T>) - Static method in class org.infinispan.client.hotrod.impl.Util
 
await(CompletableFuture<T>) - Static method in class org.infinispan.commons.util.concurrent.CompletableFutures
Wait for a long time until the CompletableFuture is completed.
await(CompletableFuture<T>, long) - Static method in class org.infinispan.client.hotrod.impl.Util
 
await(CompletionStage<T>) - Static method in class org.infinispan.client.hotrod.impl.Util
 
await(CompletionStage<T>) - Static method in class org.infinispan.util.concurrent.CompletionStages
 
AWAIT_INITIAL_RETRIEVAL - Enum constant in enum org.infinispan.server.hotrod.configuration.Attribute
 
AWAIT_INITIAL_TRANSFER - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
AWAIT_INITIAL_TRANSFER - Static variable in class org.infinispan.configuration.cache.StateTransferConfiguration
 
awaitCounterOperation(CompletionStage<T>) - Static method in class org.infinispan.counter.impl.Util
Awaits for the counter operation and throws any exception as CounterException.
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() - Method in class org.infinispan.server.hotrod.configuration.TopologyCacheConfiguration
 
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).
awaitInitialTransfer(boolean) - Method in class org.infinispan.server.hotrod.configuration.TopologyCacheConfigurationBuilder
 
awaitPendingTransactionsForAllKeys(TxInvocationContext<?>, Collection<Object>, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultPendingLockManager
 
awaitPendingTransactionsForAllKeys(TxInvocationContext<?>, Collection<Object>, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.NoOpPendingLockManager
 
awaitPendingTransactionsForAllKeys(TxInvocationContext<?>, Collection<Object>, long, TimeUnit) - Method in interface org.infinispan.util.concurrent.locks.PendingLockManager
Deprecated.
Since 10.0, the blocking variants will be removed
awaitPendingTransactionsForKey(TxInvocationContext<?>, Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultPendingLockManager
 
awaitPendingTransactionsForKey(TxInvocationContext<?>, Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.NoOpPendingLockManager
 
awaitPendingTransactionsForKey(TxInvocationContext<?>, Object, long, TimeUnit) - Method in interface org.infinispan.util.concurrent.locks.PendingLockManager
Deprecated.
Since 10.0, the blocking variants will be removed
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.server.core.utils.DelegatingEventLoopGroup
 
awaitTermination(long, TimeUnit) - Method in class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
 
awaitTermination(long, TimeUnit) - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
AZURE(Properties) - Static method in class org.infinispan.remoting.transport.jgroups.BuiltinJGroupsChannelConfigurator
 

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.
backup() - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
backup() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
 
backup() - Method in interface org.infinispan.server.core.backup.ContainerResource
Writes the backup files for the BackupManager.Resources.Type to the local filesystem, where it can then be packaged for distribution.
backup() - Method in class org.infinispan.server.core.backup.resources.CacheResource
 
backup() - Method in class org.infinispan.server.core.backup.resources.CounterResource
 
BACKUP - Enum constant in enum org.infinispan.configuration.parsing.Element
 
BACKUP - Enum constant in enum org.infinispan.distribution.Ownership
this node is the backup owner.
BACKUP_FAILURE_POLICY - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
BACKUP_FOR - Enum constant in enum org.infinispan.configuration.parsing.Element
 
BACKUP_WRITE - Enum constant in enum org.infinispan.context.Flag
Signals that a WriteCommand was sent from the primary as a backup operation.
BACKUP_WRITE - Static variable in class org.infinispan.context.impl.FlagBitSets
 
backupAck(long, Address, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
Acknowledges a write operation completion in the backup owner.
backupAddress - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
backupAlreadyExists(String) - Method in interface org.infinispan.server.core.logging.Log
 
backupComplete(String) - Method in interface org.infinispan.server.core.logging.Log
 
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
 
backupDeleted(String) - Method in interface org.infinispan.server.core.logging.Log
 
backupDeleteFailed() - Method in interface org.infinispan.rest.logging.Log
 
backupFailed() - Method in interface org.infinispan.rest.logging.Log
 
backupFailurePolicy() - Method in class org.infinispan.configuration.cache.BackupConfiguration
 
backupFailurePolicy(BackupFailurePolicy) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
Configures the policy for handling failed requests.
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, IracPutKeyValueCommand) - 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
 
backupInProgress() - Method in interface org.infinispan.server.core.logging.Log
 
BackupManager - Interface in org.infinispan.server.core
Handles all tasks related to the creation/restoration of server backups.
BackupManager.Resources - Interface in org.infinispan.server.core
An interface to encapsulate the various arguments required by the BackupManager in order to include/exclude resources from a backup/restore operation.
BackupManager.Resources.Type - Enum in org.infinispan.server.core
 
BackupManager.Status - Enum in org.infinispan.server.core
An enum representing the current state of a Backup operation.
BackupManagerImpl - Class in org.infinispan.server.core.backup
 
BackupManagerImpl(BlockingManager, DefaultCacheManager, Path) - Constructor for class org.infinispan.server.core.backup.BackupManagerImpl
 
BackupManagerResources - Class in org.infinispan.server.core.backup
 
BackupManagerResources(Map<BackupManager.Resources.Type, Set<String>>) - Constructor for class org.infinispan.server.core.backup.BackupManagerResources
 
BackupManagerResources.Builder - Class in org.infinispan.server.core.backup
 
backupQueue - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
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
backupRemotely(XSiteBackup, XSiteReplicateCommand<O>) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
backupRemotely(XSiteBackup, XSiteReplicateCommand<O>) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
backupRemotely(XSiteBackup, XSiteReplicateCommand<O>) - Method in interface org.infinispan.remoting.transport.Transport
Sends a cross-site request to a remote site.
BackupResponse - Interface in org.infinispan.remoting.transport
Represents a response from a backup replication call.
backups() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
BACKUPS - Enum constant in enum org.infinispan.configuration.parsing.Element
 
BALANCING_STRATEGY - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
 
balancingStrategy() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
balancingStrategy(Class<? extends FailoverRequestBalancingStrategy>) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
balancingStrategy(Class<? extends FailoverRequestBalancingStrategy>) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
balancingStrategy(Class<? extends FailoverRequestBalancingStrategy>) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
For replicated (vs distributed) Hot Rod server clusters, the client balances requests to the servers according to this strategy.
balancingStrategy(String) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
balancingStrategy(String) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
balancingStrategy(String) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
For replicated (vs distributed) Hot Rod server clusters, the client balances requests to the servers according to this strategy.
balancingStrategy(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.
balancingStrategy(Supplier<FailoverRequestBalancingStrategy>) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
balancingStrategy(Supplier<FailoverRequestBalancingStrategy>) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
balancingStrategy(Supplier<FailoverRequestBalancingStrategy>) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
For replicated (vs distributed) Hot Rod server clusters, the client balances requests to the servers according to this strategy.
balancingStrategyFactory() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
BARE_COLLECTIONS - Enum constant in enum org.infinispan.commons.configuration.io.ConfigurationFormatFeature
The underlying format supports collections without the need for wrapping in a container element.
BASE_64 - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
Base16Codec - Class in org.infinispan.commons.dataconversion
 
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
 
BaseCacheEntryListenerInvocation(EncoderRegistry, 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
 
BaseCacheListener(Cache<?, ?>) - Constructor for class org.infinispan.rest.resources.CacheResourceV2.BaseCacheListener
 
BaseCacheResource - Class in org.infinispan.rest.resources
Handle basic cache operations.
BaseCacheResource(InvocationHelper, RestTelemetryService) - Constructor for class org.infinispan.rest.resources.BaseCacheResource
 
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.jboss.marshalling.commons.AbstractJBossMarshaller
Deprecated.
 
BaseCounter - Class in org.infinispan.client.hotrod.counter.impl
 
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
 
BaseExtendedStatisticsContainer - Class in org.infinispan.extendedstats.container
Common logic for the ExtendedStatisticsContainer
BaseExtendedStatisticsContainer(int) - Constructor for class org.infinispan.extendedstats.container.BaseExtendedStatisticsContainer
 
BaseJdbcStore<K,V,C extends AbstractJdbcStoreConfiguration> - Class in org.infinispan.persistence.jdbc.common.impl
 
BaseJdbcStore() - Constructor for class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
 
BaseRequestProcessor - Class in org.infinispan.server.hotrod
 
BaseTableOperations<K,V> - Class in org.infinispan.persistence.jdbc.common.sql
 
BaseTableOperations(int, int, int) - Constructor for class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
 
BaseTableOperations.FlowableConnection - Class in org.infinispan.persistence.jdbc.common.sql
 
BaseTableOperations.ResultSetEntryIterator - Class in org.infinispan.persistence.jdbc.common.sql
 
BaseXSiteStateProviderState<T extends org.infinispan.xsite.statetransfer.BaseXSiteStateProviderState.OutboundTask> - Class in org.infinispan.xsite.statetransfer
Common code for AsyncProviderState and SyncProviderState implementation.
BaseXSiteStateProviderState(XSiteBackup, XSiteStateTransferConfiguration) - Constructor for class org.infinispan.xsite.statetransfer.BaseXSiteStateProviderState
 
BASIC - Enum constant in enum org.infinispan.client.hotrod.configuration.ClientIntelligence
 
BasicAuthenticator - Class in org.infinispan.rest.authentication.impl
BASIC authentication mechanism.
BasicAuthenticator(SecurityDomain, String) - Constructor for class org.infinispan.rest.authentication.impl.BasicAuthenticator
 
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.
BasicCallbackHandler - Class in org.infinispan.client.hotrod.security
BasicCallbackHandler() - Constructor for class org.infinispan.client.hotrod.security.BasicCallbackHandler
 
BasicCallbackHandler(String, char[]) - Constructor for class org.infinispan.client.hotrod.security.BasicCallbackHandler
 
BasicCallbackHandler(String, String, char[]) - Constructor for class org.infinispan.client.hotrod.security.BasicCallbackHandler
 
basicComponentRegistry - Variable in class org.infinispan.factories.AbstractNamedCacheComponentFactory
 
basicComponentRegistry - Variable in class org.infinispan.server.core.factories.NettyIOFactory
 
BasicComponentRegistry - Interface in org.infinispan.factories.impl
Basic dependency injection container.
BasicComponentRegistryImpl - Class in org.infinispan.factories.impl
 
BasicComponentRegistryImpl(ModuleRepository, boolean, BasicComponentRegistry) - Constructor for class org.infinispan.factories.impl.BasicComponentRegistryImpl
 
BasicConfiguration - Interface in org.infinispan.commons.configuration
BasicConfiguration provides the basis for concrete configurations.
BasicLogFactory - Class in org.infinispan.commons.logging
Factory that creates Log instances.
BasicLogFactory() - Constructor for class org.infinispan.commons.logging.BasicLogFactory
 
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(int, Publisher<NonBlockingStore.SegmentedPublisher<Object>>, Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>>) - Method in class org.infinispan.persistence.async.AsyncNonBlockingStore
 
batch(int, Publisher<NonBlockingStore.SegmentedPublisher<Object>>, Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>>) - Method in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
 
batch(int, Publisher<NonBlockingStore.SegmentedPublisher<Object>>, Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>>) - Method in class org.infinispan.persistence.remote.RemoteStore
 
batch(int, Publisher<NonBlockingStore.SegmentedPublisher<Object>>, Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>>) - Method in class org.infinispan.persistence.rocksdb.RocksDBStore
 
batch(int, Publisher<NonBlockingStore.SegmentedPublisher<Object>>, Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>>) - Method in interface org.infinispan.persistence.spi.NonBlockingStore
Writes and removes the entries provided by the Publishers into the store.
batch(int, Publisher<NonBlockingStore.SegmentedPublisher<Object>>, Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>>) - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
 
batch(int, Publisher<NonBlockingStore.SegmentedPublisher<Object>>, Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>>) - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
 
BATCH - Enum constant in enum org.infinispan.configuration.parsing.CacheParser.TransactionMode
 
BATCH_SIZE - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
 
BATCH_SIZE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
BATCH_SIZE - Static variable in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
batchContainer - Variable in class org.infinispan.batch.AutoBatchSupport
 
batchContainer - Variable in class org.infinispan.cache.impl.CacheImpl
 
batchContainer - Variable in class org.infinispan.cache.impl.InvocationHelper
 
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
BatchingClusterEventManagerImpl<K,V> - Class in org.infinispan.notifications.cachelistener.cluster.impl
 
BatchingClusterEventManagerImpl() - Constructor for class org.infinispan.notifications.cachelistener.cluster.impl.BatchingClusterEventManagerImpl
 
BatchingClusterEventManagerImpl.UnicastEventContext<K,V> - Class in org.infinispan.notifications.cachelistener.cluster.impl
 
BatchModeTransactionManager - Class in org.infinispan.transaction.tm
Not really a transaction manager in the truest sense of the word.
BatchModification - Class in org.infinispan.persistence.support
A simple wrapper class, necessary for Transactional stores, which allows MarshalledEntries and Object keys to be passed to a store implementation in order.
BatchModification(Set<Object>) - Constructor for class org.infinispan.persistence.support.BatchModification
 
batchSize - Variable in class org.infinispan.commons.reactive.AbstractAsyncPublisherHandler
 
batchSize() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
batchSize() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
Deprecated.
batchSize(int) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
batchSize(int) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
batchSize(int) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Sets the batch size of internal iterators (ie.
batchSize(int) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
batchUpdates(Connection, int, Publisher<Object>, Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>>) - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
 
batchUpdates(Connection, int, Publisher<Object>, Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>>) - Method in interface org.infinispan.persistence.jdbc.common.TableOperations
 
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 class org.infinispan.xsite.statetransfer.NoOpXSiteStateTransferManager
 
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
Deprecated.
Dictates that the custom interceptor appears immediately before the specified interceptor.
BEFORE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
BEFORE - Enum constant in enum 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
 
beforeCompletion() - Method in class org.infinispan.transaction.synchronization.SynchronizationAdapter
 
beforeCompletion(LocalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
 
beforeTopologyInstalled(int, ConsistentHash, ConsistentHash) - Method in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
begin() - Method in class org.infinispan.commons.tx.TransactionManagerImpl
 
begin() - Method in class org.infinispan.transaction.tm.EmbeddedUserTransaction
 
beginTransaction(GlobalTransaction, boolean) - Method in class org.infinispan.extendedstats.CacheStatisticManager
Signals the start of a transaction.
between(Object, Object) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Deprecated.
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 - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
BIAS_ACQUISITION - Static variable in class org.infinispan.configuration.cache.ClusteringConfiguration
 
BIAS_LIFESPAN - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
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
 
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
 
BiasManagerImpl - Class in org.infinispan.scattered.impl
 
BiasManagerImpl() - Constructor for class org.infinispan.scattered.impl.BiasManagerImpl
 
BiasRevocationResponse - Class in org.infinispan.remoting.responses
 
BiasRevocationResponse(Object, Address[]) - Constructor for class org.infinispan.remoting.responses.BiasRevocationResponse
 
BiasRevocationResponse.Externalizer - Class in org.infinispan.remoting.responses
 
BiFunctionMapper - Class in org.infinispan.cache.impl
A Bifuncion wrapper that uses the cache's underlying DataConversion objects to perform its operations.
BiFunctionMapper(BiFunction, DataConversion, DataConversion) - Constructor for class org.infinispan.cache.impl.BiFunctionMapper
 
BiFunctionMapper.Externalizer - Class in org.infinispan.cache.impl
 
BINARY - Enum constant in enum org.infinispan.configuration.cache.StorageType
Deprecated.
since 11.0, with no replacement. Use StorageType.HEAP and the cache's EncodingConfiguration to define a MediaType that is byte[] or primitive based.
BINARY - Enum constant in enum org.infinispan.configuration.parsing.Element
 
BINARY - Static variable in interface org.infinispan.commons.dataconversion.EncoderIds
Deprecated.
 
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 - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
 
binaryParam() - Method in interface org.infinispan.filter.ParamKeyValueFilterConverterFactory
 
BinaryTranscoder - Class in org.infinispan.commons.dataconversion
Deprecated.
since 13.0. Will be removed in a future version together with MediaType.APPLICATION_UNKNOWN.
BinaryTranscoder(Marshaller) - Constructor for class org.infinispan.commons.dataconversion.BinaryTranscoder
Deprecated.
 
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 - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.Attribute
 
BLOCKED - Enum constant in enum org.infinispan.scattered.ScatteredVersionManager.SegmentState
 
BlockHoundUtil - Class in org.infinispan.commons.internal
 
BlockHoundUtil() - Constructor for class org.infinispan.commons.internal.BlockHoundUtil
 
blocking(CompletionStage<T>) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticRpcManager
 
blocking(CompletionStage<T>) - Method in interface org.infinispan.remoting.rpc.RpcManager
Block on a request and return its result.
blocking(CompletionStage<T>) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
BLOCKING_BOUNDED_QUEUE_THREAD_POOL - Enum constant in enum org.infinispan.configuration.parsing.Element
 
BLOCKING_EXECUTOR - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
BLOCKING_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
blockingExecutor(String) - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
 
blockingManager - Variable in class org.infinispan.cache.impl.InvocationHelper
 
blockingManager - Variable in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
 
blockingManager - Variable in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
 
blockingManager - Variable in class org.infinispan.server.core.backup.resources.CounterResource
 
BlockingManager - Interface in org.infinispan.util.concurrent
Manager utility for blocking operations that runs tasks on the blocking executor and returns a CompletionStage or Publisher that continues on the non-blocking executor, similar to stage.handleAsync(callback, blockingExecutor).whenCompleteAsync(NOOP, nonBlockingExecutor).
BlockingManager.BlockingExecutor - Interface in org.infinispan.util.concurrent
Executor interface that submits task to a blocking pool that returns a stage that is guaranteed to run any chained stages on a non-blocking thread if the stage is not yet complete.
BlockingManagerImpl - Class in org.infinispan.util.concurrent
 
BlockingManagerImpl() - Constructor for class org.infinispan.util.concurrent.BlockingManagerImpl
 
blockingPublisher(Publisher<V>) - Method in interface org.infinispan.util.concurrent.BlockingManager
Provided a publisher that is known to block when subscribed to.
blockingPublisher(Publisher<V>) - Method in class org.infinispan.util.concurrent.BlockingManagerImpl
 
blockingPublisherToVoidStage(Publisher<V>, Object) - Method in interface org.infinispan.util.concurrent.BlockingManager
Subscribes to the provided blocking publisher using the the blocking executor, ignoring all elements and returning a CompletionStage with a value of null which completes on a non-blocking thread.
blockingPublisherToVoidStage(Publisher<V>, Object) - Method in class org.infinispan.util.concurrent.BlockingManagerImpl
 
BlockingRejectedExecutionHandler - Class in org.infinispan.commons.util.concurrent
A handler for rejected tasks that runs the task if the current thread is a blocking thread otherwise it rejects the task.
BlockingResource - Interface in org.infinispan.commons.executors
Interface to designate the resource is a blocking one.
BlockingRunnable - Interface in org.infinispan.util.concurrent
A special Runnable 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(ExecutorService, TimeService) - Constructor for class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
 
BlockingThreadFactory - Class in org.infinispan.factories.threads
 
BlockingThreadFactory(String, int, String, String, String) - Constructor for class org.infinispan.factories.threads.BlockingThreadFactory
 
BlockingThreadFactory(String, String, int, String, String, String) - Constructor for class org.infinispan.factories.threads.BlockingThreadFactory
 
BlockingThreadFactory.ISPNBlockingThreadGroup - Class in org.infinispan.factories.threads
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
blockingThreadPool() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
Configuration for the blocking thread pool
blockingThreadPool() - Method in class org.infinispan.configuration.global.ThreadsConfiguration
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
 
BlockingThreadPoolExecutorFactory - Class in org.infinispan.commons.executors
Deprecated.
since 12.0 with no replacement
BlockingThreadPoolExecutorFactory(int, int, int, long) - Constructor for class org.infinispan.commons.executors.BlockingThreadPoolExecutorFactory
Deprecated.
 
BlockingThreadPoolExecutorFactory(int, int, int, long, boolean) - Constructor for class org.infinispan.commons.executors.BlockingThreadPoolExecutorFactory
Deprecated.
 
blockingThreadPoolName() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
blockingThreadPoolName(String) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
blockSize() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfiguration
 
blockSize(int) - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
 
bloomFilter() - Method in class org.infinispan.client.hotrod.configuration.NearCacheConfiguration
 
bloomFilter(boolean) - Method in class org.infinispan.client.hotrod.configuration.NearCacheConfigurationBuilder
Specifies whether bloom filter should be used for near cache to limit the number of write notifications for unrelated keys.
BloomFilter<E> - Class in org.infinispan.commons.util
 
bloomFilterRequiresMaxActiveOneAndWait(int, ExhaustedAction) - Method in interface org.infinispan.client.hotrod.logging.Log
 
bool(boolean) - Method in class org.infinispan.commons.dataconversion.internal.Json.DefaultFactory
 
bool(boolean) - Method in interface org.infinispan.commons.dataconversion.internal.Json.Factory
Construct and return a JSON boolean.
bool(ByteBuf) - Static method in class org.infinispan.server.hotrod.Intrinsics
 
BOOL - Enum constant in enum org.infinispan.persistence.sql.AbstractSchemaJdbcStore.ProtostreamFieldType
 
Boolean(boolean) - Constructor for class org.infinispan.commons.util.ByRef.Boolean
 
booleanResponse(HotRodHeader, HotRodServer, Channel, boolean) - Method in class org.infinispan.server.hotrod.Encoder4x
 
booleanResponse(HotRodHeader, HotRodServer, Channel, boolean) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
 
booleanStage(boolean) - Static method in class org.infinispan.commons.util.concurrent.CompletableFutures
 
bootstrapComponents() - Method in class org.infinispan.factories.ComponentRegistry
This is a good place to register components that don't have any dependency.
BORLAND_SUN - Enum constant in enum org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
 
BOTH - Enum constant in enum org.infinispan.notifications.Listener.Observation
Observation level used to be notified of an operation before and after it occurs
BOUNDED_STRONG - Enum constant in enum org.infinispan.counter.api.CounterType
A strong consistent and bounded counter.
boundedDataContainer(int, long, EntrySizeCalculator<? super K, ? super V>) - Static method in class org.infinispan.container.impl.DefaultDataContainer
 
boundedDataContainer(int, long, EvictionType) - Static method in class org.infinispan.container.impl.DefaultDataContainer
 
BoundedExecutors - Class in org.infinispan.util.concurrent
Similar to JDK Executors except that the factory methods here allow you to specify the size of the blocking queue that backs the executor.
BoundedExecutors() - Constructor for class org.infinispan.util.concurrent.BoundedExecutors
 
BoundedOffHeapDataContainer - Class in org.infinispan.container.offheap
 
BoundedOffHeapDataContainer(long, EvictionType) - Constructor for class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
BoundedSegmentedDataContainer<K,V> - Class in org.infinispan.container.impl
Bounded implementation of segmented data container.
BoundedSegmentedDataContainer(int, long, EntrySizeCalculator<? super K, ? super InternalCacheEntry<K, V>>) - Constructor for class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
BoundedSegmentedDataContainer(int, long, EvictionType) - Constructor for class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
BoundedThreadPoolConfigurationBuilder - Class in org.infinispan.configuration.global
 
boundedThreadPools() - Method in class org.infinispan.configuration.global.ThreadsConfiguration
 
boxed() - Method in interface org.infinispan.DoubleCacheStream
boxed() - Method in interface org.infinispan.IntCacheStream
boxed() - Method in interface org.infinispan.LongCacheStream
boxed() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
boxed() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
boxed() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
boxed() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
boxed() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
boxed() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
branchQualifierLength() - Method in class org.infinispan.commons.tx.XidImpl
 
branchQualifierOffset() - Method in class org.infinispan.commons.tx.XidImpl
 
brandName() - Method in class org.infinispan.commons.util.Version
 
brandVersion() - Method in class org.infinispan.commons.util.Version
 
bringSiteOnline(String) - Method in class org.infinispan.xsite.status.DefaultTakeOfflineManager
 
bringSiteOnline(String) - Method in class org.infinispan.xsite.status.NoOpTakeOfflineManager
 
bringSiteOnline(String) - Method in interface org.infinispan.xsite.status.TakeOfflineManager
It changes the site siteName to online.
BringSiteOnlineResponse - Enum in org.infinispan.xsite.status
broadcastShutdownCache(String) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
BROUGHT_ONLINE - Enum constant in enum org.infinispan.xsite.status.BringSiteOnlineResponse
 
Bucket<V> - Class in org.infinispan.multimap.impl
Bucket used to store MultiMap values, required as HashSet cannot be directly marshalled via ProtoStream.
Bucket() - Constructor for class org.infinispan.multimap.impl.Bucket
 
Bucket(V) - Constructor for class org.infinispan.multimap.impl.Bucket
 
Bucket$___Marshaller_686dc55729a31972fef7d4722c2e90e0421789a20c8a9d4176be1714ac94d28c - Class in org.infinispan.multimap.impl
WARNING: Generated code! Do not edit!
Bucket$___Marshaller_686dc55729a31972fef7d4722c2e90e0421789a20c8a9d4176be1714ac94d28c() - Constructor for class org.infinispan.multimap.impl.Bucket$___Marshaller_686dc55729a31972fef7d4722c2e90e0421789a20c8a9d4176be1714ac94d28c
 
buf - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
bufAbsoluteStart - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
bufEnd - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
buffer(int) - Static method in class org.infinispan.server.core.transport.ExtendedByteBuf
 
buffer(int) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
 
BufferSizePredictor - Interface in org.infinispan.commons.marshall
Buffer size predictor
bufLoadFactor - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
bufSoftLimit - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
bufStart - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
build() - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
build() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
build() - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Builds a configuration object
build() - Method in class org.infinispan.client.hotrod.DataFormat.Builder
 
build() - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition.Builder
 
build() - Method in class org.infinispan.commons.configuration.io.ConfigurationReader.Builder
 
build() - Method in class org.infinispan.commons.configuration.io.ConfigurationWriter.Builder
 
build() - Method in interface org.infinispan.commons.marshall.MarshallUtil.UnboundedCollectionBuilder
 
build() - Method in class org.infinispan.configuration.cache.CustomStoreConfigurationBuilder
 
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.ScheduledExecutorFactoryConfigurationBuilder
 
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 class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
build() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
build() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata.Builder
 
build() - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
build() - Method in class org.infinispan.metadata.impl.PrivateMetadata.Builder
 
build() - Method in interface org.infinispan.metadata.Metadata.Builder
Build a metadata instance.
build() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
build() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.DelegatingCacheInvocationBuilder
 
build() - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl.DefaultBuilder
 
build() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
build() - Method in interface org.infinispan.query.dsl.QueryBuilder
Deprecated.
Builds the query object.
build() - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
 
build() - Method in interface org.infinispan.rest.framework.impl.RestRequestBuilder
 
build() - Method in interface org.infinispan.rest.framework.impl.RestResponseBuilder
 
build() - Method in class org.infinispan.rest.framework.impl.SimpleRestResponse.Builder
 
build() - Method in class org.infinispan.rest.NettyRestResponse.Builder
 
build() - Method in class org.infinispan.search.mapper.search.loading.context.impl.InfinispanLoadingContext.Builder
 
build() - Method in class org.infinispan.server.core.backup.BackupManagerResources.Builder
 
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.client.hotrod.configuration.ConfigurationBuilder
 
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(Optional<SearchIntegration>) - Method in class org.infinispan.search.mapper.mapping.SearchMappingBuilder
 
build(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
build(InvocationImpl.Builder) - Method in class org.infinispan.rest.framework.impl.Invocations.Builder
 
buildBackupAckCommand(long, int) - Method in interface org.infinispan.commands.CommandsFactory
 
buildBackupAckCommand(long, int) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildBackupMultiKeyAckCommand(long, int, int) - Method in interface org.infinispan.commands.CommandsFactory
 
buildBackupMultiKeyAckCommand(long, int, int) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildBackupNoopCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildBackupNoopCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildCancelPublisherCommand(String) - Method in interface org.infinispan.commands.CommandsFactory
 
buildCancelPublisherCommand(String) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildCheckTransactionRpcCommand(Collection<GlobalTransaction>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildCheckTransactionRpcCommand(Collection<GlobalTransaction>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildClearCommand(long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ClearCommand
buildClearCommand(long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildClusteredGetAllCommand(List<?>, long, GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ClusteredGetAllCommand, which is a remote lookup command
buildClusteredGetAllCommand(List<?>, long, GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildClusteredGetCommand(Object, Integer, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ClusteredGetCommand, which is a remote lookup command
buildClusteredGetCommand(Object, Integer, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildCommitCommand(GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Builds a CommitCommand
buildCommitCommand(GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildCompleteTransactionCommand(XidImpl, boolean) - Method in interface org.infinispan.commands.CommandsFactory
Builds a CompleteTransactionCommand command.
buildCompleteTransactionCommand(XidImpl, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildComputeCommand(Object, BiFunction, boolean, int, Metadata, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ComputeCommand
buildComputeCommand(Object, BiFunction, boolean, int, Metadata, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildComputeIfAbsentCommand(Object, Function, int, Metadata, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ComputeIfAbsentCommand
buildComputeIfAbsentCommand(Object, Function, int, Metadata, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildConflictResolutionStartCommand(int, IntSet) - Method in interface org.infinispan.commands.CommandsFactory
 
buildConflictResolutionStartCommand(int, IntSet) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildEntryReductionPublisherCommand(boolean, DeliveryGuarantee, IntSet, Set<K>, Set<K>, long, Function<? super Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>>, Function<? super Publisher<R>, ? extends CompletionStage<R>>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildEntryReductionPublisherCommand(boolean, DeliveryGuarantee, IntSet, Set<K>, Set<K>, long, Function<? super Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>>, Function<? super Publisher<R>, ? extends CompletionStage<R>>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildEntrySetCommand(long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a EntrySetCommand
buildEntrySetCommand(long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
builder - Variable in class org.infinispan.configuration.cache.CustomStoreConfigurationBuilder
 
builder - Variable in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
builder - Variable in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
 
builder() - Static method in class org.infinispan.client.hotrod.DataFormat
 
builder() - Method in class org.infinispan.container.entries.RemoteMetadata
 
builder() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
 
builder() - Method in class org.infinispan.metadata.EmbeddedMetadata
 
builder() - Method in class org.infinispan.metadata.EmbeddedMetadata.EmbeddedExpirableMetadata
 
builder() - Method in class org.infinispan.metadata.EmbeddedMetadata.EmbeddedLifespanExpirableMetadata
 
builder() - Method in class org.infinispan.metadata.EmbeddedMetadata.EmbeddedMaxIdleExpirableMetadata
 
builder() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
Deprecated.
 
builder() - Method in class org.infinispan.metadata.impl.L1Metadata
 
builder() - Method in class org.infinispan.metadata.impl.PrivateMetadata
 
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(Enum<?>, T) - Static method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
 
builder(Enum<?>, T, Class<T>) - Static method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
 
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(PojoBootstrapIntrospector) - Method in class org.infinispan.search.mapper.mapping.SearchMappingCommonBuilding
 
builder(PojoBootstrapIntrospector, ClassLoader, Collection<ProgrammaticSearchMappingProvider>, BlockingManager, NonBlockingManager) - Static method in interface org.infinispan.search.mapper.mapping.SearchMapping
 
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.client.hotrod.DataFormat.Builder
 
Builder() - Constructor for class org.infinispan.functional.impl.MetaParamsInternalMetadata.Builder
 
Builder() - Constructor for class org.infinispan.metadata.EmbeddedMetadata.Builder
 
Builder() - Constructor for class org.infinispan.metadata.impl.PrivateMetadata.Builder
 
Builder() - Constructor for class org.infinispan.rest.framework.impl.Invocations.Builder
 
Builder() - Constructor for class org.infinispan.rest.framework.impl.SimpleRestResponse.Builder
 
Builder() - Constructor for class org.infinispan.rest.NettyRestResponse.Builder
 
Builder() - Constructor for class org.infinispan.server.core.backup.BackupManagerResources.Builder
 
Builder(int, int, List<Address>, Map<Address, Float>) - Constructor for class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
Builder(int, int, List<Address>, Map<Address, Float>) - Constructor for class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory.Builder
 
Builder(int, List<Address>, Map<Address, Float>) - Constructor for class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
Builder(PojoSelectionEntityLoader<E>) - Constructor for class org.infinispan.search.mapper.search.loading.context.impl.InfinispanLoadingContext.Builder
 
Builder(DefaultConsistentHash) - Constructor for class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
Builder(DefaultConsistentHashFactory.Builder) - Constructor for class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
Builder(DefaultConsistentHash, List<Address>, Map<Address, Float>) - Constructor for class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
Builder(ScatteredConsistentHash) - Constructor for class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
Builder(ScatteredConsistentHashFactory.Builder) - Constructor for class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
Builder(ScatteredConsistentHash, List<Address>, Map<Address, Float>) - Constructor for class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
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.
buildEventLoop(int, ThreadFactory, String) - Static method in class org.infinispan.server.core.transport.NettyTransport
 
buildEvictCommand(Object, int, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds an EvictCommand
buildEvictCommand(Object, int, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildExceptionAckCommand(long, Throwable, int) - Method in interface org.infinispan.commands.CommandsFactory
 
buildExceptionAckCommand(long, Throwable, int) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildGetAllCommand(Collection<?>, long, boolean) - Method in interface org.infinispan.commands.CommandsFactory
Builds a GetAllCommand
buildGetAllCommand(Collection<?>, long, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildGetCacheEntryCommand(Object, int, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a GetCacheEntryCommand
buildGetCacheEntryCommand(Object, int, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildGetInDoubtTransactionsCommand() - Method in interface org.infinispan.commands.CommandsFactory
Builds a GetInDoubtTransactionsCommand.
buildGetInDoubtTransactionsCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildGetInDoubtTxInfoCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildGetInDoubtTxInfoCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildGetKeyValueCommand(Object, int, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a GetKeyValueCommand
buildGetKeyValueCommand(Object, int, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildInitialPublisherCommand(String, DeliveryGuarantee, int, IntSet, Set<K>, Set<K>, long, boolean, boolean, Function<? super Publisher<I>, ? extends Publisher<R>>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildInitialPublisherCommand(String, DeliveryGuarantee, int, IntSet, Set<K>, Set<K>, long, boolean, boolean, Function<? super Publisher<I>, ? extends Publisher<R>>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildInvalidateCommand(long, Object...) - Method in interface org.infinispan.commands.CommandsFactory
Builds an InvalidateCommand
buildInvalidateCommand(long, Object...) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildInvalidateFromL1Command(long, Collection<Object>) - Method in interface org.infinispan.commands.CommandsFactory
Builds an InvalidateFromL1Command
buildInvalidateFromL1Command(long, Collection<Object>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildInvalidateFromL1Command(Address, long, Collection<Object>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildInvalidateFromL1Command(Address, long, Collection<Object>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildInvalidateVersionsCommand(int, Object[], int[], long[], boolean) - Method in interface org.infinispan.commands.CommandsFactory
 
buildInvalidateVersionsCommand(int, Object[], int[], long[], boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracCleanupKeyCommand(Collection<? extends IracManagerKeyInfo>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracCleanupKeyCommand(Collection<? extends IracManagerKeyInfo>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracClearKeysCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracClearKeysCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracMetadataRequestCommand(int, IracEntryVersion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracMetadataRequestCommand(int, IracEntryVersion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracPutKeyValueCommand(Object, int, Object, Metadata, PrivateMetadata) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracPutKeyValueCommand(Object, int, Object, Metadata, PrivateMetadata) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracPutManyCommand(int) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracPutManyCommand(int) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracRequestStateCommand(IntSet) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracRequestStateCommand(IntSet) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracStateResponseCommand(int) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracStateResponseCommand(int) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracTombstoneCleanupCommand(int) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracTombstoneCleanupCommand(int) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracTombstonePrimaryCheckCommand(Collection<IracTombstoneInfo>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracTombstonePrimaryCheckCommand(Collection<IracTombstoneInfo>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracTombstoneRemoteSiteCheckCommand(List<Object>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracTombstoneRemoteSiteCheckCommand(List<Object>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracTombstoneStateResponseCommand(Collection<IracTombstoneInfo>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracTombstoneStateResponseCommand(Collection<IracTombstoneInfo>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracTouchCommand(Object) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracTouchCommand(Object) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracUpdateVersionCommand(Map<Integer, IracEntryVersion>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracUpdateVersionCommand(Map<Integer, IracEntryVersion>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildKeyReductionPublisherCommand(boolean, DeliveryGuarantee, IntSet, Set<K>, Set<K>, long, Function<? super Publisher<K>, ? extends CompletionStage<R>>, Function<? super Publisher<R>, ? extends CompletionStage<R>>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildKeyReductionPublisherCommand(boolean, DeliveryGuarantee, IntSet, Set<K>, Set<K>, long, Function<? super Publisher<K>, ? extends CompletionStage<R>>, Function<? super Publisher<R>, ? extends CompletionStage<R>>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildKeySetCommand(long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a KeySetCommand
buildKeySetCommand(long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildLockControlCommand(Object, long, GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Same as CommandsFactory.buildLockControlCommand(Collection, long, GlobalTransaction) but for locking a single key vs a collection of keys.
buildLockControlCommand(Object, long, GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildLockControlCommand(Collection<?>, long) - Method in interface org.infinispan.commands.CommandsFactory
 
buildLockControlCommand(Collection<?>, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildLockControlCommand(Collection<?>, long, GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Builds a LockControlCommand to control explicit remote locking
buildLockControlCommand(Collection<?>, long, GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildMetadata(long, TimeUnitValue, long, TimeUnitValue) - Method in class org.infinispan.server.hotrod.HotRodServer
 
buildMetadata2x(long, TimeUnitValue, long, TimeUnitValue) - Method in class org.infinispan.server.hotrod.HotRodServer
 
buildMultiClusterEventCommand(Map<UUID, Collection<ClusterEvent<K, V>>>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildMultiClusterEventCommand(Map<UUID, Collection<ClusterEvent<K, V>>>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildMultiEntriesFunctionalBackupWriteCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildMultiEntriesFunctionalBackupWriteCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildMultiKeyFunctionalBackupWriteCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildMultiKeyFunctionalBackupWriteCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildNextPublisherCommand(String) - Method in interface org.infinispan.commands.CommandsFactory
 
buildNextPublisherCommand(String) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildPrepareCommand(GlobalTransaction, List<WriteCommand>, boolean) - Method in interface org.infinispan.commands.CommandsFactory
Builds a PrepareCommand
buildPrepareCommand(GlobalTransaction, List<WriteCommand>, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildPutKeyValueCommand(Object, Object, int, Metadata, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a PutKeyValueCommand
buildPutKeyValueCommand(Object, Object, int, Metadata, long, boolean) - Method in interface org.infinispan.commands.CommandsFactory
 
buildPutKeyValueCommand(Object, Object, int, Metadata, long, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildPutMapBackupWriteCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildPutMapBackupWriteCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildPutMapCommand(Map<?, ?>, Metadata, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a PutMapCommand
buildPutMapCommand(Map<?, ?>, Metadata, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReadOnlyKeyCommand(Object, Function<EntryView.ReadEntryView<K, V>, R>, int, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildReadOnlyKeyCommand(Object, Function<EntryView.ReadEntryView<K, V>, R>, int, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReadOnlyManyCommand(Collection<?>, Function<EntryView.ReadEntryView<K, V>, R>, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildReadOnlyManyCommand(Collection<?>, Function<EntryView.ReadEntryView<K, V>, R>, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReadWriteKeyCommand(Object, Function<EntryView.ReadWriteEntryView<K, V>, R>, int, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildReadWriteKeyCommand(Object, Function<EntryView.ReadWriteEntryView<K, V>, R>, int, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReadWriteKeyValueCommand(Object, Object, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>, int, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildReadWriteKeyValueCommand(Object, Object, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>, int, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReadWriteManyCommand(Collection<?>, Function<EntryView.ReadWriteEntryView<K, V>, R>, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildReadWriteManyCommand(Collection<?>, Function<EntryView.ReadWriteEntryView<K, V>, R>, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReadWriteManyEntriesCommand(Map<?, ?>, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildReadWriteManyEntriesCommand(Map<?, ?>, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRemoveCommand(Object, Object, int, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a RemoveCommand
buildRemoveCommand(Object, Object, int, long, boolean) - Method in interface org.infinispan.commands.CommandsFactory
 
buildRemoveCommand(Object, Object, int, long, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRemoveExpiredCommand(Object, Object, int, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds an expired remove command that is used to remove only a specific entry when it expires via maxIdle
buildRemoveExpiredCommand(Object, Object, int, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRemoveExpiredCommand(Object, Object, int, Long, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds an expired remove command that is used to remove only a specific entry when it expires via lifespan
buildRemoveExpiredCommand(Object, Object, int, Long, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRenewBiasCommand(Object[]) - Method in interface org.infinispan.commands.CommandsFactory
 
buildRenewBiasCommand(Object[]) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReplaceCommand(Object, Object, Object, int, Metadata, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ReplaceCommand
buildReplaceCommand(Object, Object, Object, int, Metadata, long, boolean) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ReplaceCommand
buildReplaceCommand(Object, Object, Object, int, Metadata, long, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRevokeBiasCommand(Address, long, int, Collection<Object>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildRevokeBiasCommand(Address, long, int, Collection<Object>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRollbackCommand(GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Builds a RollbackCommand
buildRollbackCommand(GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildScatteredStateConfirmRevokeCommand(int, IntSet) - Method in interface org.infinispan.commands.CommandsFactory
 
buildScatteredStateConfirmRevokeCommand(int, IntSet) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildScatteredStateGetKeysCommand(int, IntSet) - Method in interface org.infinispan.commands.CommandsFactory
 
buildScatteredStateGetKeysCommand(int, IntSet) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildSingleKeyBackupWriteCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildSingleKeyBackupWriteCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildSingleKeyFunctionalBackupWriteCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildSingleKeyFunctionalBackupWriteCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildSingleRpcCommand(ReplicableCommand) - Method in interface org.infinispan.commands.CommandsFactory
Deprecated.
buildSingleRpcCommand(VisitableCommand) - Method in interface org.infinispan.commands.CommandsFactory
Builds a SingleRpcCommand "envelope" containing a single ReplicableCommand
buildSingleRpcCommand(VisitableCommand) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildSingleXSiteRpcCommand(VisitableCommand) - Method in interface org.infinispan.commands.CommandsFactory
Builds SingleRpcCommand used to perform VisitableCommand on the backup site,
buildSingleXSiteRpcCommand(VisitableCommand) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildSizeCommand(IntSet, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a SizeCommand
buildSizeCommand(IntSet, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildStateResponseCommand(int, Collection<StateChunk>, boolean, boolean) - Method in interface org.infinispan.commands.CommandsFactory
Builds a StateResponseCommand used for pushing cache entries to another node.
buildStateResponseCommand(int, Collection<StateChunk>, boolean, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildStateTransferCancelCommand(int, IntSet) - Method in interface org.infinispan.commands.CommandsFactory
 
buildStateTransferCancelCommand(int, IntSet) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildStateTransferGetListenersCommand(int) - Method in interface org.infinispan.commands.CommandsFactory
 
buildStateTransferGetListenersCommand(int) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildStateTransferGetTransactionsCommand(int, IntSet) - Method in interface org.infinispan.commands.CommandsFactory
 
buildStateTransferGetTransactionsCommand(int, IntSet) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildStateTransferStartCommand(int, IntSet) - Method in interface org.infinispan.commands.CommandsFactory
 
buildStateTransferStartCommand(int, IntSet) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildTouchCommand(Object, int, boolean, long) - Method in interface org.infinispan.commands.CommandsFactory
 
buildTouchCommand(Object, int, boolean, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildTxCompletionNotificationCommand(long) - Method in interface org.infinispan.commands.CommandsFactory
 
buildTxCompletionNotificationCommand(long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildTxCompletionNotificationCommand(XidImpl, GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Builds a TxCompletionNotificationCommand.
buildTxCompletionNotificationCommand(XidImpl, GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildTxReadOnlyKeyCommand(Object, Function<EntryView.ReadEntryView<K, V>, R>, List<Mutation<K, V, ?>>, int, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildTxReadOnlyKeyCommand(Object, Function<EntryView.ReadEntryView<K, V>, R>, List<Mutation<K, V, ?>>, int, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildTxReadOnlyManyCommand(Collection<?>, List<List<Mutation<K, V, ?>>>, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildTxReadOnlyManyCommand(Collection<?>, List<List<Mutation<K, V, ?>>>, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildVersionedCommitCommand(GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Builds a VersionedCommitCommand
buildVersionedCommitCommand(GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildVersionedPrepareCommand(GlobalTransaction, List<WriteCommand>, boolean) - Method in interface org.infinispan.commands.CommandsFactory
Builds a VersionedPrepareCommand
buildVersionedPrepareCommand(GlobalTransaction, List<WriteCommand>, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildWriteOnlyKeyCommand(Object, Consumer<EntryView.WriteEntryView<K, V>>, int, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildWriteOnlyKeyCommand(Object, Consumer<EntryView.WriteEntryView<K, V>>, int, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildWriteOnlyKeyValueCommand(Object, Object, BiConsumer<T, EntryView.WriteEntryView<K, V>>, int, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildWriteOnlyKeyValueCommand(Object, Object, BiConsumer<T, EntryView.WriteEntryView<K, V>>, int, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildWriteOnlyManyCommand(Collection<?>, Consumer<EntryView.WriteEntryView<K, V>>, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildWriteOnlyManyCommand(Collection<?>, Consumer<EntryView.WriteEntryView<K, V>>, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildWriteOnlyManyEntriesCommand(Map<?, ?>, BiConsumer<T, EntryView.WriteEntryView<K, V>>, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildWriteOnlyManyEntriesCommand(Map<?, ?>, BiConsumer<T, EntryView.WriteEntryView<K, V>>, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteAmendOfflineStatusCommand(String, Integer, Long) - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteAmendOfflineStatusCommand(String, Integer, Long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteAutoTransferStatusCommand(String) - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteAutoTransferStatusCommand(String) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteBringOnlineCommand(String) - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteBringOnlineCommand(String) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteOfflineStatusCommand(String) - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteOfflineStatusCommand(String) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteSetStateTransferModeCommand(String, XSiteStateTransferMode) - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteSetStateTransferModeCommand(String, XSiteStateTransferMode) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteStatePushCommand(XSiteState[], long) - Method in interface org.infinispan.commands.CommandsFactory
Builds XSiteStatePushCommand used to transfer a single chunk of data between sites.
buildXSiteStatePushCommand(XSiteState[], long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteStateTransferCancelSendCommand(String) - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteStateTransferCancelSendCommand(String) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteStateTransferClearStatusCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteStateTransferClearStatusCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteStateTransferFinishReceiveCommand(String) - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteStateTransferFinishReceiveCommand(String) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteStateTransferFinishSendCommand(String, boolean) - Method in interface org.infinispan.commands.