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

ABORTED - Enum constant in enum class org.infinispan.transaction.impl.TransactionTable.CompletedTransactionStatus
 
AbstractArtifact - Class in org.infinispan.commons.maven
 
AbstractArtifact() - Constructor for class org.infinispan.commons.maven.AbstractArtifact
 
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
 
AbstractBlockingPop - Class in org.infinispan.server.resp.commands.list.blocking
Derogating to the command documentation, when multiple client are blocked on a BLPOP, the order in which they will be served is unspecified.
AbstractBlockingPop(int, int, int, int) - Constructor for class org.infinispan.server.resp.commands.list.blocking.AbstractBlockingPop
 
AbstractBlockingPop.PollListenerSynchronizer - Class in org.infinispan.server.resp.commands.list.blocking
PollListenerSynchronizer This class synchronizes the access to a CompletableFuture `resultFuture` so that its final value will be completed either - with value v by an onListenerAdded() call if a not null value is found - otherwise by onEvent(k) call if the referred entry is not null or empty
AbstractBlockingPop.PubSubListener - Class in org.infinispan.server.resp.commands.list.blocking
 
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,S2> - 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, for removal: This API element is subject to removal in a future version.
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> - Class in org.infinispan.distribution.ch.impl
 
AbstractConsistentHashFactory() - Constructor for class org.infinispan.distribution.ch.impl.AbstractConsistentHashFactory
 
AbstractCounterConfiguration - Class in org.infinispan.counter.configuration
Base counter configuration with its name, initial value and Storage mode.
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
 
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
 
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
Common parent for both embedded and standalone JBoss Marshalling-based marshallers.
AbstractJBossMarshaller() - Constructor for class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller
 
AbstractJBossMarshaller.DebuggingExceptionListener - Class in org.infinispan.jboss.marshalling.commons
 
AbstractJdbcStoreConfiguration<T> - Class in org.infinispan.persistence.jdbc.common.configuration
 
AbstractJdbcStoreConfiguration(Enum<?>, AttributeSet, AsyncStoreConfiguration, ConnectionFactoryConfiguration) - Constructor for class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfiguration
 
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> - 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> - 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> - 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,S,A> - Class in org.infinispan.server.core.configuration
Helper
AbstractProtocolServerConfigurationChildBuilder(ProtocolServerConfigurationChildBuilder<T, S, A>) - Constructor for class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
 
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<T> - Class in org.infinispan.persistence.sql.configuration
 
AbstractSchemaJdbcConfiguration(Enum<?>, AttributeSet, AsyncStoreConfiguration, ConnectionFactoryConfiguration, SchemaJdbcConfiguration) - Constructor for class org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfiguration
 
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> - 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> - Class in org.infinispan.persistence.sql
 
AbstractSchemaJdbcStore.ProtostreamFieldType - Enum Class in org.infinispan.persistence.sql
 
AbstractSchemaJdbcStore.SchemaTableOperations<K,V,C> - 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> - Class in org.infinispan.configuration.cache
Abstract store configuration that should be extended when the store configuration supports being segmented.
AbstractSegmentedStoreConfiguration(Enum<?>, 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<T> - Class in org.infinispan.configuration.cache
 
AbstractStoreConfiguration(Enum<?>, AttributeSet, AsyncStoreConfiguration, ConfigurationElement<?>...) - Constructor for class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
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> - 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
 
AbstractTransportConfigurationChildBuilder - Class in org.infinispan.configuration.cache
 
AbstractTransportConfigurationChildBuilder(TransactionConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractTransportConfigurationChildBuilder
 
AbstractTxInvocationContext<T> - 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(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(int) - Method in class org.infinispan.server.resp.logging.AccessLoggerManager
 
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, Object, Metadata, Object, Metadata, EventType) - Method in class org.infinispan.server.resp.filter.EventListenerKeysFilter
 
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(IntSet, Throwable) - Method in class org.infinispan.xsite.irac.IracResponseCollector
 
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(ScoredValue<byte[]>, ResponseWriter) - Method in class org.infinispan.server.resp.response.ScoredValueSerializer
 
accept(LogAppender.WriteOperation) - Method in class org.infinispan.persistence.sifs.LogAppender
 
accept(ValidResponse, Throwable) - Method in class org.infinispan.remoting.transport.impl.XSiteResponseImpl
 
accept(ZSetCommonUtils.ZOperationResponse, ResponseWriter) - Method in record class org.infinispan.server.resp.commands.sortedset.ZSetCommonUtils.ZOperationResponse
 
accept(T, CounterTracker) - Method in class org.infinispan.commons.stat.CounterMetricInfo
 
accept(T, DistributionSummaryTracker) - Method in class org.infinispan.commons.stat.DistributionSummaryMetricInfo
 
accept(T, TimerTracker) - Method in class org.infinispan.commons.stat.FunctionTimerMetricInfo
 
accept(T, TimerTracker) - Method in class org.infinispan.commons.stat.TimerMetricInfo
 
accept(T, Throwable) - Method in interface org.infinispan.telemetry.InfinispanSpan
 
accept(T, O) - Method in interface org.infinispan.server.resp.serialization.NestedResponseSerializer
 
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 class 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
 
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 class org.infinispan.persistence.jdbc.common.DatabaseType
 
AccessControlFilter<A> - 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
 
AccessData - Class in org.infinispan.server.resp.logging
Access data from a single request.
AccessLoggerManager - Class in org.infinispan.server.resp.logging
Handle the access log.
AccessLoggerManager(ChannelHandlerContext, TimeService) - Constructor for class org.infinispan.server.resp.logging.AccessLoggerManager
 
accessLogging - Variable in class org.infinispan.server.memcached.MemcachedBaseDecoder
 
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 class 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.
AclCategory - Class in org.infinispan.server.resp
 
AclCategory() - Constructor for class org.infinispan.server.resp.AclCategory
 
aclMask() - Method in class org.infinispan.server.resp.commands.cluster.CLUSTER
 
aclMask() - Method in class org.infinispan.server.resp.commands.cluster.KEYSLOT
 
aclMask() - Method in class org.infinispan.server.resp.commands.cluster.NODES
 
aclMask() - Method in class org.infinispan.server.resp.commands.cluster.SHARDS
 
aclMask() - Method in class org.infinispan.server.resp.commands.cluster.SLOTS
 
aclMask() - Method in class org.infinispan.server.resp.commands.CONFIG
 
aclMask() - Method in class org.infinispan.server.resp.commands.connection.AUTH
 
aclMask() - Method in class org.infinispan.server.resp.commands.connection.CLIENT
 
aclMask() - Method in class org.infinispan.server.resp.commands.connection.COMMAND
 
aclMask() - Method in class org.infinispan.server.resp.commands.connection.DBSIZE
 
aclMask() - Method in class org.infinispan.server.resp.commands.connection.ECHO
 
aclMask() - Method in class org.infinispan.server.resp.commands.connection.HELLO
 
aclMask() - Method in class org.infinispan.server.resp.commands.connection.MEMORY
 
aclMask() - Method in class org.infinispan.server.resp.commands.connection.MODULE
 
aclMask() - Method in class org.infinispan.server.resp.commands.connection.PING
 
aclMask() - Method in class org.infinispan.server.resp.commands.connection.QUIT
 
aclMask() - Method in class org.infinispan.server.resp.commands.connection.READONLY
 
aclMask() - Method in class org.infinispan.server.resp.commands.connection.READWRITE
 
aclMask() - Method in class org.infinispan.server.resp.commands.connection.RESET
 
aclMask() - Method in class org.infinispan.server.resp.commands.connection.SELECT
 
aclMask() - Method in class org.infinispan.server.resp.commands.generic.EXISTS
 
aclMask() - Method in class org.infinispan.server.resp.commands.generic.EXPIRE
 
aclMask() - Method in class org.infinispan.server.resp.commands.generic.FLUSHDB
 
aclMask() - Method in class org.infinispan.server.resp.commands.generic.KEYS
 
aclMask() - Method in class org.infinispan.server.resp.commands.generic.PERSIST
 
aclMask() - Method in class org.infinispan.server.resp.commands.generic.RANDOMKEY
 
aclMask() - Method in class org.infinispan.server.resp.commands.generic.RENAME
 
aclMask() - Method in class org.infinispan.server.resp.commands.generic.RENAMENX
 
aclMask() - Method in class org.infinispan.server.resp.commands.generic.SCAN
 
aclMask() - Method in class org.infinispan.server.resp.commands.generic.SORT_RO
 
aclMask() - Method in class org.infinispan.server.resp.commands.generic.SORT
 
aclMask() - Method in class org.infinispan.server.resp.commands.generic.TIME
 
aclMask() - Method in class org.infinispan.server.resp.commands.generic.TOUCH
 
aclMask() - Method in class org.infinispan.server.resp.commands.generic.TTL
 
aclMask() - Method in class org.infinispan.server.resp.commands.generic.TYPE
 
aclMask() - Method in class org.infinispan.server.resp.commands.hash.HDEL
 
aclMask() - Method in class org.infinispan.server.resp.commands.hash.HEXISTS
 
aclMask() - Method in class org.infinispan.server.resp.commands.hash.HGET
 
aclMask() - Method in class org.infinispan.server.resp.commands.hash.HGETALL
 
aclMask() - Method in class org.infinispan.server.resp.commands.hash.HINCRBY
 
aclMask() - Method in class org.infinispan.server.resp.commands.hash.HINCRBYFLOAT
 
aclMask() - Method in class org.infinispan.server.resp.commands.hash.HKEYS
 
aclMask() - Method in class org.infinispan.server.resp.commands.hash.HLEN
 
aclMask() - Method in class org.infinispan.server.resp.commands.hash.HMGET
 
aclMask() - Method in class org.infinispan.server.resp.commands.hash.HMSET
 
aclMask() - Method in class org.infinispan.server.resp.commands.hash.HRANDFIELD
 
aclMask() - Method in class org.infinispan.server.resp.commands.hash.HSCAN
 
aclMask() - Method in class org.infinispan.server.resp.commands.hash.HSETNX
 
aclMask() - Method in class org.infinispan.server.resp.commands.hash.HSTRLEN
 
aclMask() - Method in class org.infinispan.server.resp.commands.hash.HVALS
 
aclMask() - Method in class org.infinispan.server.resp.commands.hll.PFADD
 
aclMask() - Method in class org.infinispan.server.resp.commands.INFO
 
aclMask() - Method in class org.infinispan.server.resp.commands.list.blocking.BLMPOP
 
aclMask() - Method in class org.infinispan.server.resp.commands.list.blocking.BLPOP
 
aclMask() - Method in class org.infinispan.server.resp.commands.list.blocking.BRPOP
 
aclMask() - Method in class org.infinispan.server.resp.commands.list.LINDEX
 
aclMask() - Method in class org.infinispan.server.resp.commands.list.LINSERT
 
aclMask() - Method in class org.infinispan.server.resp.commands.list.LLEN
 
aclMask() - Method in class org.infinispan.server.resp.commands.list.LMOVE
 
aclMask() - Method in class org.infinispan.server.resp.commands.list.LMPOP
 
aclMask() - Method in class org.infinispan.server.resp.commands.list.LPOP
 
aclMask() - Method in class org.infinispan.server.resp.commands.list.LPOS
 
aclMask() - Method in class org.infinispan.server.resp.commands.list.LPUSH
 
aclMask() - Method in class org.infinispan.server.resp.commands.list.LPUSHX
 
aclMask() - Method in class org.infinispan.server.resp.commands.list.LRANGE
 
aclMask() - Method in class org.infinispan.server.resp.commands.list.LREM
 
aclMask() - Method in class org.infinispan.server.resp.commands.list.LSET
 
aclMask() - Method in class org.infinispan.server.resp.commands.list.LTRIM
 
aclMask() - Method in class org.infinispan.server.resp.commands.list.RPOP
 
aclMask() - Method in class org.infinispan.server.resp.commands.list.RPOPLPUSH
 
aclMask() - Method in class org.infinispan.server.resp.commands.list.RPUSH
 
aclMask() - Method in class org.infinispan.server.resp.commands.list.RPUSHX
 
aclMask() - Method in class org.infinispan.server.resp.commands.pubsub.PSUBSCRIBE
 
aclMask() - Method in class org.infinispan.server.resp.commands.pubsub.PUBLISH
 
aclMask() - Method in class org.infinispan.server.resp.commands.pubsub.PUBSUB
 
aclMask() - Method in class org.infinispan.server.resp.commands.pubsub.PUNSUBSCRIBE
 
aclMask() - Method in class org.infinispan.server.resp.commands.pubsub.SUBSCRIBE
 
aclMask() - Method in class org.infinispan.server.resp.commands.pubsub.UNSUBSCRIBE
 
aclMask() - Method in class org.infinispan.server.resp.commands.set.SADD
 
aclMask() - Method in class org.infinispan.server.resp.commands.set.SCARD
 
aclMask() - Method in class org.infinispan.server.resp.commands.set.SDIFF
 
aclMask() - Method in class org.infinispan.server.resp.commands.set.SDIFFSTORE
 
aclMask() - Method in class org.infinispan.server.resp.commands.set.SINTER
 
aclMask() - Method in class org.infinispan.server.resp.commands.set.SINTERCARD
 
aclMask() - Method in class org.infinispan.server.resp.commands.set.SINTERSTORE
 
aclMask() - Method in class org.infinispan.server.resp.commands.set.SISMEMBER
 
aclMask() - Method in class org.infinispan.server.resp.commands.set.SMEMBERS
 
aclMask() - Method in class org.infinispan.server.resp.commands.set.SMISMEMBER
 
aclMask() - Method in class org.infinispan.server.resp.commands.set.SMOVE
 
aclMask() - Method in class org.infinispan.server.resp.commands.set.SPOP
 
aclMask() - Method in class org.infinispan.server.resp.commands.set.SRANDMEMBER
 
aclMask() - Method in class org.infinispan.server.resp.commands.set.SREM
 
aclMask() - Method in class org.infinispan.server.resp.commands.set.SSCAN
 
aclMask() - Method in class org.infinispan.server.resp.commands.set.SUNION
 
aclMask() - Method in class org.infinispan.server.resp.commands.set.SUNIONSTORE
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.internal.ZREMRANGE
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZADD
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZCARD
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZCOUNT
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZDIFF
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZDIFFSTORE
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZINCRBY
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZINTER
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZINTERCARD
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZINTERSTORE
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZLEXCOUNT
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZMPOP
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZMSCORE
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZPOPMAX
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZPOPMIN
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZRANDMEMBER
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZRANGE
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZRANGESTORE
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZRANK
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZREM
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZSCAN
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZSCORE
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZUNION
 
aclMask() - Method in class org.infinispan.server.resp.commands.sortedset.ZUNIONSTORE
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.APPEND
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.DECR
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.DECRBY
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.DEL
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.GET
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.GETDEL
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.GETEX
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.GETRANGE
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.GETSET
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.INCR
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.INCRBY
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.INCRBYFLOAT
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.LCS
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.MGET
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.MSET
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.MSETNX
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.PSETEX
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.SET
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.SETEX
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.SETNX
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.SETRANGE
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.STRALGO
 
aclMask() - Method in class org.infinispan.server.resp.commands.string.STRLEN
 
aclMask() - Method in class org.infinispan.server.resp.commands.tx.DISCARD
 
aclMask() - Method in class org.infinispan.server.resp.commands.tx.EXEC
 
aclMask() - Method in class org.infinispan.server.resp.commands.tx.MULTI
 
aclMask() - Method in class org.infinispan.server.resp.commands.tx.UNWATCH
 
aclMask() - Method in class org.infinispan.server.resp.commands.tx.WATCH
 
aclMask() - Method in class org.infinispan.server.resp.RespCommand
 
acquire(int) - Method in interface org.infinispan.server.memcached.ByteBufPool
This method will return a pooled ByteBuf.
acquire(int) - Method in interface org.infinispan.server.resp.ByteBufPool
This method will return a pooled ByteBuf.
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 class org.infinispan.configuration.parsing.Attribute
 
ACQUIRED - Enum constant in enum class org.infinispan.util.concurrent.locks.LockState
The lock owner left the queue and it is available to acquire the lock.
acquireHeader() - Method in class org.infinispan.server.memcached.binary.BinaryAuthDecoderImpl
 
acquireHeader() - Method in class org.infinispan.server.memcached.binary.BinaryOpDecoderImpl
 
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 Class 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 class org.infinispan.server.hotrod.tx.table.Status
The client transaction is being replayed.
activeIterations() - Method in class org.infinispan.server.iteration.DefaultIterationManager
 
activeIterations() - Method in interface org.infinispan.server.iteration.IterationManager
 
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
 
actualHandleRequest(ChannelHandlerContext, RespCommand, List<byte[]>) - Method in class org.infinispan.server.resp.Resp3AuthHandler
 
actualHandleRequest(ChannelHandlerContext, RespCommand, List<byte[]>) - Method in class org.infinispan.server.resp.Resp3Handler
 
actualHandleRequest(ChannelHandlerContext, RespCommand, List<byte[]>) - Method in class org.infinispan.server.resp.RespRequestHandler
Handles the RESP request returning a stage that when complete notifies the command has completed as well as providing the request handler for subsequent commands.
actualHandleRequest(ChannelHandlerContext, RespCommand, List<byte[]>) - Method in class org.infinispan.server.resp.SubscriberHandler
 
actualHandleRequest(ChannelHandlerContext, RespCommand, List<byte[]>) - Method in class org.infinispan.server.resp.tx.RespTransactionHandler
 
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 - Enum constant in enum class org.infinispan.server.memcached.text.TextCommand
 
add() - Static method in class org.infinispan.reactive.publisher.PublisherReducers
 
add(byte[]) - Method in class org.infinispan.server.resp.hll.HyperLogLog
 
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, E) - Method in class org.infinispan.commons.util.ForwardingList
 
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(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(K, Collection<V>) - Method in class org.infinispan.multimap.impl.EmbeddedSetCache
Add the specified elements to the set, creates the set in case
add(K, V) - Method in class org.infinispan.multimap.impl.EmbeddedSetCache
Add the specified element to the set, creates the set in case
add(Flags<?, ?>) - Method in enum class org.infinispan.client.hotrod.Flag
 
add(Flag) - Method in class org.infinispan.client.hotrod.HotRodFlags
 
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(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(BinaryHeader, byte[], byte[], int, int, boolean) - Method in class org.infinispan.server.memcached.binary.BinaryOpDecoderImpl
 
add(TextHeader, byte[], byte[], int, int, boolean) - Method in class org.infinispan.server.memcached.text.TextOpDecoder
 
add(R) - Method in class org.infinispan.util.CollectionMapper
 
add(R) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
 
add(T) - Method in class org.infinispan.commons.util.ArrayRingBuffer
 
add(V, boolean) - Method in class org.infinispan.multimap.impl.Bucket
 
ADD - Enum constant in enum class org.infinispan.server.memcached.binary.BinaryCommand
 
ADD_AND_UPDATE_ONLY_INCOMPATIBLE_ERROR - Static variable in class org.infinispan.multimap.impl.SortedSetAddArgs
 
ADD_AND_UPDATE_OPTIONS_INCOMPATIBLE_ERROR - Static variable in class org.infinispan.multimap.impl.SortedSetAddArgs
 
ADD_BLOOM_FILTER_CLIENT_LISTENER - Enum constant in enum class 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 class 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
 
addActiveProfile(String) - Method in class org.infinispan.commons.maven.MavenSettings
 
addAdvancedExternalizer(int, AdvancedExternalizer<T>) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
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, for removal: This API element is subject to removal in a future version.
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, for removal: This API element is subject to removal in a future version.
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 Map.Entry<K, V>>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySet
 
addAll(Collection<? extends CacheEntry<K, V>>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntrySet
 
addAll(Collection<? extends R>) - Method in class org.infinispan.util.CollectionMapper
 
addAll(Collection<? extends R>) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
 
addAll(Collection<V>) - Method in class org.infinispan.multimap.impl.SetBucket
 
addAll(List<CorsConfig>) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
 
addAll(Flags<Flag, HotRodFlags>) - Method in class org.infinispan.client.hotrod.HotRodFlags
 
addAll(IntSet) - Method in interface org.infinispan.commons.util.IntSet
Adds all ints from the provided set into this one
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.core.configuration.SaslConfigurationBuilder
 
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
 
addCacheDependency(EmbeddedCacheManager, String, String) - Static method in class org.infinispan.security.actions.SecurityActions
 
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, for removal: This API element is subject to removal in a future version.
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.commons.api.query.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.commons.api.query.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.commons.api.query.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
 
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
 
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
 
addEventToSite(ByteString, XSiteEvent) - Method in class org.infinispan.xsite.events.XSiteEventSender
 
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
addExpire(Object, IracMetadata) - Method in class org.infinispan.xsite.commands.remote.IracPutManyRequest
 
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(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
addFilteredListener(ListenerHolder, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in 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
 
addFlags(long) - Method in interface org.infinispan.commands.FlagAffectedCommand
Add a set of flags to the command.
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.IndexReaderConfigurationBuilder
 
addIndexedEntities(Class<?>...) - Method in class org.infinispan.configuration.cache.IndexShardingConfigurationBuilder
 
addIndexedEntities(Class<?>...) - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
 
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.IndexReaderConfigurationBuilder
 
addIndexedEntities(String...) - Method in class org.infinispan.configuration.cache.IndexShardingConfigurationBuilder
 
addIndexedEntities(String...) - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
 
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.IndexReaderConfigurationBuilder
 
addIndexedEntity(Class<?>) - Method in class org.infinispan.configuration.cache.IndexShardingConfigurationBuilder
 
addIndexedEntity(Class<?>) - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
 
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.IndexReaderConfigurationBuilder
 
addIndexedEntity(String) - Method in class org.infinispan.configuration.cache.IndexShardingConfigurationBuilder
 
addIndexedEntity(String) - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
 
addIndexedEntity(String) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
addIndexedEntity(String) - Method in interface org.infinispan.configuration.cache.IndexingConfigurationChildBuilder
 
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, for removal: This API element is subject to removal in a future version.
Since 14.0. To be removed without replacement.
additionalParameters() - Method in class org.infinispan.client.hotrod.telemetry.impl.TelemetryOperation
 
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, for removal: This API element is subject to removal in a future version.
addJavaSerialWhiteList(String...) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
addJavaSerialWhiteList(String...) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
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.IndexReaderConfigurationBuilder
 
addKeyTransformer(Class<?>, Class<?>) - Method in class org.infinispan.configuration.cache.IndexShardingConfigurationBuilder
 
addKeyTransformer(Class<?>, Class<?>) - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
 
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.iteration.DefaultIterationManager
 
addKeyValueFilterConverterFactory(String, KeyValueFilterConverterFactory) - Method in interface org.infinispan.server.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) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
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>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
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(EmbeddedCacheManager, Object) - Static method in class org.infinispan.security.actions.SecurityActions
 
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
 
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(EmbeddedCacheManager, Object) - Static method in class org.infinispan.security.actions.SecurityActions
 
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
An add listener operation for StrongCounter.addListener(CounterListener) and WeakCounter.addListener(CounterListener)
AddListenerOperation(String, byte[]) - Constructor for class org.infinispan.client.hotrod.counter.operation.AddListenerOperation
 
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
 
addLoggerListenerAsync(EmbeddedCacheManager, Object) - Static method in class org.infinispan.security.actions.SecurityActions
 
AddLoggerListenerAsyncAction - Class in org.infinispan.security.actions
Add logger listener action.
AddLoggerListenerAsyncAction(EmbeddedCacheManager, Object) - Constructor for class org.infinispan.security.actions.AddLoggerListenerAsyncAction
 
addMany(Collection<ScoredValue<V>>, boolean, boolean, boolean, boolean) - Method in class org.infinispan.multimap.impl.SortedSetBucket
 
addMany(K, Collection<ScoredValue<V>>, SortedSetAddArgs) - Method in class org.infinispan.multimap.impl.EmbeddedMultimapSortedSetCache
Adds and/or updates, depending on the provided options, the value and the associated score.
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.RestAuthenticationConfigurationBuilder
 
addMechanisms(String...) - Method in class org.infinispan.server.core.configuration.SaslConfigurationBuilder
 
addMechProperty(String, String) - Method in class org.infinispan.server.core.configuration.SaslConfigurationBuilder
 
addMember(String) - Method in enum class org.infinispan.remoting.transport.impl.EmptyRaftManager
 
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
 
addOnly - Variable in class org.infinispan.multimap.impl.SortedSetAddArgs
 
addOnly() - Method in class org.infinispan.multimap.impl.SortedSetAddArgs.Builder
 
AddOperation - Class in org.infinispan.client.hotrod.counter.operation
Add operation.
AddOperation(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
 
AddOrUpdatesCounters() - Constructor for class org.infinispan.multimap.impl.SortedSetBucket.AddOrUpdatesCounters
 
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.AddListenerOperation
 
addParams(StringBuilder) - Method in class org.infinispan.client.hotrod.counter.operation.AddOperation
 
addParams(StringBuilder) - Method in class org.infinispan.client.hotrod.counter.operation.CompareAndSwapOperation
 
addParams(StringBuilder) - Method in class org.infinispan.client.hotrod.counter.operation.DefineCounterOperation
 
addParams(StringBuilder) - Method in class org.infinispan.client.hotrod.counter.operation.GetConfigurationOperation
 
addParams(StringBuilder) - Method in class org.infinispan.client.hotrod.counter.operation.GetValueOperation
 
addParams(StringBuilder) - Method in class org.infinispan.client.hotrod.counter.operation.IsDefinedOperation
 
addParams(StringBuilder) - Method in class org.infinispan.client.hotrod.counter.operation.RemoveListenerOperation
 
addParams(StringBuilder) - Method in class org.infinispan.client.hotrod.counter.operation.RemoveOperation
 
addParams(StringBuilder) - Method in class org.infinispan.client.hotrod.counter.operation.ResetOperation
 
addParams(StringBuilder) - Method in class org.infinispan.client.hotrod.counter.operation.SetOperation
 
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.core.configuration.SaslConfigurationBuilder
 
addPrimaryOwner(int, Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.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
 
addProfile(MavenSettings.Profile) - Method in class org.infinispan.commons.maven.MavenSettings
 
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 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.ScheduledExecutorFactoryConfigurationBuilder
Add key/value property pair to this executor factory configuration
addProperty(String, String) - Method in class org.infinispan.server.core.configuration.SaslConfigurationBuilder
 
addProtoSchemas(String...) - Method in class org.infinispan.server.core.backup.BackupManagerResources.Builder
 
addProxy(MavenSettings.Proxy) - Method in class org.infinispan.commons.maven.MavenSettings
 
ADDQ - Enum constant in enum class org.infinispan.server.memcached.binary.BinaryCommand
 
addQOP(String) - Method in class org.infinispan.server.core.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
addRemoteContainer(String) - Method in class org.infinispan.persistence.remote.configuration.global.RemoteContainersConfigurationBuilder
 
addRemoteSite(String, String, String, String) - Method in class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.RemoteSites
 
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
 
addRemove(Object, IracMetadata) - Method in class org.infinispan.xsite.commands.remote.IracPutManyRequest
 
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 class org.infinispan.configuration.parsing.Attribute
 
addresses() - Method in class org.infinispan.rest.distribution.CacheDistributionInfo
 
addresses() - Method in class org.infinispan.rest.distribution.KeyDistributionInfo
 
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, for removal: This API element is subject to removal in a future version.
since 13.0. To be removed in 16.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.
addStorageFormatFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
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.core.configuration.SaslConfigurationBuilder
 
addStrongCounter() - Method in class org.infinispan.counter.configuration.StrongCounterConfigurationBuilder
 
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.
addUpdate(Object, Object, Metadata, IracMetadata) - Method in class org.infinispan.xsite.commands.remote.IracPutManyRequest
 
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.
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.StrongCounterConfigurationBuilder
 
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
 
ADMIN - Enum constant in enum class org.infinispan.security.AuthorizationPermission
Allows performing "administrative" operations on a cache
ADMIN - Static variable in class org.infinispan.server.resp.AclCategory
 
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 Class in org.infinispan.server.core.admin
AdminOperations
AdminOperationParameter - Enum Class 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(AdminOperationsHandler) - Method in class org.infinispan.server.resp.configuration.RespServerConfigurationBuilder
 
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 class org.infinispan.configuration.parsing.Element
 
ADVANCED_EXTERNALIZERS - Enum constant in enum class 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, for removal: This API element is subject to removal in a future version.
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, for removal: This API element is subject to removal in a future version.
since 11.0 replaced by NonBlockingStore
AdvancedCacheWriter<K,V> - Interface in org.infinispan.persistence.spi
Deprecated, for removal: This API element is subject to removal in a future version.
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, for removal: This API element is subject to removal in a future version.
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, for removal: This API element is subject to removal in a future version.
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, for removal: This API element is subject to removal in a future version.
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 - Enum constant in enum class org.infinispan.configuration.parsing.Attribute
 
AFTER - Enum constant in enum class org.infinispan.container.versioning.InequalVersionComparisonResult
Denotes a version that was created temporally after another version.
AFTER - Static variable in class org.infinispan.server.resp.commands.list.LINSERT
 
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
 
afterCreation(Protocol) - Method in class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator
 
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.
AGGCommand - Class in org.infinispan.server.resp.commands.sortedset.internal
Common implementation for UNION and INTER commands
AGGCommand(int, int, int, int, AGGCommand.AGGCommandType) - Constructor for class org.infinispan.server.resp.commands.sortedset.internal.AGGCommand
 
AGGCommand.AGGCommandType - Enum Class in org.infinispan.server.resp.commands.sortedset.internal
 
AGGREGATE - Static variable in class org.infinispan.server.resp.commands.sortedset.internal.AGGCommand
 
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.commons.util.concurrent.CompletionStages
Returns a CompletionStage that also can be composed of many other CompletionStages.
aggregateCompletionStage(R) - Static method in class org.infinispan.commons.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.commons.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.query.impl.IndexedQueryImpl
 
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.
ALIAS_NAME - Static variable in class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
 
AliasCache<K,V> - Class in org.infinispan.cache.impl
 
AliasCache(AdvancedCache<K, V>, String) - Constructor for class org.infinispan.cache.impl.AliasCache
 
aliases() - Method in class org.infinispan.configuration.cache.Configuration
 
aliases(String...) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationChildBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.AbstractPersistenceConfigurationChildBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.remote.configuration.AbstractSecurityConfigurationChildBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.AbstractTransportConfigurationChildBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.jdbc.common.configuration.CDIConnectionFactoryConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.security.impl.CreatePermissionConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.CustomStoreConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.IndexReaderConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.IndexShardingConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder.StringTableManipulationConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.jdbc.common.configuration.ManagedConnectionFactoryConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.remote.configuration.MechanismConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.MemoryStorageConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.QueryConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.SecurityConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.remote.configuration.SecurityConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.parsing.SFSToSIFSConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.StatisticsConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.TracingConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.persistence.remote.configuration.TrustStoreConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
 
aliases(String...) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
aliases(String...) - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
ALIASES - Enum constant in enum class org.infinispan.configuration.parsing.Attribute
 
ALIASES - Static variable in class org.infinispan.configuration.cache.Configuration
 
all() - Static method in class org.infinispan.server.resp.commands.Commands
 
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 class 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 class org.infinispan.manager.ClusterExecutionPolicy
The command can be executed on any node in the cluster
ALL - Enum constant in enum class org.infinispan.security.AuthorizationPermission
Aggregate permission which implies all the others
ALL_COMMANDS - Static variable in class org.infinispan.server.resp.commands.Commands
 
ALL_NODES - Enum constant in enum class org.infinispan.tasks.TaskExecutionMode
 
ALL_READ - Enum constant in enum class org.infinispan.security.AuthorizationPermission
Aggregate permission which implies all read permissions
ALL_WRITE - Enum constant in enum class 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
 
allocateBuffer(ChannelHandlerContext, int) - Method in class org.infinispan.server.resp.RespHandler
 
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.commons.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.commons.util.concurrent.CompletionStages
Returns a CompletableStage that completes when both of the provides CompletionStages complete.
ALLOW - Enum constant in enum class org.infinispan.security.AuditResponse
 
ALLOW_CREDENTIALS - Static variable in class org.infinispan.rest.configuration.CorsRuleConfiguration
 
ALLOW_DUPLICATE_DOMAINS - Enum constant in enum class org.infinispan.configuration.parsing.Attribute
Deprecated, for removal: This API element is subject to removal in a future version.
ALLOW_HEADERS - Static variable in class org.infinispan.rest.configuration.CorsRuleConfiguration
 
ALLOW_LIST - Enum constant in enum class 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 class org.infinispan.partitionhandling.PartitionHandling
Allow entries on each partition to diverge, with conflicts resolved during merge.
ALLOW_READS - Enum constant in enum class 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
 
ALLOWED_DUPLICATES - Static variable in class org.infinispan.configuration.parsing.CacheParser
 
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 class 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, BlockingManager, ScheduledExecutorService) - Static method in class org.infinispan.manager.impl.ClusterExecutors
 
allTypeIdentifiers() - Method in interface org.infinispan.search.mapper.session.impl.InfinispanTypeContextProvider
 
alpha - Variable in class org.infinispan.multimap.impl.SortableBucket.SortOptions
 
ALPHA - Enum constant in enum class org.infinispan.server.resp.commands.generic.SORT.Arg
 
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 class 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 class org.infinispan.xsite.status.TakeSiteOfflineResponse
 
ALREADY_ONLINE - Enum constant in enum class org.infinispan.xsite.status.BringSiteOnlineResponse
 
ALWAYS_REMOVE - Enum constant in enum class 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.
alwaysTrue() - Static method in interface org.infinispan.commons.configuration.attributes.AttributeMatcher
 
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
 
annotation() - Method in class org.infinispan.persistence.jdbc.common.configuration.CDIConnectionFactoryConfiguration
 
ANNOTATION - Enum constant in enum class org.infinispan.persistence.jdbc.common.configuration.Attribute
 
ANNOTATION - Static variable in class org.infinispan.persistence.jdbc.common.configuration.CDIConnectionFactoryConfiguration
 
annotationValueReadHandleFactory() - Method in class org.infinispan.search.mapper.model.impl.InfinispanBootstrapIntrospector
 
anonymizeSecureCache(AdvancedCache<K, V>) - Static method in class org.infinispan.security.actions.SecurityActions
 
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
 
ANONYMOUS - Static variable in class org.infinispan.server.memcached.MemcachedBaseDecoder
 
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 - Enum constant in enum class org.infinispan.server.memcached.text.TextCommand
 
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(BinaryHeader, byte[], byte[], boolean) - Method in class org.infinispan.server.memcached.binary.BinaryOpDecoderImpl
 
APPEND - Class in org.infinispan.server.resp.commands.string
APPEND
APPEND - Enum constant in enum class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.StackCombine
 
APPEND - Enum constant in enum class org.infinispan.server.memcached.binary.BinaryCommand
 
APPEND() - Constructor for class org.infinispan.server.resp.commands.string.APPEND
 
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
 
APPENDQ - Enum constant in enum class org.infinispan.server.memcached.binary.BinaryCommand
 
APPLICATION_GZIP - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_GZIP_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_INFINISPAN_BINARY - Static variable in class org.infinispan.commons.dataconversion.MediaType
Deprecated, for removal: This API element is subject to removal in a future version.
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, for removal: This API element is subject to removal in a future version.
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, for removal: This API element is subject to removal in a future version.
Since 11.0, will be removed with ISPN-9622
APPLICATION_INFINISPAN_MARSHALLING - Static variable in class org.infinispan.commons.dataconversion.MediaType
Deprecated, for removal: This API element is subject to removal in a future version.
Since 11.0, will be removed with ISPN-9622
APPLICATION_INFINISPAN_MARSHALLING_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
Deprecated, for removal: This API element is subject to removal in a future version.
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_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_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, for removal: This API element is subject to removal in a future version.
Since 11.0, without replacement.
APPLICATION_UNKNOWN_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
Deprecated, for removal: This API element is subject to removal in a future version.
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
 
APPLIED - Static variable in class org.infinispan.server.resp.commands.generic.EXPIRE
 
apply(double, double) - Method in enum class org.infinispan.multimap.impl.SortedSetBucket.AggregateFunction
 
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(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(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(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
 
argumentMissing(String) - Method in interface org.infinispan.rest.logging.Log
 
ARGUMENTS - Static variable in class org.infinispan.server.resp.commands.sortedset.ZADD
 
ArgumentUtils - Class in org.infinispan.server.resp.commands
Utility class to transform byte[] arguments.
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.
array(Collection<?>, Resp3Type) - Method in class org.infinispan.server.resp.serialization.bytebuf.ByteBufResponseWriter
Serializes a collection in the array format with elements of a specified type.
array(Collection<?>, Resp3Type) - Method in interface org.infinispan.server.resp.serialization.ResponseWriter
 
array(Collection<T>) - Static method in class org.infinispan.commons.dataconversion.internal.Json
 
array(Collection<T>, JavaObjectSerializer<T>) - Method in class org.infinispan.server.resp.serialization.bytebuf.ByteBufResponseWriter
Serializes the collection by delegating the serialization of the elements to the provided serializer.
array(Collection<T>, JavaObjectSerializer<T>) - Method in interface org.infinispan.server.resp.serialization.ResponseWriter
 
ARRAY - Static variable in interface org.infinispan.server.resp.serialization.RespConstants
 
ARRAY_BULK_STRING - Static variable in interface org.infinispan.server.resp.serialization.ResponseWriter
List the consumers for array responses with the different types needed.
ARRAY_DOUBLE - Static variable in interface org.infinispan.server.resp.serialization.ResponseWriter
 
ARRAY_INTEGER - Static variable in interface org.infinispan.server.resp.serialization.ResponseWriter
 
ArrayCollector - Class in org.infinispan.commons.util
 
ArrayCollector(Object[]) - Constructor for class org.infinispan.commons.util.ArrayCollector
 
arrayEmpty() - Method in class org.infinispan.server.resp.serialization.bytebuf.ByteBufResponseWriter
Serializes a collection in the array format.
arrayEmpty() - Method in interface org.infinispan.server.resp.serialization.ResponseWriter
 
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
 
ArrayRingBuffer<T> - Class in org.infinispan.commons.util
It's a growable ring buffer that allows to move tail/head sequences, clear, append, set/replace at specific positions.
ArrayRingBuffer() - Constructor for class org.infinispan.commons.util.ArrayRingBuffer
 
ArrayRingBuffer(int) - Constructor for class org.infinispan.commons.util.ArrayRingBuffer
 
ArrayRingBuffer(int, long) - Constructor for class org.infinispan.commons.util.ArrayRingBuffer
 
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.
Artifact - Interface in org.infinispan.commons.maven
 
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 - Variable in class org.infinispan.multimap.impl.SortableBucket.SortOptions
 
ASC - Enum constant in enum class org.infinispan.query.dsl.SortOrder
Deprecated.
 
ASC - Enum constant in enum class org.infinispan.server.resp.commands.generic.SORT.Arg
 
asChar() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
ascii(byte[]) - Static method in class org.infinispan.server.resp.RespUtil
 
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
 
asScheduler() - Method in interface org.infinispan.util.concurrent.NonBlockingManager
Returns a scheduler to be used with RxJava Flowable.observeOn(Scheduler) method or similar.
asScheduler() - Method in class org.infinispan.util.concurrent.NonBlockingManagerImpl
 
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
 
assertTopologyStable(String) - Method in interface org.infinispan.topology.LocalTopologyManager
Asserts the cache with the given name has a stable topology installed.
assertTopologyStable(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
asSet(T...) - Static method in class org.infinispan.commons.util.Util
 
asShort() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
assignAlias(String, String) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
 
assignAlias(String, String) - Method in interface org.infinispan.client.hotrod.RemoteCacheManagerAdmin
Assign an alias to a cache.
assignAlias(String, String) - Method in interface org.infinispan.commons.api.CacheContainerAdmin
Assign an alias to a cache.
assignAlias(String, String) - Method in class org.infinispan.manager.DefaultCacheManagerAdmin
 
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 class org.infinispan.configuration.cache.BackupConfiguration.BackupStrategy
 
ASYNC - Enum constant in enum class org.infinispan.configuration.parsing.CacheParser.Mode
 
ASYNC - Enum constant in enum class org.infinispan.configuration.parsing.Element
 
ASYNC - Enum constant in enum class org.infinispan.expiration.TouchMode
Send touch commands to other owners, but do not wait for their confirmation.
ASYNC - Enum constant in enum class org.infinispan.functional.Param.ReplicationMode
Invoking node does not know when the owners are updated nor if the command fails.
ASYNC_EXECUTOR - Enum constant in enum class org.infinispan.configuration.parsing.Attribute
Deprecated, for removal: This API element is subject to removal in a future version.
ASYNC_EXECUTOR - Enum constant in enum class org.infinispan.persistence.remote.configuration.Attribute
 
ASYNC_EXECUTOR_FACTORY - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
ASYNC_NOTIFICATION_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
ASYNC_TRANSPORT_EXECUTOR - Enum constant in enum class 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
 
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 class org.infinispan.remoting.rpc.ResponseMode
 
Asynchronous operations - Search tag in interface org.infinispan.Cache
Section
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.BoundedThreadPoolConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.CachedThreadPoolConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.GlobalJmxConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.GlobalMetricsConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.GlobalStatePathConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.GlobalStorageConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.GlobalTracingConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.JGroupsConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.PrincipalRoleMapperConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.RolePermissionMapperConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.ScheduledThreadPoolConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.StackConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.StackFileConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.TemporaryGlobalStatePathConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.ThreadFactoryConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
 
asyncThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
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, for removal: This API element is subject to removal in a future version.
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 class 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 class 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 Class in org.infinispan.configuration.parsing
Enumerates the attributes used in Infinispan
Attribute - Enum Class in org.infinispan.counter.configuration
 
Attribute - Enum Class in org.infinispan.lock.configuration
 
Attribute - Enum Class in org.infinispan.persistence.jdbc.common.configuration
Enumerates the attributes used by the JDBC cache stores configuration
Attribute - Enum Class in org.infinispan.persistence.remote.configuration
Enumerates the attributes used by the Remote cache store configuration
Attribute - Enum Class in org.infinispan.persistence.rocksdb.configuration
Enumerates the attributes used by the LevelDB cache stores configuration
Attribute - Enum Class in org.infinispan.server.core.configuration
 
Attribute - Enum Class in org.infinispan.server.hotrod.configuration
 
ATTRIBUTE - Static variable in class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
 
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.client.hotrod.configuration.ExecutorFactoryConfiguration
 
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.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.CorsRuleConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.rest.configuration.RestAuthenticationConfiguration
 
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.SaslAuthenticationConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.core.configuration.SaslConfiguration
 
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.HotRodServerConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.hotrod.configuration.TopologyCacheConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.memcached.configuration.MemcachedAuthenticationConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.memcached.configuration.MemcachedServerConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.memcached.configuration.TextAuthenticationConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.resp.configuration.RespAuthenticationConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.resp.configuration.RespServerConfiguration
 
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.
AttributeMatcher<T> - Interface in org.infinispan.commons.configuration.attributes
A way to match attributes to works with types without the need to subclass them to add the @Matchable interface.
AttributeMetadata(String, String, boolean, boolean, String, boolean, Function<?, ?>, BiConsumer<?, ?>) - Constructor for class org.infinispan.factories.impl.MBeanMetadata.AttributeMetadata
 
AttributeMetadata(String, String, boolean, boolean, String, boolean, Function<?, ?>, BiConsumer<?, ?>, boolean) - 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.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
Deprecated.
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfiguration
 
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.commons.configuration.Combine
 
attributes() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
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.ContentTypeConfigurationBuilder
 
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.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.IndexShardingConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
 
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.PersistenceConfigurationBuilder
 
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.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 interface org.infinispan.configuration.cache.StoreConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.TracingConfigurationBuilder
 
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.GlobalStorageConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.GlobalTracingConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.GlobalTracingConfigurationBuilder
 
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.CDIConnectionFactoryConfigurationBuilder
 
attributes() - Method in interface org.infinispan.persistence.jdbc.common.configuration.ConnectionFactoryConfiguration
 
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.AuthenticationConfigurationBuilder
 
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.global.RemoteContainerConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.global.RemoteContainersConfigurationBuilder
 
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.RemoteServerConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.TrustStoreConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBExpirationConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.sifs.configuration.DataConfigurationBuilder
 
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.CorsConfigurationBuilder
 
attributes() - Method in class org.infinispan.rest.configuration.CorsRuleConfigurationBuilder
 
attributes() - Method in class org.infinispan.rest.configuration.RestAuthenticationConfigurationBuilder
 
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.NoAuthenticationConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.core.configuration.SaslAuthenticationConfiguration
 
attributes() - Method in class org.infinispan.server.core.configuration.SaslAuthenticationConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.core.configuration.SaslConfigurationBuilder
 
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.HotRodServerConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.hotrod.configuration.TopologyCacheConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.memcached.configuration.MemcachedAuthenticationConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.memcached.configuration.TextAuthenticationConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.resp.configuration.RespAuthenticationConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.resp.configuration.RespServerConfigurationBuilder
 
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.CDIConnectionFactoryConfiguration
 
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() - Static method in class org.infinispan.persistence.remote.configuration.global.RemoteContainerConfiguration
 
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 class 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 Class 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 Class in org.infinispan.security
 
auth - Variable in class org.infinispan.server.hotrod.HotRodDecoder
 
auth(byte[]) - Method in class org.infinispan.server.memcached.text.TextAuthDecoder
 
auth(HotRodHeader, String, byte[]) - Method in class org.infinispan.server.hotrod.Authentication
 
AUTH - Class in org.infinispan.server.resp.commands.connection
AUTH
AUTH - Enum constant in enum class org.infinispan.client.hotrod.configuration.SaslQop
 
AUTH - Enum constant in enum class org.infinispan.server.core.configuration.QOP
 
AUTH - Enum constant in enum class org.infinispan.server.hotrod.HotRodOperation
 
AUTH() - Constructor for class org.infinispan.server.resp.commands.connection.AUTH
 
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_CMDS - Static variable in class org.infinispan.server.memcached.MemcachedStats.MemcachedStatsKeys
 
AUTH_CONF - Enum constant in enum class org.infinispan.client.hotrod.configuration.SaslQop
 
AUTH_CONF - Enum constant in enum class org.infinispan.server.core.configuration.QOP
 
AUTH_DIGEST - Enum constant in enum class org.infinispan.persistence.remote.configuration.Element
 
AUTH_ERRORS - Static variable in class org.infinispan.server.memcached.MemcachedStats.MemcachedStatsKeys
 
AUTH_EXTERNAL - Enum constant in enum class org.infinispan.persistence.remote.configuration.Element
 
AUTH_INT - Enum constant in enum class org.infinispan.client.hotrod.configuration.SaslQop
 
AUTH_INT - Enum constant in enum class org.infinispan.server.core.configuration.QOP
 
AUTH_MECH_LIST - Enum constant in enum class 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 class 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, char[]) - Method in interface org.infinispan.server.core.security.UsernamePasswordAuthenticator
Performs authentication using the supplied credentials and returns the authenticated Subject
authenticate(String, String) - Method in interface org.infinispan.rest.authentication.SecurityDomain
Returns Subject based on user/password combination.
authentication - Variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
 
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.core.configuration.AbstractProtocolServerConfigurationChildBuilder
 
authentication() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
 
authentication() - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
 
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() - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
 
authentication() - Method in class org.infinispan.server.resp.configuration.RespServerConfiguration
 
authentication() - Method in class org.infinispan.server.resp.configuration.RespServerConfigurationBuilder
 
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 class org.infinispan.persistence.remote.configuration.Element
 
AUTHENTICATION - Enum constant in enum class org.infinispan.server.core.configuration.Element
 
AUTHENTICATION - Enum constant in enum class 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 - Interface in org.infinispan.server.core.configuration
 
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<A> - Interface in org.infinispan.server.core.configuration
 
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
 
authenticationWithoutAuthenticator() - Method in interface org.infinispan.server.resp.logging.Log
 
authenticator() - Method in class org.infinispan.rest.configuration.RestAuthenticationConfiguration
 
authenticator() - Method in class org.infinispan.server.core.configuration.SaslConfiguration
 
authenticator() - Method in class org.infinispan.server.memcached.configuration.TextAuthenticationConfiguration
 
authenticator() - Method in class org.infinispan.server.resp.configuration.RespAuthenticationConfiguration
 
authenticator(RestAuthenticator) - Method in class org.infinispan.rest.configuration.RestAuthenticationConfigurationBuilder
 
authenticator(SaslAuthenticator) - Method in class org.infinispan.server.core.configuration.SaslConfigurationBuilder
 
authenticator(UsernamePasswordAuthenticator) - Method in class org.infinispan.server.memcached.configuration.TextAuthenticationConfigurationBuilder
 
authenticator(RespAuthenticator) - Method in class org.infinispan.server.resp.configuration.RespAuthenticationConfigurationBuilder
 
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
 
AUTHN_CONTINUE - Enum constant in enum class org.infinispan.server.memcached.MemcachedStatus
 
AUTHN_ERROR - Enum constant in enum class org.infinispan.server.memcached.MemcachedStatus
 
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 class org.infinispan.configuration.parsing.Element
 
AUTHORIZATION - Enum constant in enum class 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 thread, 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 Class 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.sasl
AuthorizingCallbackHandler.
AuthResp3Command - Interface in org.infinispan.server.resp.commands
 
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 class org.infinispan.configuration.cache.IndexingMode
All the changes to the cache will be immediately applied to the indexes.
AUTO - Enum constant in enum class 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 class org.infinispan.configuration.cache.XSiteStateTransferMode
Cross-site state transfer is triggered automatically.
AUTO - Enum constant in enum class org.infinispan.server.memcached.configuration.MemcachedProtocol
 
AUTO_COMMIT - Enum constant in enum class org.infinispan.configuration.parsing.Attribute
 
AUTO_COMMIT - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
 
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.
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, boolean) - Constructor for class org.infinispan.xsite.response.AutoStateTransferResponseCollector
 
AVAILABILITY_INTERVAL - Enum constant in enum class 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 Class 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 class org.infinispan.partitionhandling.AvailabilityException
 
AvailabilityException(String) - Constructor for exception class org.infinispan.partitionhandling.AvailabilityException
 
AvailabilityException(String, Throwable) - Constructor for exception class org.infinispan.partitionhandling.AvailabilityException
 
AvailabilityException(Throwable) - Constructor for exception class org.infinispan.partitionhandling.AvailabilityException
 
availabilityInterval() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
 
availabilityInterval(int) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
availabilityInterval(String) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
AvailabilityMode - Enum Class 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 class org.infinispan.marshall.core.AbstractBytesObjectInput
 
AVAILABLE - Enum constant in enum class 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 class org.infinispan.lock.configuration.Reliability
 
AVAILABLE - Enum constant in enum class org.infinispan.partitionhandling.AvailabilityMode
Regular operation mode
availableCapacityWithoutResizing() - Method in class org.infinispan.commons.util.ArrayRingBuffer
 
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.commons.util.concurrent.CompletionStages
 
await(CompletionStage<T>, long) - Static method in class org.infinispan.client.hotrod.impl.Util
 
AWAIT_INITIAL_RETRIEVAL - Enum constant in enum class org.infinispan.server.hotrod.configuration.Attribute
 
AWAIT_INITIAL_TRANSFER - Enum constant in enum class 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
 
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

B - Enum constant in enum class org.infinispan.commons.util.ByteQuantity.Unit
 
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.
backtrack(byte[], byte[]) - Method in class org.infinispan.server.resp.operation.LCSOperation.LCSOperationContext
 
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 class org.infinispan.configuration.parsing.Element
 
BACKUP - Enum constant in enum class org.infinispan.distribution.Ownership
this node is the backup owner.
BACKUP_FAILURE_POLICY - Enum constant in enum class org.infinispan.configuration.parsing.Attribute
 
BACKUP_FOR - Enum constant in enum class org.infinispan.configuration.parsing.Element
 
BACKUP_WRITE - Enum constant in enum class 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, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
Acknowledges a PutMapCommand completion in the backup owner.
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 Class in org.infinispan.configuration.cache
 
BackupConfigurationBuilder - Class in org.infinispan.configuration.cache
 
BackupConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
backupCreated(String) - Method in class org.infinispan.server.core.logging.Messages_$bundle
 
backupCreated(String) - Method in interface org.infinispan.server.core.logging.Messages
 
backupCreated$str() - Method in class org.infinispan.server.core.logging.Messages_$bundle
 
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 Class 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 Class in org.infinispan.server.core
 
BackupManager.Status - Enum Class in org.infinispan.server.core
An enum representing the current state of a Backup operation.
BackupManagerImpl - Class in org.infinispan.server.core.backup
 
BackupManagerImpl(EventLogger, 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
 
backupRemotely(XSiteBackup, XSiteRequest<O>) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
backupRemotely(XSiteBackup, XSiteRequest<O>) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
backupRemotely(XSiteBackup, XSiteRequest<O>) - Method in interface org.infinispan.remoting.transport.Transport
Sends a cross-site request to a remote site.
backupRemoved(String) - Method in class org.infinispan.server.core.logging.Messages_$bundle
 
backupRemoved(String) - Method in interface org.infinispan.server.core.logging.Messages
 
backupRemoved$str() - Method in class org.infinispan.server.core.logging.Messages_$bundle
 
BackupResponse - Interface in org.infinispan.remoting.transport
Represents a response from a backup replication call.
backupRestored(String) - Method in class org.infinispan.server.core.logging.Messages_$bundle
 
backupRestored(String) - Method in interface org.infinispan.server.core.logging.Messages
 
backupRestored$str() - Method in class org.infinispan.server.core.logging.Messages_$bundle
 
backups() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
BACKUPS - Enum constant in enum class org.infinispan.configuration.parsing.Element
 
BALANCING_STRATEGY - Enum constant in enum class 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 class 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, InfinispanTelemetry) - Constructor for class org.infinispan.rest.resources.BaseCacheResource
 
BaseCacheStream<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
 
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
 
BaseIterationCommand - Class in org.infinispan.server.resp.commands.iteration
 
BaseIterationCommand(int, int, int, int) - Constructor for class org.infinispan.server.resp.commands.iteration.BaseIterationCommand
 
BaseJdbcStore<K,V,C> - 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
 
BaseRespDecoder - Class in org.infinispan.server.resp
 
BaseRespDecoder() - Constructor for class org.infinispan.server.resp.BaseRespDecoder
 
BaseServerManagement - Class in org.infinispan.server.core
 
BaseServerManagement() - Constructor for class org.infinispan.server.core.BaseServerManagement
 
BaseSetBucket<E> - Interface in org.infinispan.multimap.impl
Implements base functionalities shared by set-like data structures.
BaseSetBucket.SetUtil - Class in org.infinispan.multimap.impl
 
baseStream(AdvancedCache, IterationInitializationContext) - Method in class org.infinispan.server.iteration.DefaultIterationManager
 
baseStream(AdvancedCache, IterationInitializationContext) - Method in class org.infinispan.server.iteration.ExternalSourceIterationManager
 
BaseTableOperations<K,V> - Class in org.infinispan.persistence.jdbc.common.sql
 
BaseTableOperations(AbstractJdbcStoreConfiguration<?>) - 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> - 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 class 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.commons.api.multimap
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 class org.infinispan.configuration.parsing.CacheParser.TransactionMode
 
BATCH_SIZE - Enum constant in enum class 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.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.client.hotrod.impl.RemoteCacheImpl
 
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, for removal: This API element is subject to removal in a future version.
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
Deprecated, for removal: This API element is subject to removal in a future version.
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 - Enum constant in enum class org.infinispan.configuration.parsing.Attribute
 
BEFORE - Enum constant in enum class org.infinispan.container.versioning.InequalVersionComparisonResult
Denotes a version that was created temporally before another version.
BEFORE - Static variable in class org.infinispan.server.resp.commands.list.LINSERT
 
beforeCompletion() - Method in class org.infinispan.transaction.synchronization.SynchronizationAdapter
 
beforeCompletion(LocalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
 
begin() - Method in class org.infinispan.commons.tx.TransactionManagerImpl
 
begin() - Method in class org.infinispan.transaction.tm.EmbeddedUserTransaction
 
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 class org.infinispan.configuration.parsing.Attribute
 
BIAS_LIFESPAN - Enum constant in enum class org.infinispan.configuration.parsing.Attribute
 
BIAS_REVOCATION_RESPONSE - Static variable in interface org.infinispan.commons.marshall.Ids
 
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
 
BIG_NUMBER - Static variable in interface org.infinispan.server.resp.serialization.RespConstants
 
BINARY - Enum constant in enum class org.infinispan.configuration.cache.StorageType
Deprecated, for removal: This API element is subject to removal in a future version.
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 class org.infinispan.configuration.parsing.Element
 
BINARY - Enum constant in enum class org.infinispan.server.memcached.configuration.MemcachedProtocol
 
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 class org.infinispan.persistence.jdbc.common.configuration.Element
 
BinaryAuthDecoderImpl - Class in org.infinispan.server.memcached.binary
 
BinaryAuthDecoderImpl(MemcachedServer) - Constructor for class org.infinispan.server.memcached.binary.BinaryAuthDecoderImpl
 
BinaryCommand - Enum Class in org.infinispan.server.memcached.binary
 
BinaryConstants - Interface in org.infinispan.server.memcached.binary
Memcache binary protocol constants.
BinaryHeader - Class in org.infinispan.server.memcached.binary
 
BinaryIntrinsics - Class in org.infinispan.server.memcached.binary
 
BinaryIntrinsics() - Constructor for class org.infinispan.server.memcached.binary.BinaryIntrinsics
 
BinaryOpDecoderImpl - Class in org.infinispan.server.memcached.binary
 
BinaryOpDecoderImpl(MemcachedServer) - Constructor for class org.infinispan.server.memcached.binary.BinaryOpDecoderImpl
 
BinaryOpDecoderImpl(MemcachedServer, Subject) - Constructor for class org.infinispan.server.memcached.binary.BinaryOpDecoderImpl
 
binaryParam() - Method in interface org.infinispan.filter.ParamKeyValueFilterConverterFactory
 
binaryParam() - Method in class org.infinispan.server.resp.filter.ComposedFilterConverterFactory
 
binaryParam() - Method in class org.infinispan.server.resp.filter.GlobMatchFilterConverterFactory
 
binaryParam() - Method in class org.infinispan.server.resp.filter.RespTypeFilterConverterFactory
 
BinaryResponse - Class in org.infinispan.server.memcached.binary
 
BinaryResponse(Throwable, Header) - Constructor for class org.infinispan.server.memcached.binary.BinaryResponse
 
BinaryResponse(CompletionStage<?>, Header, GenericFutureListener<? extends Future<? super Void>>) - Constructor for class org.infinispan.server.memcached.binary.BinaryResponse
 
BinaryTranscoder - Class in org.infinispan.commons.dataconversion
Deprecated, for removal: This API element is subject to removal in a future version.
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 class org.infinispan.server.hotrod.tx.ControlByte
 
BITMAP - Static variable in class org.infinispan.server.resp.AclCategory
 
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
 
BITSET - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
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
 
bitsToUse() - Method in class org.infinispan.distribution.ch.impl.HashFunctionPartitioner
 
bitsToUse() - Method in class org.infinispan.distribution.ch.impl.RESPHashFunctionPartitioner
 
BLMPOP - Class in org.infinispan.server.resp.commands.list.blocking
BLMPOP
BLMPOP() - Constructor for class org.infinispan.server.resp.commands.list.blocking.BLMPOP
 
BLOCK_SIZE - Enum constant in enum class org.infinispan.persistence.rocksdb.configuration.Attribute
 
BlockHoundUtil - Class in org.infinispan.commons.internal
 
BlockHoundUtil() - Constructor for class org.infinispan.commons.internal.BlockHoundUtil
 
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 - Static variable in class org.infinispan.server.resp.AclCategory
 
BLOCKING_BOUNDED_QUEUE_THREAD_POOL - Enum constant in enum class org.infinispan.configuration.parsing.Element
 
BLOCKING_EXECUTOR - Enum constant in enum class org.infinispan.configuration.parsing.Attribute
 
BLOCKING_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
BLOCKING_GROUP - Static variable in interface org.infinispan.commons.ThreadGroups
 
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.CacheResource
 
blockingManager - Variable in class org.infinispan.server.core.backup.resources.CounterResource
 
blockingManager - Variable in class org.infinispan.server.resp.Resp3Handler
 
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.
BlockingManager.ScheduledBlockingCompletableStage<V> - Interface in org.infinispan.util.concurrent
 
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(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
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.CachedThreadPoolConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.GlobalJmxConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.GlobalMetricsConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.GlobalStatePathConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.GlobalStorageConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.GlobalTracingConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.JGroupsConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.PrincipalRoleMapperConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.RolePermissionMapperConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.ScheduledThreadPoolConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.StackConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.StackFileConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.TemporaryGlobalStatePathConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.ThreadFactoryConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
 
blockingThreadPool() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
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, for removal: This API element is subject to removal in a future version.
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(int) - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
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
 
BLPOP - Class in org.infinispan.server.resp.commands.list.blocking
BLPOP
BLPOP() - Constructor for class org.infinispan.server.resp.commands.list.blocking.BLPOP
 
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 class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.ProtostreamFieldType
 
Boolean(boolean) - Constructor for class org.infinispan.commons.util.ByRef.Boolean
 
BOOLEAN - Static variable in interface org.infinispan.server.resp.serialization.RespConstants
 
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
 
booleans(boolean) - Method in class org.infinispan.server.resp.serialization.bytebuf.ByteBufResponseWriter
Serializes a boolean value in the RESP3 format.
booleans(boolean) - Method in interface org.infinispan.server.resp.serialization.ResponseWriter
 
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 class org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
 
BOTH - Enum constant in enum class org.infinispan.notifications.Listener.Observation
Observation level used to be notified of an operation before and after it occurs
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
 
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 Class in org.infinispan.xsite.status
broadcastShutdownCache(String) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
BROUGHT_ONLINE - Enum constant in enum class org.infinispan.xsite.status.BringSiteOnlineResponse
 
BRPOP - Class in org.infinispan.server.resp.commands.list.blocking
BRPOP
BRPOP() - Constructor for class org.infinispan.server.resp.commands.list.blocking.BRPOP
 
bucket() - Method in record class org.infinispan.multimap.impl.HashMapBucket.HashMapBucketResponse
Returns the value of the bucket record component.
bucket() - Method in record class org.infinispan.multimap.impl.ListBucket.ListBucketResult
Returns the value of the bucket record component.
bucket() - Method in record class org.infinispan.multimap.impl.SetBucket.SetBucketResult
Returns the value of the bucket record component.
bucket() - Method in record class org.infinispan.multimap.impl.SortedSetBucket.SortedSetResult
Returns the value of the bucket record component.
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
 
BucketEntry$___Marshaller_c86ba4e6b19c49a76e97b0093c9e8a28003105d719cd619aede81b86e1b15f81 - Class in org.infinispan.multimap.impl
WARNING: Generated code! Do not edit!
BucketEntry$___Marshaller_c86ba4e6b19c49a76e97b0093c9e8a28003105d719cd619aede81b86e1b15f81() - Constructor for class org.infinispan.multimap.impl.BucketEntry$___Marshaller_c86ba4e6b19c49a76e97b0093c9e8a28003105d719cd619aede81b86e1b15f81
 
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.client.hotrod.metrics.micrometer.MicrometerRemoteCacheManagerMetricsRegistry.Builder
Create a new MicrometerRemoteCacheManagerMetricsRegistry with this configuration.
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.commons.util.SslContextFactory
 
build() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationChildBuilder
 
build() - Method in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.AbstractPersistenceConfigurationChildBuilder
 
build() - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
build() - Method in class org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.remote.configuration.AbstractSecurityConfigurationChildBuilder
 
build() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
 
build() - Method in class org.infinispan.configuration.cache.AbstractTransportConfigurationChildBuilder
 
build() - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
build() - Method in class org.infinispan.persistence.jdbc.common.configuration.CDIConnectionFactoryConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
 
build() - Method in class org.infinispan.security.impl.CreatePermissionConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.CustomStoreConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.IndexReaderConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.IndexShardingConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder.StringTableManipulationConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.jdbc.common.configuration.