Index

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

A

ABORT_RATE - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
 
ABORTED - Enum constant in enum org.infinispan.transaction.impl.TransactionTable.CompletedTransactionStatus
 
AbstractApplicationPublisherBridge - Class in org.infinispan.spring.common.session
A bridge for passing events between Infinispan (both embedded and remote) and Spring.
AbstractApplicationPublisherBridge(SpringCache) - Constructor for class org.infinispan.spring.common.session.AbstractApplicationPublisherBridge
 
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
 
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.
AbstractCustomInterceptorsConfigurationChildBuilder - Class in org.infinispan.configuration.cache
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
AbstractCustomInterceptorsConfigurationChildBuilder(CustomInterceptorsConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractCustomInterceptorsConfigurationChildBuilder
Deprecated.
 
AbstractDelegatingAdvancedCache<K,V> - Class in org.infinispan.cache.impl
AbstractDelegatingAdvancedCache(AdvancedCache<K, V>) - Constructor for class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
AbstractDelegatingCache<K,V> - Class in org.infinispan.cache.impl
This is a convenient base class for implementing a cache delegate.
AbstractDelegatingCache(Cache<K, V>) - Constructor for class org.infinispan.cache.impl.AbstractDelegatingCache
 
AbstractDelegatingCacheStream<R> - Class in org.infinispan.util
Delegate that forwards all the of the method calls to the underlying cache stream.
AbstractDelegatingCacheStream(CacheStream<R>) - Constructor for class org.infinispan.util.AbstractDelegatingCacheStream
 
AbstractDelegatingCollection<E> - Class in org.infinispan.commons.util
Delegating collection that delegates all calls to the collection returned from AbstractDelegatingCollection.delegate()
AbstractDelegatingCollection() - Constructor for class org.infinispan.commons.util.AbstractDelegatingCollection
 
AbstractDelegatingConcurrentMap<K,V> - Class in org.infinispan.commons.util
 
AbstractDelegatingConcurrentMap() - Constructor for class org.infinispan.commons.util.AbstractDelegatingConcurrentMap
 
AbstractDelegatingEmbeddedCacheManager - Class in org.infinispan.manager.impl
This is a convenient base class for implementing a cache manager delegate.
AbstractDelegatingEmbeddedCacheManager(EmbeddedCacheManager) - Constructor for class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
AbstractDelegatingInternalDataContainer<K,V> - Class in org.infinispan.container.impl
Delegating data container that delegates all calls to the container returned from AbstractDelegatingInternalDataContainer.delegate()
AbstractDelegatingInternalDataContainer() - Constructor for class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
AbstractDelegatingMap<K,V> - Class in org.infinispan.commons.util
 
AbstractDelegatingMap() - Constructor for class org.infinispan.commons.util.AbstractDelegatingMap
 
AbstractDelegatingSet<E> - Class in org.infinispan.commons.util
 
AbstractDelegatingSet() - Constructor for class org.infinispan.commons.util.AbstractDelegatingSet
 
AbstractDelegatingTransport - Class in org.infinispan.remoting.transport
Designed to be overwrite.
AbstractDelegatingTransport(Transport) - Constructor for class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
AbstractEmbeddedCacheManagerFactory - Class in org.infinispan.spring.embedded
An abstract base class for factories creating cache managers that are backed by an EmbeddedCacheManager.
AbstractEmbeddedCacheManagerFactory() - Constructor for class org.infinispan.spring.embedded.AbstractEmbeddedCacheManagerFactory
 
AbstractEnlistmentAdapter - Class in org.infinispan.transaction.impl
Base class for both Sync and XAResource enlistment adapters.
AbstractEnlistmentAdapter() - Constructor for class org.infinispan.transaction.impl.AbstractEnlistmentAdapter
 
AbstractEnlistmentAdapter(CacheTransaction) - Constructor for class org.infinispan.transaction.impl.AbstractEnlistmentAdapter
 
AbstractEntrySizeCalculatorHelper<K,V> - Class in org.infinispan.commons.util
Abstract class that provides a method to round up to the nearest value of 8 which is important for most jvm when doing size calculations.
AbstractEntrySizeCalculatorHelper() - Constructor for class org.infinispan.commons.util.AbstractEntrySizeCalculatorHelper
 
AbstractExternalizer<T> - Class in org.infinispan.commons.marshall
Base class for AdvancedExternalizer implementations that offers default implementations for some of its methods.
AbstractExternalizer() - Constructor for class org.infinispan.commons.marshall.AbstractExternalizer
 
AbstractFileLookup - Class in org.infinispan.commons.util
 
AbstractFileLookup() - Constructor for class org.infinispan.commons.util.AbstractFileLookup
 
AbstractFlagAffectedCommand - Class in org.infinispan.commands
Base class for those commands that can carry flags.
AbstractFlagAffectedCommand() - Constructor for class org.infinispan.commands.AbstractFlagAffectedCommand
 
AbstractHotRodServerChildConfigurationBuilder - Class in org.infinispan.server.hotrod.configuration
AbstractHotRodServerChildConfigurationBuilder.
AbstractHotRodServerChildConfigurationBuilder(HotRodServerChildConfigurationBuilder) - Constructor for class org.infinispan.server.hotrod.configuration.AbstractHotRodServerChildConfigurationBuilder
 
AbstractInfinispanSessionRepository - Class in org.infinispan.spring.common.session
Infinispan implementation for Spring Session with basic functionality.
AbstractInfinispanSessionRepository(SpringCache, AbstractApplicationPublisherBridge) - Constructor for class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository
 
AbstractInfinispanSessionRepository.InfinispanSession - Class in org.infinispan.spring.common.session
A custom implementation of Session that uses a MapSession as the basis for its mapping.
AbstractInternalCacheEntry - Class in org.infinispan.container.entries
An abstract internal cache entry that is typically stored in the data container
AbstractInternalCacheEntry(Object, Object, PrivateMetadata) - Constructor for class org.infinispan.container.entries.AbstractInternalCacheEntry
 
AbstractInternalDataContainer<K,V> - Class in org.infinispan.container.impl
Abstract class implemenation for a segmented data container.
AbstractInternalDataContainer() - Constructor for class org.infinispan.container.impl.AbstractInternalDataContainer
 
AbstractInternalDataContainer.EntryIterator - Class in org.infinispan.container.impl
 
AbstractInvocationBuilder() - Constructor for class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
AbstractInvocationContext - Class in org.infinispan.context.impl
Common features of transaction and invocation contexts
AbstractInvocationContext(Address) - Constructor for class org.infinispan.context.impl.AbstractInvocationContext
 
AbstractInvocationContextFactory - Class in org.infinispan.context.impl
Base class for InvocationContextFactory implementations.
AbstractInvocationContextFactory() - Constructor for class org.infinispan.context.impl.AbstractInvocationContextFactory
 
AbstractIterator<E> - Class in org.infinispan.commons.util
Abstract iterator that allows overriding just the AbstractIterator.getNext() method to implement it.
AbstractIterator() - Constructor for class org.infinispan.commons.util.AbstractIterator
 
AbstractJBossMarshaller - Class in org.infinispan.jboss.marshalling.commons
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 - Class in org.infinispan.persistence.jdbc.common.configuration
 
AbstractJdbcStoreConfiguration(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> - Class in org.infinispan.server.core.configuration
Helper
AbstractProtocolServerConfigurationChildBuilder(ProtocolServerConfigurationChildBuilder<T, S>) - Constructor for class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
 
AbstractRemoteCacheManagerFactory - Class in org.infinispan.spring.remote
An abstract base class for factories creating cache manager that are backed by an Infinispan RemoteCacheManager.
AbstractRemoteCacheManagerFactory() - Constructor for class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
 
AbstractRemoteStoreConfigurationChildBuilder<S> - Class in org.infinispan.persistence.remote.configuration
AbstractRemoteStoreConfigurationChildBuilder.
AbstractRemoteStoreConfigurationChildBuilder(RemoteStoreConfigurationBuilder, AttributeSet) - Constructor for class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
AbstractRequest<T> - Class in org.infinispan.remoting.transport
A remote invocation request.
AbstractRequest(long, ResponseCollector<T>, RequestRepository) - Constructor for class org.infinispan.remoting.transport.AbstractRequest
 
AbstractSchemaJdbcConfiguration - Class in org.infinispan.persistence.sql.configuration
 
AbstractSchemaJdbcConfiguration(AttributeSet, AsyncStoreConfiguration, ConnectionFactoryConfiguration, SchemaJdbcConfiguration) - Constructor for class org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfiguration
 
AbstractSchemaJdbcConfigurationBuilder<T,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 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(AttributeSet, AsyncStoreConfiguration) - Constructor for class org.infinispan.configuration.cache.AbstractSegmentedStoreConfiguration
 
AbstractSiteStatusBuilder<E> - Class in org.infinispan.xsite.status
A SiteStatus builder based on its online and offline members.
AbstractSiteStatusBuilder() - Constructor for class org.infinispan.xsite.status.AbstractSiteStatusBuilder
 
AbstractStoreConfiguration - Class in org.infinispan.configuration.cache
 
AbstractStoreConfiguration(AttributeSet, AsyncStoreConfiguration) - Constructor for class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
AbstractStoreConfigurationBuilder<T,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
 
AbstractTransport - Class in org.infinispan.remoting.transport
Deprecated, for removal: This API element is subject to removal in a future version.
Since 9.1, please implement Transport directly.
AbstractTransport() - Constructor for class org.infinispan.remoting.transport.AbstractTransport
Deprecated.
 
AbstractTransportConfigurationChildBuilder - Class in org.infinispan.configuration.cache
 
AbstractTransportConfigurationChildBuilder(TransactionConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractTransportConfigurationChildBuilder
 
AbstractTxInvocationContext<T> - Class in org.infinispan.context.impl
Support class for TxInvocationContext.
AbstractTxInvocationContext(T, Address) - Constructor for class org.infinispan.context.impl.AbstractTxInvocationContext
 
AbstractTypedPropertiesConfiguration - Class in org.infinispan.commons.configuration
 
AbstractTypedPropertiesConfiguration(Properties) - Constructor for class org.infinispan.commons.configuration.AbstractTypedPropertiesConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
AbstractTypedPropertiesConfiguration(AttributeSet) - Constructor for class org.infinispan.commons.configuration.AbstractTypedPropertiesConfiguration
 
AbstractUnmanagedConnectionFactoryConfiguration - Class in org.infinispan.persistence.jdbc.common.configuration
 
AbstractUnmanagedConnectionFactoryConfiguration(AttributeSet) - Constructor for class org.infinispan.persistence.jdbc.common.configuration.AbstractUnmanagedConnectionFactoryConfiguration
 
AbstractVisitor - Class in org.infinispan.commands
An abstract implementation of a Visitor that delegates all visit calls to a default handler which can be overridden.
AbstractVisitor() - Constructor for class org.infinispan.commands.AbstractVisitor
 
accept(long) - Method in class org.infinispan.commons.reactive.AbstractAsyncPublisherHandler
This method is invoked every time a new request is sent to the underlying publisher.
accept(long) - Method in class org.infinispan.reactive.publisher.impl.InnerPublisherSubscription
This method is invoked every time a new request is sent to the underlying publisher.
accept(Object, Object, Metadata) - Method in class org.infinispan.filter.AcceptAllKeyValueFilter
 
accept(Object, Object, Metadata, Object, Metadata, EventType) - Method in class org.infinispan.persistence.remote.upgrade.RemovedFilter
 
accept(Object, Throwable) - Method in interface org.infinispan.scattered.BiasManager.Revocation
 
accept(Void) - Method in class org.infinispan.client.hotrod.event.impl.ReconnectTask
 
accept(InetSocketAddress) - Method in class org.infinispan.server.core.transport.AccessControlFilter
 
accept(Supplier<PrimitiveIterator.OfInt>) - Method in interface org.infinispan.BaseCacheStream.SegmentCompletionListener
Invoked each time a given number of segments have completed and the terminal operation has consumed all entries in the given segment
accept(K, V, Metadata) - Method in class org.infinispan.filter.AbstractKeyValueFilterConverter
 
accept(K, V, Metadata) - Method in class org.infinispan.filter.CompositeKeyValueFilter
 
accept(K, V, Metadata) - Method in interface org.infinispan.filter.KeyValueFilter
 
accept(K, V, Metadata) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterAsKeyValueFilter
 
accept(K, V, Metadata, V, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.AbstractCacheEventFilterConverter
 
accept(K, V, Metadata, V, Metadata, EventType) - Method in interface org.infinispan.notifications.cachelistener.filter.CacheEventFilter
Whether or not this event should be raised to the listener it is attached to.
accept(K, V, Metadata, V, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.CompositeCacheEventFilter
 
accept(K, V, Metadata, V, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterAsCacheEventFilter
 
accept(K, V, Metadata, V, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter
 
accept(K, V, Metadata, V, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.PostCacheEventFilter
 
accept(InvocationContext, C, Object) - Method in interface org.infinispan.interceptors.InvocationSuccessAction
Process the result from a successful invocation stage and possibly throw an exception.
accept(InvocationContext, C, Object, Throwable) - Method in interface org.infinispan.interceptors.InvocationFinallyAction
Process the result or the exception from an invocation stage and possibly throw an exception.
accept(ScopedState, Object, Metadata, Object, Metadata, EventType) - Method in class org.infinispan.globalstate.ScopeFilter
 
accept(EmbeddedCacheManager, Cache<K, V>) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerReplicateCallable
 
accept(LogAppender.WriteOperation) - Method in class org.infinispan.persistence.sifs.LogAppender
 
accept(ValidResponse, Throwable) - Method in class org.infinispan.remoting.transport.impl.XSiteResponseImpl
 
accept(T, 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, U, V) - Method in interface org.infinispan.util.function.TriConsumer
Performs this operation on the given arguments.
ACCEPT_ALL_KEY_VALUE_FILTER - Static variable in interface org.infinispan.commons.marshall.Ids
 
ACCEPT_HEADER - Enum constant in enum org.infinispan.rest.RequestHeader
 
AcceptAllKeyValueFilter - Class in org.infinispan.filter
A key value filter that accepts all entries found.
AcceptAllKeyValueFilter.Externalizer - Class in org.infinispan.filter
 
acceptResponse(ByteBuf, short, HeaderDecoder) - Method in class org.infinispan.client.hotrod.counter.operation.AddListenerOperation
 
acceptResponse(ByteBuf, short, HeaderDecoder) - Method in class org.infinispan.client.hotrod.counter.operation.AddOperation
 
acceptResponse(ByteBuf, short, HeaderDecoder) - Method in class org.infinispan.client.hotrod.counter.operation.CompareAndSwapOperation
 
acceptResponse(ByteBuf, short, HeaderDecoder) - Method in class org.infinispan.client.hotrod.counter.operation.DefineCounterOperation
 
acceptResponse(ByteBuf, short, HeaderDecoder) - Method in class org.infinispan.client.hotrod.counter.operation.GetConfigurationOperation
 
acceptResponse(ByteBuf, short, HeaderDecoder) - Method in class org.infinispan.client.hotrod.counter.operation.GetCounterNamesOperation
 
acceptResponse(ByteBuf, short, HeaderDecoder) - Method in class org.infinispan.client.hotrod.counter.operation.GetValueOperation
 
acceptResponse(ByteBuf, short, HeaderDecoder) - Method in class org.infinispan.client.hotrod.counter.operation.IsDefinedOperation
 
acceptResponse(ByteBuf, short, HeaderDecoder) - Method in class org.infinispan.client.hotrod.counter.operation.RemoveListenerOperation
 
acceptResponse(ByteBuf, short, HeaderDecoder) - Method in class org.infinispan.client.hotrod.counter.operation.RemoveOperation
 
acceptResponse(ByteBuf, short, HeaderDecoder) - Method in class org.infinispan.client.hotrod.counter.operation.ResetOperation
 
acceptVisitor(InvocationContext, Visitor) - Method in interface org.infinispan.commands.VisitableCommand
Accept a visitor, and return the result of accepting this visitor.
acceptVisitor(InvocationContext, Visitor) - Method in class org.infinispan.expiration.impl.TouchCommand
 
ACCESS - Enum constant in enum org.infinispan.persistence.jdbc.common.DatabaseType
 
AccessControlFilter<A> - Class in org.infinispan.server.core.transport
This class provides the functionality to either accept or reject new Channels based on their IP address.
AccessControlFilter(A) - Constructor for class org.infinispan.server.core.transport.AccessControlFilter
 
AccessControlFilter(A, boolean) - Constructor for class org.infinispan.server.core.transport.AccessControlFilter
 
AccessControlFilter.AccessControlFilterEvent - Class in org.infinispan.server.core.transport
 
accessLogging() - Method in class org.infinispan.server.hotrod.HotRodServer
 
AccessLoggingHeader - Class in org.infinispan.server.hotrod
 
AccessLoggingHeader(HotRodHeader, Subject, Object, int, Temporal) - Constructor for class org.infinispan.server.hotrod.AccessLoggingHeader
 
accumulate(BiConsumer<E, E>) - Static method in class org.infinispan.reactive.publisher.PublisherReducers
 
accumulator() - Method in class org.infinispan.commons.dataconversion.internal.JsonArrayCollector
 
accumulator() - Method in class org.infinispan.commons.util.ArrayCollector
 
ACCURATE_SIZE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
ACCURATE_SIZE - Static variable in class org.infinispan.configuration.global.GlobalMetricsConfiguration
 
accurateSize() - Method in class org.infinispan.configuration.global.GlobalMetricsConfiguration
Whether cache sizes should be computed
accurateSize(boolean) - Method in class org.infinispan.configuration.global.GlobalMetricsConfigurationBuilder
Enables accurate size computation for numberOfEntries statistics.
acquire(Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.InfinispanLock
It tries to acquire this lock.
acquire(Object, Object, long, TimeUnit) - Method in interface org.infinispan.util.concurrent.locks.impl.LockContainer
 
acquire(Object, Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.PerKeyLockContainer
 
acquire(Object, Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.StripedLockContainer
 
ACQUIRE_TIMEOUT - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
ACQUIRED - Enum constant in enum org.infinispan.util.concurrent.locks.LockState
The lock owner left the queue and it is available to acquire the lock.
Action - Interface in org.infinispan.remoting.inboundhandler.action
An action represents a step in PerCacheInboundInvocationHandler.
ActionListener - Interface in org.infinispan.remoting.inboundhandler.action
A listener that is invoked when an Action is completed.
ActionSequencer - Class in org.infinispan.util.concurrent
Orders multiple actions/tasks based on a key.
ActionSequencer(Executor, boolean, TimeService) - Constructor for class org.infinispan.util.concurrent.ActionSequencer
 
ActionState - Class in org.infinispan.remoting.inboundhandler.action
The state used by an Action.
ActionState(ReplicableCommand, int) - Constructor for class org.infinispan.remoting.inboundhandler.action.ActionState
 
ActionStatus - Enum in org.infinispan.remoting.inboundhandler.action
The status for an Action.
activateAsync(Object, int) - Method in interface org.infinispan.eviction.impl.ActivationManager
Activates an entry, effectively removing it from the underlying persistence store.
activateAsync(Object, int) - Method in class org.infinispan.eviction.impl.ActivationManagerImpl
 
activateAsync(Object, int) - Method in class org.infinispan.eviction.impl.ActivationManagerStub
 
ActivationManager - Interface in org.infinispan.eviction.impl
Controls activation of cache entries that have been passivated.
ActivationManagerImpl - Class in org.infinispan.eviction.impl
Concrete implementation of activation logic manager.
ActivationManagerImpl() - Constructor for class org.infinispan.eviction.impl.ActivationManagerImpl
 
ActivationManagerStub - Class in org.infinispan.eviction.impl
 
ActivationManagerStub() - Constructor for class org.infinispan.eviction.impl.ActivationManagerStub
 
ACTIVE - Enum constant in enum org.infinispan.server.hotrod.tx.table.Status
The client transaction is being replayed.
activeIterations() - Method in class org.infinispan.server.hotrod.iteration.DefaultIterationManager
 
activeIterations() - Method in interface org.infinispan.server.hotrod.iteration.IterationManager
 
actual - Variable in class org.infinispan.persistence.support.DelegatingCacheLoader
 
actual - Variable in class org.infinispan.persistence.support.DelegatingCacheWriter
 
actual - Variable in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
actual() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
Deprecated.
 
actualCreateTableOperations(AbstractSchemaJdbcStore.ProtoSchemaOptions<K, V, C>) - Method in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore
Implementation specific method to return a table operations which will then be used appropriately for store operations.
actualCreateTableOperations(AbstractSchemaJdbcStore.ProtoSchemaOptions<K, V, QueriesJdbcStoreConfiguration>) - Method in class org.infinispan.persistence.sql.QueriesJdbcStore
 
actualCreateTableOperations(AbstractSchemaJdbcStore.ProtoSchemaOptions<K, V, TableJdbcStoreConfiguration>) - Method in class org.infinispan.persistence.sql.TableJdbcStore
 
AdaptiveBufferSizePredictor - Class in org.infinispan.commons.marshall
The BufferSizePredictor that automatically increases and decreases the predicted buffer size on feed back.
AdaptiveBufferSizePredictor() - Constructor for class org.infinispan.commons.marshall.AdaptiveBufferSizePredictor
Creates a new predictor with the default parameters.
AdaptiveBufferSizePredictor(int, int, int) - Constructor for class org.infinispan.commons.marshall.AdaptiveBufferSizePredictor
Creates a new predictor with the specified parameters.
add() - Static method in class org.infinispan.reactive.publisher.PublisherReducers
 
add(int) - Method in class org.infinispan.commons.util.ImmutableIntSet
 
add(int) - Method in interface org.infinispan.commons.util.IntSet
Adds the given int to this set and returns true if it was set or false if it was already present
add(int) - Method in class org.infinispan.commons.util.RangeSet
Deprecated.
 
add(int) - Method in class org.infinispan.commons.util.SmallIntSet
Deprecated.
Add an integer to the set without boxing the parameter.
add(int, E) - Method in class org.infinispan.commons.util.ForwardingList
 
add(long) - Method in interface org.infinispan.counter.api.SyncWeakCounter
 
add(long) - Method in interface org.infinispan.counter.api.WeakCounter
Adds the given value to the new value.
add(long) - Method in class org.infinispan.counter.impl.SyncWeakCounterAdapter
 
add(E) - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
Adding new cache entries via a set is not allowed.
add(E) - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
 
add(E) - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
 
add(E) - Method in class org.infinispan.commons.util.ForwardingList
 
add(E) - Method in class org.infinispan.commons.util.ImmutableHopscotchHashSet
 
add(E) - Method in class org.infinispan.commons.util.ImmutableListCopy
 
add(E) - Method in class org.infinispan.InternalCacheSet
 
add(Integer) - Method in class org.infinispan.commons.util.ImmutableIntSet
 
add(Integer) - Method in class org.infinispan.commons.util.RangeSet
Deprecated.
 
add(Integer) - Method in class org.infinispan.commons.util.SmallIntSet
Deprecated.
 
add(Object) - Method in class org.infinispan.commons.dataconversion.internal.Json
Add an arbitrary Java object to this Json array.
add(Object) - Method in class org.infinispan.commons.util.ArrayCollector
 
add(Object, String, Object) - Method in class org.infinispan.search.mapper.work.impl.SearchIndexerImpl
 
add(Object, String, Object) - Method in interface org.infinispan.search.mapper.work.SearchIndexer
 
add(Permission) - Method in class org.infinispan.security.CachePermissionCollection
 
add(AtomicLongFieldUpdater<T>, T, long) - Method in class org.infinispan.commons.util.concurrent.StripedCounters
 
add(List<CorsConfig>) - Method in class org.infinispan.rest.configuration.CorsConfigurationBuilder
 
add(List<XidImpl>) - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
 
add(Map.Entry<K, V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySet
 
add(Json) - Method in class org.infinispan.commons.dataconversion.internal.Json
Add the specified Json element to this array.
add(Json) - Method in class org.infinispan.commons.dataconversion.internal.JsonArrayCollector
 
add(CacheEntry<K, V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntrySet
 
add(ExtendedStatistic, double, boolean) - Method in class org.infinispan.extendedstats.container.ConcurrentGlobalContainer
 
add(ExtendedStatistic, double, GlobalTransaction, boolean) - Method in class org.infinispan.extendedstats.CacheStatisticManager
Adds a value to a statistic.
add(Listeners.ReadWriteListeners.ReadWriteListener<K, V>) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
 
add(Listeners.ReadWriteListeners.ReadWriteListener<K, V>) - Method in interface org.infinispan.functional.Listeners.ReadWriteListeners
Add a read-write listener, and return an AutoCloseable instance that can be used to remove the listener registration.
add(Listeners.WriteListeners.WriteListener<K, V>) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
 
add(Listeners.WriteListeners.WriteListener<K, V>) - Method in interface org.infinispan.functional.Listeners.WriteListeners
Add a write-only listener, and return an AutoCloseable instance that can be used to remove the listener registration.
add(MetaParam) - Method in class org.infinispan.functional.impl.MetaParams
 
add(MetaParam<?>) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata.Builder
 
add(Param<?>) - Method in class org.infinispan.functional.impl.Params
 
add(R) - Method in class org.infinispan.util.CollectionMapper
 
add(R) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
 
add(V, boolean) - Method in class org.infinispan.multimap.impl.Bucket
 
ADD_BLOOM_FILTER_CLIENT_LISTENER - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
ADD_BLOOM_FILTER_NEAR_CACHE_LISTENER_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
ADD_CLIENT_LISTENER - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
ADD_CLIENT_LISTENER_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
ADD_REMOTE_STORE - Static variable in interface org.infinispan.persistence.remote.ExternalizerIds
 
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 Integer>) - Method in class org.infinispan.commons.util.ImmutableIntSet
 
addAll(Collection<? extends Integer>) - Method in class org.infinispan.commons.util.RangeSet
Deprecated.
 
addAll(Collection<? extends Integer>) - Method in class org.infinispan.commons.util.SmallIntSet
Deprecated.
 
addAll(Collection<? extends Map.Entry<K, V>>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySet
 
addAll(Collection<? extends CacheEntry<K, V>>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntrySet
 
addAll(Collection<? extends R>) - Method in class org.infinispan.util.CollectionMapper
 
addAll(Collection<? extends R>) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
 
addAll(List<CorsConfig>) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
 
addAll(IntSet) - Method in class org.infinispan.commons.util.ImmutableIntSet
Deprecated.
 
addAll(IntSet) - Method in interface org.infinispan.commons.util.IntSet
Adds all ints from the provided set into this one
addAll(IntSet) - Method in class org.infinispan.commons.util.RangeSet
Deprecated.
 
addAll(IntSet) - Method in class org.infinispan.commons.util.SmallIntSet
Deprecated.
 
addAll(Params) - Method in class org.infinispan.functional.impl.Params
 
addAll(Param<?>...) - Method in class org.infinispan.functional.impl.Params
Adds all parameters and returns a new parameter collection.
addAllAffectedKeys(Collection<?>) - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
addAllAffectedKeys(Collection<?>) - Method in interface org.infinispan.context.impl.TxInvocationContext
Registers a new participant with the transaction.
addAllAffectedKeys(Collection<?>) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
addAllowedMech(String) - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
 
addAllowedMech(String) - Method in class org.infinispan.server.hotrod.configuration.SaslConfigurationBuilder
 
addAndGet(long) - Method in interface org.infinispan.counter.api.StrongCounter
Atomically adds the given value and return the new value.
addAndGet(long) - Method in interface org.infinispan.counter.api.SyncStrongCounter
 
addAndGet(long) - Method in class org.infinispan.counter.impl.SyncStrongCounterAdapter
 
addBackup() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
addBackupLockForKey(Object) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
addBackupLockForKey(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
addBackupOwners(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
 
addBackupOwners(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.TopologyAwareConsistentHashFactory
 
addBoundedThreadPool(String) - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
 
addCache(ByteString, Status) - Method in class org.infinispan.server.hotrod.tx.operation.CommitTransactionOperation
 
addCache(ByteString, Status) - Method in class org.infinispan.server.hotrod.tx.operation.RollbackTransactionOperation
 
addCache(ByteString, Status) - Method in interface org.infinispan.server.hotrod.tx.table.CacheNameCollector
Adds the cache name and the SetDecisionFunction return value.
addCacheConfigurations(String...) - Method in class org.infinispan.server.core.backup.BackupManagerResources.Builder
 
addCacheDependency(String, String) - Method in class org.infinispan.manager.DefaultCacheManager
 
addCacheDependency(String, String) - Method in interface org.infinispan.manager.EmbeddedCacheManager
Add a dependency between two caches.
addCacheDependency(String, String) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
AddCacheDependencyAction - Class in org.infinispan.security.actions
AddCacheDependencyAction.
AddCacheDependencyAction(EmbeddedCacheManager, String, String) - Constructor for class org.infinispan.security.actions.AddCacheDependencyAction
 
addCachedThreadPool(String) - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
 
addCacheEventConverterFactory(String, CacheEventConverterFactory) - Method in class org.infinispan.server.hotrod.HotRodServer
 
addCacheEventFilterConverterFactory(String, CacheEventFilterConverterFactory) - Method in class org.infinispan.server.hotrod.HotRodServer
 
addCacheEventFilterFactory(String, CacheEventFilterFactory) - Method in class org.infinispan.server.hotrod.HotRodServer
 
AddCacheManagerListenerAction - Class in org.infinispan.security.actions
CacheManagerAddListenerAction.
AddCacheManagerListenerAction(EmbeddedCacheManager, Object) - Constructor for class org.infinispan.security.actions.AddCacheManagerListenerAction
 
AddCacheManagerListenerAsyncAction - Class in org.infinispan.security.actions
CacheManagerAddListenerAction.
AddCacheManagerListenerAsyncAction(EmbeddedCacheManager, Object) - Constructor for class org.infinispan.security.actions.AddCacheManagerListenerAsyncAction
 
addCacheName(String, SiteStatus) - Method in class org.infinispan.xsite.status.ContainerSiteStatusBuilder
Adds the cache with the SiteStatus connection to the site.
addCaches(String...) - Method in class org.infinispan.server.core.backup.BackupManagerResources.Builder
 
addCallback(InvocationContext, C, InvocationCallback<C>) - Method in class org.infinispan.interceptors.InvocationStage
After the current stage completes, invoke function and return its result.
addCallback(InvocationContext, C, InvocationCallback<C>) - Method in class org.infinispan.interceptors.SyncInvocationStage
 
addCallback(InvocationContext, VisitableCommand, InvocationCallback) - Method in class org.infinispan.interceptors.ExceptionSyncInvocationStage
 
addChannelListener(ChannelListener) - Method in class org.infinispan.remoting.transport.jgroups.AbstractJGroupsChannelConfigurator
 
addChannelListener(ChannelListener) - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelConfigurator
 
addClass(String) - Method in class org.infinispan.configuration.global.AllowListConfigurationBuilder
Helper method that allows for registration of a class to the ClassAllowList.
addClass(String) - Method in class org.infinispan.configuration.global.WhiteListConfigurationBuilder
Deprecated.
Helper method that allows for registration of a class to the ClassAllowList.
addClasses(Class...) - Method in class org.infinispan.configuration.global.AllowListConfigurationBuilder
Helper method that allows for registration of classes to the ClassAllowList.
addClasses(Class...) - Method in class org.infinispan.configuration.global.WhiteListConfigurationBuilder
Deprecated.
Helper method that allows for registration of classes to the ClassAllowList.
addClasses(Class<?>...) - Method in class org.infinispan.commons.configuration.ClassAllowList
 
addClasses(String...) - Method in class org.infinispan.commons.configuration.ClassAllowList
 
addClasses(String...) - Method in class org.infinispan.configuration.global.AllowListConfigurationBuilder
Helper method that allows for registration of classes to the ClassAllowList.
addClientListener(Object) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
addClientListener(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
addClientListener(Object) - Method in interface org.infinispan.client.hotrod.RemoteCache
Add a client listener to receive events that happen in the remote cache.
addClientListener(Object, Object[], Object[]) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
addClientListener(Object, Object[], Object[]) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
addClientListener(Object, Object[], Object[]) - Method in interface org.infinispan.client.hotrod.RemoteCache
Add a client listener to receive events that happen in the remote cache.
addClientQueryListener(RemoteCache<?, ?>, Object, Query<?>) - Static method in class org.infinispan.client.hotrod.event.ClientEvents
Register a client listener that uses a query DSL based filter.
addCluster(String) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
addCluster(String) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
addCluster(String) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Adds a new remote server cluster
addClusteredLock() - Method in class org.infinispan.lock.configuration.ClusteredLockManagerConfigurationBuilder
 
addClusterLoader() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
Deprecated, 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.query.api.continuous.ContinuousQuery
Add a listener for a continuous query.
addContinuousQueryListener(String, ContinuousQueryListener<K, C>) - Method in class org.infinispan.client.hotrod.event.impl.ContinuousQueryImpl
 
addContinuousQueryListener(String, ContinuousQueryListener<K, C>) - Method in interface org.infinispan.query.api.continuous.ContinuousQuery
Add a listener for a continuous query.
addContinuousQueryListener(Query<?>, ContinuousQueryListener<K, C>) - Method in class org.infinispan.client.hotrod.event.impl.ContinuousQueryImpl
Registers a continuous query listener that uses a query DSL based filter.
addContinuousQueryListener(Query<?>, ContinuousQueryListener<K, C>) - Method in interface org.infinispan.query.api.continuous.ContinuousQuery
Add a listener for a continuous query.
addCounterListener(byte[], byte, String, Channel, VersionedEncoder) - Method in class org.infinispan.server.hotrod.counter.listener.ClientCounterManagerNotificationManager
 
addCounters(String...) - Method in class org.infinispan.server.core.backup.BackupManagerResources.Builder
 
addCustomCacheConfiguration(ConfigurationBuilder) - Method in class org.infinispan.spring.embedded.AbstractEmbeddedCacheManagerFactory
Sets the ConfigurationBuilder to use when creating an EmbeddedCacheManager.
addCustomConfiguration(ConfigurationBuilder) - Method in class org.infinispan.spring.embedded.support.InfinispanNamedEmbeddedCacheFactoryBean
API to introduce a customised ConfigurationBuilder that will override the default configurations which are already available on this class.
addCustomGlobalConfiguration(GlobalConfigurationBuilder) - Method in class org.infinispan.spring.embedded.AbstractEmbeddedCacheManagerFactory
Sets the GlobalConfigurationBuilder to use when creating an EmbeddedCacheManager.
addDependency(T, T) - Method in class org.infinispan.util.DependencyGraph
Add a dependency between two elements
addDispatcher(EventDispatcher<?>) - Method in class org.infinispan.client.hotrod.event.impl.ClientListenerNotifier
 
addDynamicDependency(String, String) - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
Add a dynamic dependency between two components.
addDynamicDependency(String, String) - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
 
addEntityType(Class<?>) - Method in class org.infinispan.search.mapper.mapping.SearchMappingBuilder
Register a type as an entity type with the default name, its class name.
addEntityType(Class<?>, String) - Method in class org.infinispan.search.mapper.impl.InfinispanMappingInitiator
 
addEntityType(Class<?>, String) - Method in class org.infinispan.search.mapper.mapping.SearchMappingBuilder
Register a type as an entity type with the given name.
addEntityTypes(Set<Class<?>>) - Method in class org.infinispan.search.mapper.mapping.SearchMappingBuilder
 
addErroneousAttribute(String) - Method in exception class org.infinispan.commons.CacheConfigurationException
Deprecated, for removal: This API element is subject to removal in a future version.
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(ListenerHolder, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in interface org.infinispan.notifications.DataConversionAwareListenable
 
addFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
addFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.CacheImpl
 
addFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
addFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.EncoderCache
 
addFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
addFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in interface org.infinispan.notifications.FilteringListenable
addFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
addFilteredListenerAsync(ListenerHolder, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addFilteredListenerAsync(ListenerHolder, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in interface org.infinispan.notifications.DataConversionAwareListenable
 
addFlag(Flag) - Method in interface org.infinispan.commands.FlagAffectedCommand
Deprecated, for removal: This API element is subject to removal in a future version.
Since 9.0, please use FlagAffectedCommand.addFlags(long) with a FlagBitSets constant instead.
addFlags(long) - Method in interface org.infinispan.commands.FlagAffectedCommand
Add a set of flags to the command.
addFlags(Set<Flag>) - Method in interface org.infinispan.commands.FlagAffectedCommand
Deprecated, for removal: This API element is subject to removal in a future version.
Since 9.0, please use FlagAffectedCommand.addFlags(long) with a FlagBitSets constant instead.
addGet(Object, boolean) - Method in class org.infinispan.extendedstats.topK.StreamSummaryContainer
Adds the key to the read top-key.
addGrouper(Grouper<?>) - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
Add a grouper
addHexByte(StringBuilder, byte) - Static method in class org.infinispan.commons.util.Util
 
addIndexedEntities(Class<?>...) - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
 
addIndexedEntities(Class<?>...) - Method in class org.infinispan.configuration.cache.IndexReaderConfigurationBuilder
 
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.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.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.IndexWriterConfigurationBuilder
 
addIndexedEntity(String) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
addIndexedEntity(String) - Method in interface org.infinispan.configuration.cache.IndexingConfigurationChildBuilder
 
AddIndexingOperation - Class in org.infinispan.search.mapper.work.impl
 
addInterceptor() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
addInterceptor(AsyncInterceptor, int) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Inserts the given interceptor at the specified position in the chain (0 based indexing).
addInterceptor(AsyncInterceptor, int) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
addInterceptorAfter(AsyncInterceptor, Class<? extends AsyncInterceptor>) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Adds a new interceptor in list after an interceptor of a given type.
addInterceptorAfter(AsyncInterceptor, Class<? extends AsyncInterceptor>) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
addInterceptorBefore(AsyncInterceptor, Class<? extends AsyncInterceptor>) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Adds a new interceptor in list before an interceptor of a given type.
addInterceptorBefore(AsyncInterceptor, Class<? extends AsyncInterceptor>) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
addIntermediateOperation(Queue<IntermediateOperation>, IntermediateOperation<T, S, ?, ?>) - Method in class org.infinispan.stream.impl.AbstractCacheStream
 
addIntermediateOperation(IntermediateOperation<T, S, T, S>) - Method in class org.infinispan.stream.impl.AbstractCacheStream
 
addIntermediateOperationMap(IntermediateOperation<T, S, ?, ?>) - Method in class org.infinispan.stream.impl.AbstractCacheStream
 
addInternalListener(InternalExpirationManager.ExpirationConsumer<K, V>) - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
addInternalListener(InternalExpirationManager.ExpirationConsumer<K, V>) - Method in interface org.infinispan.expiration.impl.InternalExpirationManager
Adds an InternalExpirationManager.ExpirationConsumer to be invoked when an entry is expired.
addInUseBackupSite(String) - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 14.0. To be removed without replacement.
addJavaSerialAllowList(String...) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
addJavaSerialAllowList(String...) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
addJavaSerialAllowList(String...) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
List of regular expressions for classes that can be deserialized using standard Java deserialization when reading data that might have been stored with a different endpoint, e.g.
addJavaSerialWhiteList(String...) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
Deprecated, 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.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.hotrod.iteration.DefaultIterationManager
 
addKeyValueFilterConverterFactory(String, KeyValueFilterConverterFactory) - Method in interface org.infinispan.server.hotrod.iteration.IterationManager
 
addListener(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
addListener(Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
addListener(Object) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
addListener(Object) - Method in interface org.infinispan.notifications.Listenable
Adds a listener to the component.
addListener(Object, ClassLoader) - Method in interface org.infinispan.notifications.ClassLoaderAwareListenable
Adds a listener along with a class loader to use for the invocation
addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.cache.impl.EncoderCache
 
addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in interface org.infinispan.notifications.FilteringListenable
Registers a listener that will be notified on events that pass the filter condition.
addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, ClassLoader) - Method in interface org.infinispan.notifications.ClassLoaderAwareFilteringListenable
Adds a listener with the provided filter and converter and using a given classloader when invoked.
addListener(String, T) - Method in class org.infinispan.client.hotrod.counter.impl.NotificationManager
 
addListener(AttributeListener<T>) - Method in class org.infinispan.commons.configuration.attributes.Attribute
 
addListener(ListenerHolder, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, ClassLoader) - Method in interface org.infinispan.notifications.DataConversionAwareListenable
 
addListener(ActionListener) - Method in interface org.infinispan.remoting.inboundhandler.action.Action
Adds a listener to be invoked when this action is ready or canceled.
addListener(ActionListener) - Method in class org.infinispan.remoting.inboundhandler.action.DefaultReadyAction
 
addListener(ActionListener) - Method in interface org.infinispan.remoting.inboundhandler.action.ReadyAction
It adds a listener that is invoked when this action is ready.
addListener(CacheTransaction.TransactionCompletedListener) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
addListener(CacheTransaction.TransactionCompletedListener) - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
addListener(KeyAwareLockListener) - Method in interface org.infinispan.util.concurrent.locks.KeyAwareLockPromise
It adds the listener to this LockPromise.
addListener(LockListener) - Method in interface org.infinispan.util.concurrent.locks.LockPromise
Adds a LockListener to be invoked when the lock is available.
addListener(PendingLockListener) - Method in interface org.infinispan.util.concurrent.locks.PendingLockPromise
Adds a listener to this promise.
addListener(T) - Method in class org.infinispan.client.hotrod.counter.impl.BaseCounter
 
addListener(T) - Method in interface org.infinispan.counter.api.StrongCounter
Registers a CounterListener to this counter.
addListener(T) - Method in interface org.infinispan.counter.api.WeakCounter
Adds a CounterListener to this counter.
addListenerAsync(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
addListenerAsync(Object) - Method in class org.infinispan.cache.impl.CacheImpl
 
addListenerAsync(Object) - Method in class org.infinispan.cache.impl.DecoratedCache
 
addListenerAsync(Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
addListenerAsync(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
addListenerAsync(Object) - Method in class org.infinispan.manager.DefaultCacheManager
 
addListenerAsync(Object) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
addListenerAsync(Object) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addListenerAsync(Object) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
addListenerAsync(Object) - Method in interface org.infinispan.notifications.Listenable
Asynchronous version of Listenable.addListener(Object)
addListenerAsync(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
addListenerAsync(Object, ClassLoader) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addListenerAsync(Object, ClassLoader) - Method in interface org.infinispan.notifications.ClassLoaderAwareListenable
addListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
addListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.cache.impl.CacheImpl
 
addListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
addListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.cache.impl.EncoderCache
 
addListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
addListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in interface org.infinispan.notifications.FilteringListenable
addListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
addListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, ClassLoader) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
Adds the listener using the provided filter converter and class loader.
addListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, ClassLoader) - Method in interface org.infinispan.notifications.ClassLoaderAwareFilteringListenable
 
addListenerAsync(ListenerHolder, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, ClassLoader) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addListenerAsync(ListenerHolder, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, ClassLoader) - Method in interface org.infinispan.notifications.DataConversionAwareListenable
 
AddListenerOperation - Class in org.infinispan.client.hotrod.counter.operation
AddListenerOperation(ChannelFactory, AtomicReference<ClientTopology>, Configuration, String, byte[], SocketAddress) - Constructor for class org.infinispan.client.hotrod.counter.operation.AddListenerOperation
 
addLocalBias(Object, int) - Method in interface org.infinispan.scattered.BiasManager
Allow reading local data if the topology is still actual.
addLocalBias(Object, int) - Method in class org.infinispan.scattered.impl.BiasManagerImpl
 
addLocalValue(ExtendedStatistic, double) - Method in class org.infinispan.extendedstats.CacheStatisticCollector
Adds a value to a local statistic.
addLockedKey(Object) - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
addLockedKey(Object) - Method in class org.infinispan.context.impl.ClearInvocationContext
 
addLockedKey(Object) - Method in class org.infinispan.context.impl.ImmutableContext
 
addLockedKey(Object) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
addLockedKey(Object) - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
 
addLockedKey(Object) - Method in interface org.infinispan.context.InvocationContext
Tracks the given key as locked by this invocation context.
addLockedKeys(Collection<?>) - Method in interface org.infinispan.context.InvocationContext
 
addLockInformation(Object, boolean, boolean) - Method in class org.infinispan.extendedstats.topK.StreamSummaryContainer
Adds the lock information about the key, namely if the key suffer some contention and if the keys was locked or not.
AddLoggerListenerAsyncAction - Class in org.infinispan.security.actions
Add logger listener action.
AddLoggerListenerAsyncAction(EmbeddedCacheManager, Object) - Constructor for class org.infinispan.security.actions.AddLoggerListenerAsyncAction
 
addMany(MetaParam...) - Method in class org.infinispan.functional.impl.MetaParams
 
addMarshalledEntry(Object, MarshallableEntry<Object, Object>) - Method in class org.infinispan.persistence.support.BatchModification
 
addMechanisms(String...) - Method in class org.infinispan.rest.configuration.AuthenticationConfigurationBuilder
 
addMechanisms(String...) - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
 
addMechanisms(String...) - Method in class org.infinispan.server.hotrod.configuration.SaslConfigurationBuilder
 
addMechProperty(String, String) - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
 
addMember(Address, boolean) - Method in class org.infinispan.xsite.status.CacheSiteStatusBuilder
Adds a member with an online/offline connection to the server based on the online parameter.
addMergePolicyFactory(EntryMergePolicyFactory) - Method in class org.infinispan.conflict.EntryMergePolicyFactoryRegistry
 
addModification(WriteCommand) - Method in class org.infinispan.transaction.impl.LocalTransaction
 
addModule(Class<T>) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
addModule(Class<T>) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
addNearCacheListener(Object, int) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
addNearCacheListener(Object, int) - Method in interface org.infinispan.client.hotrod.impl.InternalRemoteCache
Add a client listener to handle near cache with bloom filter optimization The listener object must be annotated with @ClientListener annotation.
addNearCacheListener(Object, int) - Method in class org.infinispan.client.hotrod.impl.InvalidatedNearRemoteCache
 
addNearCacheListener(Object, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
addNewRule() - Method in class org.infinispan.rest.configuration.CorsConfigurationBuilder
 
AddOperation - Class in org.infinispan.client.hotrod.counter.operation
Add operation.
AddOperation(ChannelFactory, AtomicReference<ClientTopology>, Configuration, String, long, boolean) - Constructor for class org.infinispan.client.hotrod.counter.operation.AddOperation
 
addOptionalParameter(String, Object) - Method in class org.infinispan.tasks.TaskContext
Adds a named parameter to the task context only if it is non-null
addOrUpdate(Object, String, Object) - Method in class org.infinispan.search.mapper.work.impl.SearchIndexerImpl
 
addOrUpdate(Object, String, Object) - Method in interface org.infinispan.search.mapper.work.SearchIndexer
 
AddOrUpdateIndexingOperation - Class in org.infinispan.search.mapper.work.impl
 
addOwner(int, Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
addOwner(Address) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfo
Adds owner as a node where this transaction information is maintained.
addOwners(int, Collection<Address>) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
addParameter(String, Object) - Method in class org.infinispan.tasks.TaskContext
Adds a named parameter to the task context
addParams(StringBuilder) - Method in class org.infinispan.client.hotrod.counter.operation.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.GetCounterNamesOperation
 
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
 
addParserListener(ConfigurationParserListener) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
addPartialCommit1PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, List<WriteCommand>) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
addPartialCommit1PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, List<WriteCommand>) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
Adds a partially committed transaction.
addPartialCommit1PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, List<WriteCommand>) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
addPartialCommit2PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, Map<Object, IncrementableEntryVersion>) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
addPartialCommit2PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, Map<Object, IncrementableEntryVersion>) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
Adds a partially committed transaction.
addPartialCommit2PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, Map<Object, IncrementableEntryVersion>) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
addPartialRollbackTransaction(GlobalTransaction, Collection<Address>, Collection<Object>) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
addPartialRollbackTransaction(GlobalTransaction, Collection<Address>, Collection<Object>) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
Adds a partially aborted transaction.
addPartialRollbackTransaction(GlobalTransaction, Collection<Address>, Collection<Object>) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
addPersistenceInterceptors(AsyncInterceptorChain, Configuration, List<StoreConfiguration>) - Method in class org.infinispan.factories.InterceptorChainFactory
Adds all the interceptors related to persistence to the stack.
addPersistentAddressMapping(Address, PersistentUUID) - Method in interface org.infinispan.topology.PersistentUUIDManager
Adds a mapping between an Address and a PersistentUUID
addPersistentAddressMapping(Address, PersistentUUID) - Method in class org.infinispan.topology.PersistentUUIDManagerImpl
 
addPolicy(String) - Method in class org.infinispan.server.hotrod.configuration.SaslConfigurationBuilder
 
addPrimaryOwner(int, Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
addPrimaryOwner(int, Address) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
addPrimaryOwners(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
 
addProcessedDate(Date) - Method in interface org.infinispan.rest.framework.impl.RestResponseBuilder
 
addProcessedDate(Date) - Method in class org.infinispan.rest.framework.impl.SimpleRestResponse.Builder
 
addProcessedDate(Date) - Method in class org.infinispan.rest.NettyRestResponse.Builder
 
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 class org.infinispan.configuration.cache.IndexingConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 12.0, please use IndexingConfigurationBuilder.writer() and IndexingConfigurationBuilder.reader() to define indexing behavior.
addProperty(String, String) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
Deprecated.
 
addProperty(String, String) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
Defines a single property.
addProperty(String, String) - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
Add key/value property pair to this executor factory configuration
addProperty(String, String) - Method in class org.infinispan.configuration.global.GlobalJmxConfigurationBuilder
 
addProperty(String, String) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
Deprecated.
 
addProperty(String, String) - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
Add key/value property pair to this executor factory configuration
addProperty(String, String) - Method in class org.infinispan.server.hotrod.configuration.SaslConfigurationBuilder
 
addProtoSchemas(String...) - Method in class org.infinispan.server.core.backup.BackupManagerResources.Builder
 
addProxy(MavenSettings.Proxy) - Method in class org.infinispan.commons.maven.MavenSettings
 
addPut(Object, boolean) - Method in class org.infinispan.extendedstats.topK.StreamSummaryContainer
Adds the key to the put top-key.
addQOP(String) - Method in class org.infinispan.server.hotrod.configuration.SaslConfigurationBuilder
 
addRegexp(String) - Method in class org.infinispan.configuration.global.AllowListConfigurationBuilder
Helper method that allows for registration of a regexp to the ClassAllowList.
addRegexp(String) - Method in class org.infinispan.configuration.global.WhiteListConfigurationBuilder
Deprecated.
Helper method that allows for registration of a regexp to the ClassAllowList.
addRegexps(String...) - Method in class org.infinispan.commons.configuration.ClassAllowList
 
addRegexps(String...) - Method in class org.infinispan.configuration.global.AllowListConfigurationBuilder
Helper method that allows for registration of regexps to the ClassAllowList.
addRegexps(String...) - Method in class org.infinispan.configuration.global.WhiteListConfigurationBuilder
Deprecated.
Helper method that allows for registration of regexps to the ClassAllowList.
addRemoteCache(String, Consumer<RemoteCacheConfigurationBuilder>) - Method in class org.infinispan.client.hotrod.configuration.Configuration
addRemoteSite(String, String, String, String) - Method in class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.RemoteSites
 
addRemoteValue(ExtendedStatistic, double) - Method in class org.infinispan.extendedstats.CacheStatisticCollector
Adds a value to a remote statistic.
addRemovalListener(Consumer<Iterable<InternalCacheEntry<K, V>>>) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
addRemovalListener(Consumer<Iterable<InternalCacheEntry<K, V>>>) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
addRemovalListener(Consumer<Iterable<InternalCacheEntry<K, V>>>) - Method in interface org.infinispan.container.impl.InternalDataContainer
Adds a listener that is invoked whenever InternalDataContainer.removeSegments(IntSet) is invoked providing a way for the listener to see what actual entries were removed from the container.
addRemovalListener(Consumer<Iterable<InternalCacheEntry<WrappedBytes, WrappedBytes>>>) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
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 org.infinispan.configuration.parsing.Attribute
 
addresses() - Method in class org.infinispan.rest.distribution.CacheDistributionInfo
 
addresses() - Method in interface org.infinispan.rest.distribution.NodeDataDistribution
 
addresses() - Method in class org.infinispan.rest.distribution.NodeDistributionInfo
 
addressToPersistentUUID() - Method in interface org.infinispan.topology.PersistentUUIDManager
Provides a remapping operator which translates addresses to persistentuuids
addressToPersistentUUID() - Method in class org.infinispan.topology.PersistentUUIDManagerImpl
 
addRole(Role) - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
addRole(Role) - Method in class org.infinispan.security.mappers.ClusterPermissionMapper
 
addRole(Role) - Method in interface org.infinispan.security.MutableRolePermissionMapper
Adds a new role
addScheduledThreadPool(String) - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
 
addScript(String, String) - Method in interface org.infinispan.scripting.ScriptingManager
Adds a new named script.
addScripts(String...) - Method in class org.infinispan.server.core.backup.BackupManagerResources.Builder
 
addSegments(IntSet) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
addSegments(IntSet) - Method in class org.infinispan.container.impl.DefaultDataContainer
 
addSegments(IntSet) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
addSegments(IntSet) - Method in interface org.infinispan.container.impl.InternalDataContainer
Sets what segments this data container should be using.
addSegments(IntSet) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
addSegments(IntSet) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
addSegments(IntSet) - Method in class org.infinispan.persistence.async.AsyncNonBlockingStore
 
addSegments(IntSet) - Method in class org.infinispan.persistence.file.SingleFileStore
 
addSegments(IntSet) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
addSegments(IntSet) - Method in class org.infinispan.persistence.remote.RemoteStore
 
addSegments(IntSet) - Method in class org.infinispan.persistence.rocksdb.RocksDBStore
 
addSegments(IntSet) - Method in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
 
addSegments(IntSet) - Method in class org.infinispan.persistence.sifs.TemporaryTable
 
addSegments(IntSet) - Method in interface org.infinispan.persistence.spi.NonBlockingStore
Invoked when a node becomes an owner of the given segments.
addSegments(IntSet) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
Deprecated.
Invoked when a node becomes an owner of the given segments.
addSegments(IntSet) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
addSegments(IntSet) - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
 
addSegments(IntSet) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
 
addSegments(IntSet) - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
 
addServer() - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
addServer() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
addServer() - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Adds a new remote server
addServer() - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
addServer() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
addServer() - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
Adds a new remote server
addServers(String) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
addServers(String) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
addServers(String) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Adds a list of remote servers in the form: host1[:port][;host2[:port]]...
addShutdownHook() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
addShutdownHook() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
addSingleFileStore() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
since 13.0. To be removed in 14.0 has been replaced by PersistenceConfigurationBuilder.addSoftIndexFileStore()
addSni() - Method in class org.infinispan.server.core.configuration.EncryptionConfigurationBuilder
 
addSoftIndexFileStore() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
Adds a soft index file cache store.
AddSourceRemoteStoreTask - Class in org.infinispan.persistence.remote.upgrade
Task to add a remote store to the cache.
AddSourceRemoteStoreTask(String, RemoteStoreConfiguration) - Constructor for class org.infinispan.persistence.remote.upgrade.AddSourceRemoteStoreTask
 
AddSourceRemoteStoreTask.Externalizer - Class in org.infinispan.persistence.remote.upgrade
 
addStack(String) - Method in class org.infinispan.configuration.global.JGroupsConfigurationBuilder
 
addStackFile(String) - Method in class org.infinispan.configuration.global.JGroupsConfigurationBuilder
 
addStats(String, String) - Method in class org.infinispan.client.hotrod.impl.ServerStatisticsImpl
 
addStorageFormatFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
addStorageFormatFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.EncoderCache
 
addStorageFormatFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in interface org.infinispan.notifications.FilteringListenable
Same as FilteringListenable.addFilteredListener(Object, CacheEventFilter, CacheEventConverter, Set), but assumes the filter and/or the converter will be done in the same data format as it's stored in the cache.
addStorageFormatFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
addStorageFormatFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.CacheImpl
 
addStorageFormatFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
addStorageFormatFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.EncoderCache
 
addStorageFormatFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
addStorageFormatFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
addStorageFormatFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in interface org.infinispan.notifications.FilteringListenable
addStorageFormatFilteredListenerAsync(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
addStore(Class<T>) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
Adds a cache loader that uses the specified builder class to build its configuration.
addStore(StoreConfiguration) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
 
addStore(StoreConfigurationBuilder<?, ?>) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
Adds a cache loader that uses the specified builder instance to build its configuration.
addStoreListener(PersistenceManager.StoreChangeListener) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
 
addStrength(String) - Method in class org.infinispan.server.hotrod.configuration.SaslConfigurationBuilder
 
addStrongCounter() - Method in class org.infinispan.counter.configuration.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
 
addUser(String, String, char[], String...) - Method in class org.infinispan.server.core.security.simple.SimpleServerAuthenticationProvider
Add a user to the authentication table.
addValidResponse(Address, ValidResponse) - Method in class org.infinispan.remoting.transport.impl.FilterMapResponseCollector
 
addValidResponse(Address, ValidResponse) - Method in class org.infinispan.remoting.transport.impl.MapResponseCollector
 
addValidResponse(Address, ValidResponse) - Method in class org.infinispan.remoting.transport.impl.VoidResponseCollector
 
addValidResponse(Address, ValidResponse) - Method in class org.infinispan.remoting.transport.ValidResponseCollector
Process a valid response from a target.
addValue(ExtendedStatistic, double) - Method in class org.infinispan.extendedstats.container.BaseExtendedStatisticsContainer
 
addValue(ExtendedStatistic, double) - Method in interface org.infinispan.extendedstats.container.ExtendedStatisticsContainer
it adds the value to the statistic.
addValue(ExtendedStatistic, double) - Method in class org.infinispan.extendedstats.TransactionStatistics
Adds a value to a statistic collected for this transaction.
addVersionRead(Object, EntryVersion) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
addVersionRead(Object, EntryVersion) - Method in interface org.infinispan.transaction.xa.CacheTransaction
Sets the version read for this key.
addVersionRead(TxInvocationContext<?>, CacheEntry<?, ?>, Object, VersionGenerator, Log) - Static method in class org.infinispan.transaction.impl.WriteSkewHelper
 
addWeakCounter() - Method in class org.infinispan.counter.configuration.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
 
addWriteSkewFailed(Object) - Method in class org.infinispan.extendedstats.topK.StreamSummaryContainer
Adds the key to the write skew failed top-key.
ADMIN - Enum constant in enum org.infinispan.security.AuthorizationPermission
Allows performing "administrative" operations on a cache
ADMIN_FLAG - Static variable in interface org.infinispan.commons.marshall.Ids
 
ADMIN_OPERATION_HANDLER - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
 
adminEndpoint - Variable in class org.infinispan.server.core.AbstractProtocolServer
 
AdminFlagExternalizer - Class in org.infinispan.commons.marshall
 
AdminFlagExternalizer() - Constructor for class org.infinispan.commons.marshall.AdminFlagExternalizer
 
administration() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
Access to administration operations (cache creation, removal, etc)
administration() - Method in interface org.infinispan.manager.CacheContainer
Provides access to administrative methods which affect the underlying cache container, such as cache creation and removal.
administration() - Method in class org.infinispan.manager.DefaultCacheManager
 
administration() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Provides an EmbeddedCacheManagerAdmin whose methods affect the entire cluster as opposed to a single node.
administration() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
AdminOperation - Enum in org.infinispan.server.core.admin
AdminOperations
AdminOperationParameter - Enum in org.infinispan.server.core.admin
AdminOperationParameters
adminOperationsHandler() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
 
adminOperationsHandler(AdminOperationsHandler) - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
 
adminOperationsHandler(AdminOperationsHandler) - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
 
adminOperationsHandler(AdminOperationsHandler) - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
Indicates the AdminOperationsHandler which will be used to handle admin operations
adminOperationsHandler(AdminOperationsHandler) - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
 
AdminOperationsHandler - Class in org.infinispan.server.core.admin
AdminOperationsHandler is a special TaskEngine which can handle admin tasks
AdminOperationsHandler(AdminServerTask<?>...) - Constructor for class org.infinispan.server.core.admin.AdminOperationsHandler
 
AdminServerTask<T> - Class in org.infinispan.server.core.admin
Common base for admin server tasks
AdminServerTask() - Constructor for class org.infinispan.server.core.admin.AdminServerTask
 
ADVANCED_EXTERNALIZER - Enum constant in enum org.infinispan.configuration.parsing.Element
 
ADVANCED_EXTERNALIZERS - Enum constant in enum org.infinispan.configuration.parsing.Element
 
ADVANCED_EXTERNALIZERS - Static variable in class org.infinispan.configuration.global.SerializationConfiguration
 
AdvancedCache<K,V> - Interface in org.infinispan
An advanced interface that exposes additional methods not available on Cache.
AdvancedCacheExpirationWriter<K,V> - Interface in org.infinispan.persistence.spi
Deprecated, 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() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
after(Class<? extends AsyncInterceptor>) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
Deprecated.
Dictates that the custom interceptor appears immediately after the specified interceptor.
AFTER - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
AFTER - Enum constant in enum org.infinispan.container.versioning.InequalVersionComparisonResult
Denotes a version that was created temporally after another version.
AFTER - Static variable in class org.infinispan.configuration.cache.InterceptorConfiguration
 
AFTER_FAILURES - Static variable in class org.infinispan.configuration.cache.TakeOfflineConfiguration
 
AFTER_FAILURES_FIELD - Static variable in class org.infinispan.rest.resources.XSiteResource
 
afterCompletion(int) - Method in class org.infinispan.transaction.synchronization.SynchronizationAdapter
 
afterCompletion(LocalTransaction, int) - Method in class org.infinispan.transaction.impl.TransactionTable
 
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.
afterPropertiesSet() - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository
 
afterPropertiesSet() - Method in class org.infinispan.spring.embedded.InfinispanDefaultCacheFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.embedded.provider.SpringEmbeddedCacheManagerFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.embedded.support.InfinispanEmbeddedCacheManagerFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.embedded.support.InfinispanNamedEmbeddedCacheFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.remote.provider.SpringRemoteCacheManagerFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.remote.support.InfinispanNamedRemoteCacheFactoryBean
 
afterPropertiesSet() - Method in class org.infinispan.spring.remote.support.InfinispanRemoteCacheManagerFactoryBean
 
AggregateBackupResponse - Class in org.infinispan.remoting.transport
 
AggregateBackupResponse(BackupResponse, BackupResponse) - Constructor for class org.infinispan.remoting.transport.AggregateBackupResponse
 
aggregateCompletionStage() - Static method in class org.infinispan.util.concurrent.CompletionStages
Returns a CompletionStage that also can be composed of many other CompletionStages.
aggregateCompletionStage(R) - Static method in class org.infinispan.util.concurrent.CompletionStages
Same as CompletionStages.aggregateCompletionStage() except that when this stage completes normally it will return the value provided.
AggregateCompletionStage<R> - Interface in org.infinispan.util.concurrent
Aggregation of multiple CompletionStage instances where their count is not known or when a large amount of stages are required, as it uses less memory foot print per stage.
AggregatedClassLoader - Class in org.infinispan.commons.util
A ClassLoader that delegates loading of classes and resources to a list of delegate ClassLoaders.
AggregatedClassLoader(Collection<ClassLoader>) - Constructor for class org.infinispan.commons.util.AggregatedClassLoader
Create an aggregated ClassLoader from a Collection of ClassLoaders
aggregation() - Method in class org.infinispan.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.
ALIASES - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
all() - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
 
all() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager.RecoveryIterator
Exhaust the iterator.
ALL - Enum constant in enum org.infinispan.configuration.cache.Index
Deprecated.
All cluster nodes will add the entry to the index.
ALL - Enum constant in enum org.infinispan.functional.Param.ExecutionMode
Command is executed on its owners, in transactional mode in the context, too, but there it is not persisted.
ALL - Enum constant in enum org.infinispan.manager.ClusterExecutionPolicy
The command can be executed on any node in the cluster
ALL - Enum constant in enum org.infinispan.security.AuthorizationPermission
Aggregate permission which implies all the others
ALL_GET_EXECUTION - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
 
ALL_NODES - Enum constant in enum org.infinispan.tasks.TaskExecutionMode
 
ALL_READ - Enum constant in enum org.infinispan.security.AuthorizationPermission
Aggregate permission which implies all read permissions
ALL_WRITE - Enum constant in enum org.infinispan.security.AuthorizationPermission
Aggregate permission which implies all write permissions
allBackups() - Method in class org.infinispan.configuration.cache.SitesConfiguration
Returns the list of all sites where this cache might back up its data.
allBackupsStream() - Method in class org.infinispan.configuration.cache.SitesConfiguration
 
allIndexedEntities() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
 
allIndexedEntities() - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
 
allIndexedEntityJavaClasses() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
 
allIndexedEntityJavaClasses() - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
 
allIndexedEntityNames() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
 
allIndexedEntityNames() - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
 
allMatch(DoublePredicate) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
allMatch(DoublePredicate) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
allMatch(IntPredicate) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
allMatch(IntPredicate) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
allMatch(LongPredicate) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
allMatch(LongPredicate) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
allMatch(Predicate<? super E>) - Static method in class org.infinispan.reactive.publisher.PublisherReducers
 
allMatch(Predicate<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
allMatch(Predicate<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
allMatch(Predicate<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
allMatch(Predicate<? super T>) - Method in interface org.infinispan.functional.Traversable
A terminal operation that returns whether all elements of this traversable match the provided predicate.
allMatch(SerializableDoublePredicate) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleStream.allMatch(DoublePredicate) except that the DoublePredicate must also implement Serializable
allMatch(SerializableIntPredicate) - Method in interface org.infinispan.IntCacheStream
Same as IntStream.allMatch(IntPredicate) except that the IntPredicate must also implement Serializable
allMatch(SerializableLongPredicate) - Method in interface org.infinispan.LongCacheStream
Same as LongStream.allMatch(LongPredicate) except that the LongPredicate must also implement Serializable.
allMatch(SerializablePredicate<? super R>) - Method in interface org.infinispan.CacheStream
Same as Stream.allMatch(Predicate) except that the Predicate must also implement Serializable
allNodeSubmission() - Method in interface org.infinispan.manager.ClusterExecutor
When a command is submitted it will submit this command to all of the available nodes that pass the provided filter.
allocate(long) - Method in interface org.infinispan.container.offheap.OffHeapMemoryAllocator
Allocates a new chunk of memory sized to the given length.
allocate(long) - Method in class org.infinispan.container.offheap.UnpooledOffHeapMemoryAllocator
 
allocator - Variable in class org.infinispan.container.offheap.OffHeapDataContainer
 
allocator - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
allocList(int) - Method in class org.infinispan.server.hotrod.HotRodDecoder
 
allocMap(int) - Method in class org.infinispan.server.hotrod.HotRodDecoder
We usually know the size of the map ahead, and we want to return static empty map if we're not going to add anything.
allocSet(int) - Method in class org.infinispan.server.hotrod.HotRodDecoder
 
allOf(CompletionStage<?>...) - Static method in class org.infinispan.util.concurrent.CompletionStages
Returns a CompletionStage that completes when all of the provided stages complete, either normally or via exception.
allOf(CompletionStage<Void>, CompletionStage<Void>) - Static method in class org.infinispan.util.concurrent.CompletionStages
Returns a CompletableStage that completes when both of the provides CompletionStages complete.
ALLOW - Enum constant in enum org.infinispan.security.AuditResponse
 
ALLOW_CREDENTIALS - Static variable in class org.infinispan.rest.configuration.CorsRuleConfiguration
 
ALLOW_DUPLICATE_DOMAINS - Enum constant in enum org.infinispan.configuration.parsing.Attribute
Deprecated, 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 org.infinispan.configuration.parsing.Element
 
ALLOW_METHODS - Static variable in class org.infinispan.rest.configuration.CorsRuleConfiguration
 
ALLOW_ORIGINS - Static variable in class org.infinispan.rest.configuration.CorsRuleConfiguration
 
ALLOW_READ_WRITES - Enum constant in enum org.infinispan.partitionhandling.PartitionHandling
Allow entries on each partition to diverge, with conflicts resolved during merge.
ALLOW_READS - Enum constant in enum org.infinispan.partitionhandling.PartitionHandling
Allows reads for a given key if it exists in this partition, but only allows writes if this partition contains all owners of a segment.
allowCredentials(boolean) - Method in class org.infinispan.rest.configuration.CorsRuleConfigurationBuilder
 
ALLOWED_DUPLICATES - Static variable in class org.infinispan.configuration.parsing.CacheParser
 
allowedMechs() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfiguration
 
allowedSegments - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
 
allowedSegments - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator
 
allowedSegments - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
 
allowFrom(String) - Method in class org.infinispan.server.core.configuration.IpFilterConfigurationBuilder
 
allowHeaders(String[]) - Method in class org.infinispan.rest.configuration.CorsRuleConfigurationBuilder
 
allowInvocations() - Method in enum org.infinispan.lifecycle.ComponentStatus
 
allowList() - Method in class org.infinispan.client.hotrod.event.impl.ClientListenerNotifier
 
allowList() - Method in class org.infinispan.configuration.global.SerializationConfiguration
 
allowList() - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
AllowListConfiguration - Class in org.infinispan.configuration.global
 
AllowListConfigurationBuilder - Class in org.infinispan.configuration.global
allowMethods(String[]) - Method in class org.infinispan.rest.configuration.CorsRuleConfigurationBuilder
 
allowMethodsToBlock(BlockHound.Builder, Class<?>, boolean) - Static method in class org.infinispan.commons.internal.CommonsBlockHoundIntegration
 
allowOrigins(String[]) - Method in class org.infinispan.rest.configuration.CorsRuleConfigurationBuilder
 
allowPublicMethodsToBlock(BlockHound.Builder, Class<?>) - Static method in class org.infinispan.commons.internal.CommonsBlockHoundIntegration
 
allStringsInterned - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
Implementation notice: the is instance variable that controls if newString() is interning.
allSubmissionExecutor(Predicate<? super Address>, EmbeddedCacheManager, Transport, long, TimeUnit, BlockingManager, ScheduledExecutorService) - Static method in class org.infinispan.manager.impl.ClusterExecutors
 
allTypeIdentifiers() - Method in interface org.infinispan.search.mapper.session.impl.InfinispanTypeContextProvider
 
ALPNHandler - Class in org.infinispan.rest
Handler responsible for TLS/ALPN negotiation.
ALPNHandler(RestServer) - Constructor for class org.infinispan.rest.ALPNHandler
 
ALREADY_HAS_LOCK - Enum constant in enum org.infinispan.context.Flag
Flag to designate that this operation was performed on behalf of another that already has the lock for the given key.
ALREADY_HAS_LOCK - Static variable in class org.infinispan.context.impl.FlagBitSets
 
ALREADY_OFFLINE - Enum constant in enum org.infinispan.xsite.status.TakeSiteOfflineResponse
 
ALREADY_ONLINE - Enum constant in enum org.infinispan.xsite.status.BringSiteOnlineResponse
 
ALWAYS_REMOVE - Enum constant in enum org.infinispan.xsite.spi.XSiteMergePolicy
Always remove the key if there is a conflict.
ALWAYS_TRUE_LOGIC - Static variable in class org.infinispan.transaction.impl.WriteSkewHelper
 
AlwaysRemoveXSiteEntryMergePolicy<K,V> - Class in org.infinispan.xsite.spi
A XSiteEntryMergePolicy that removes the key if a conflict is detected.
alwaysTruePredicate() - Static method in class org.infinispan.stream.StreamMarshalling
Predicate taht always returns true irrespective of the value provided
amendChannel(JChannel) - Method in class org.infinispan.remoting.transport.jgroups.AbstractJGroupsChannelConfigurator
 
amendConfiguration(String, Integer, Long) - Method in class org.infinispan.xsite.status.DefaultTakeOfflineManager
 
amendConfiguration(String, Integer, Long) - Method in class org.infinispan.xsite.status.NoOpTakeOfflineManager
 
amendConfiguration(String, Integer, Long) - Method in interface org.infinispan.xsite.status.TakeOfflineManager
It changes the TakeOfflineConfiguration for site siteName.
and() - Method in interface org.infinispan.query.dsl.FilterConditionContext
Deprecated.
Creates a new context and connects it with the current one using boolean AND.
and() - Static method in class org.infinispan.reactive.publisher.PublisherReducers
 
and(FilterConditionContext) - Method in interface org.infinispan.query.dsl.FilterConditionContext
Deprecated.
Connects a given context with the current one using boolean AND.
andExceptionally(InvocationContext, C, InvocationExceptionFunction<C>) - Method in class org.infinispan.interceptors.InvocationStage
After the current stage completes exceptionally, invoke function and return its result.
andExceptionally(InvocationContext, C, InvocationExceptionFunction<C>) - Method in class org.infinispan.interceptors.SyncInvocationStage
 
andExceptionally(InvocationContext, VisitableCommand, InvocationExceptionFunction) - Method in class org.infinispan.interceptors.ExceptionSyncInvocationStage
 
andExceptionallyMakeStage(InvocationContext, C, InvocationExceptionFunction<C>) - Method in class org.infinispan.interceptors.InvocationStage
After the current stage completes exceptionally, invoke function and return its result.
andExceptionallyMakeStage(InvocationContext, C, InvocationExceptionFunction<C>) - Method in class org.infinispan.interceptors.SyncInvocationStage
 
andFinally(InvocationContext, C, InvocationFinallyAction<C>) - Method in class org.infinispan.interceptors.InvocationStage
After the current stage completes, invoke action.
andFinally(InvocationContext, C, InvocationFinallyAction<C>) - Method in class org.infinispan.interceptors.SyncInvocationStage
 
andFinally(InvocationContext, VisitableCommand, InvocationFinallyAction) - Method in class org.infinispan.interceptors.ExceptionSyncInvocationStage
 
andFinallyMakeStage(InvocationContext, C, InvocationFinallyAction<C>) - Method in class org.infinispan.interceptors.InvocationStage
After the current stage completes, invoke action.
andFinallyMakeStage(InvocationContext, C, InvocationFinallyAction<C>) - Method in class org.infinispan.interceptors.SyncInvocationStage
 
andHandle(InvocationContext, C, InvocationFinallyFunction<C>) - Method in class org.infinispan.interceptors.InvocationStage
After the current stage completes, invoke function and return its result.
andHandle(InvocationContext, C, InvocationFinallyFunction<C>) - Method in class org.infinispan.interceptors.SyncInvocationStage
 
andHandle(InvocationContext, VisitableCommand, InvocationFinallyFunction) - Method in class org.infinispan.interceptors.ExceptionSyncInvocationStage
 
andHandleMakeStage(InvocationContext, C, InvocationFinallyFunction<C>) - Method in class org.infinispan.interceptors.InvocationStage
After the current stage completes, invoke function and return its result.
andHandleMakeStage(InvocationContext, C, InvocationFinallyFunction<C>) - Method in class org.infinispan.interceptors.SyncInvocationStage
 
annotation - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
annotation - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
annotationValueReadHandleFactory() - Method in class org.infinispan.search.mapper.model.impl.InfinispanBootstrapIntrospector
 
anonymous() - Method in class org.infinispan.rest.framework.impl.InvocationImpl
 
anonymous() - Method in class org.infinispan.rest.framework.impl.InvocationImpl.Builder
 
anonymous() - Method in interface org.infinispan.rest.framework.Invocation
 
anonymous(boolean) - Method in class org.infinispan.rest.framework.impl.InvocationImpl.Builder
 
anyMatch(DoublePredicate) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
anyMatch(DoublePredicate) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
anyMatch(IntPredicate) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
anyMatch(IntPredicate) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
anyMatch(LongPredicate) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
anyMatch(LongPredicate) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
anyMatch(Predicate<? super E>) - Static method in class org.infinispan.reactive.publisher.PublisherReducers
 
anyMatch(Predicate<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
anyMatch(Predicate<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
anyMatch(Predicate<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
anyMatch(Predicate<? super T>) - Method in interface org.infinispan.functional.Traversable
A terminal operation that returns whether any elements of this traversable match the provided predicate.
anyMatch(SerializableDoublePredicate) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleStream.anyMatch(DoublePredicate) except that the DoublePredicate must also implement Serializable
anyMatch(SerializableIntPredicate) - Method in interface org.infinispan.IntCacheStream
Same as IntStream.anyMatch(IntPredicate) except that the IntPredicate must also implement Serializable
anyMatch(SerializableLongPredicate) - Method in interface org.infinispan.LongCacheStream
Same as LongStream.anyMatch(LongPredicate) except that the LongPredicate must also implement Serializable.
anyMatch(SerializablePredicate<? super R>) - Method in interface org.infinispan.CacheStream
Same as Stream.anyMatch(Predicate) except that the Predicate must also implement Serializable
AnyScopeComponentFactory - Class in org.infinispan.factories
 
AnyScopeComponentFactory() - Constructor for class org.infinispan.factories.AnyScopeComponentFactory
 
append(char) - Method in class org.infinispan.commons.io.StringBuilderWriter
 
append(CharSequence) - Method in class org.infinispan.commons.io.StringBuilderWriter
 
append(CharSequence, int, int) - Method in class org.infinispan.commons.io.StringBuilderWriter
 
append(WriteCommand) - Method in class org.infinispan.transaction.impl.ModificationList
Appends the WriteCommand to this list.
APPEND - Enum constant in enum org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.StackCombine
 
appendErrors(ErrorWriter) - Method in class org.infinispan.server.core.dataconversion.xml.MXParserReader
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheEntry
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.MortalCacheEntry
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.MortalCacheValue
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.TransientCacheEntry
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.TransientCacheValue
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
appendFieldsToString(StringBuilder) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
appendInterceptor(AsyncInterceptor, boolean) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Appends at the end.
appendInterceptor(AsyncInterceptor, boolean) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
AppendRequest - Enum constant in enum org.infinispan.server.memcached.MemcachedOperation
 
APPLICATION_INFINISPAN_BINARY - Static variable in class org.infinispan.commons.dataconversion.MediaType
Deprecated, 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_KRYO - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_KRYO_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_OBJECT - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_OBJECT_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_OCTET_STREAM - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_OCTET_STREAM_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_OPENMETRICS - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_OPENMETRICS_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_PDF - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_PDF_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_PROTOSTREAM - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_PROTOSTREAM_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_PROTOSTUFF - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_PROTOSTUFF_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_RTF - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_RTF_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_SERIALIZED_OBJECT - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_SERIALIZED_OBJECT_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
APPLICATION_TEXT_STRING - Static variable in class org.infinispan.scripting.utils.ScriptConversions
 
APPLICATION_UNKNOWN - Static variable in class org.infinispan.commons.dataconversion.MediaType
Deprecated, 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
 
applicationEventPublisher - Variable in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository
 
apply(Object) - Method in class org.infinispan.cache.impl.FunctionMapper
 
apply(Object) - Method in class org.infinispan.remoting.LocalInvocation
 
apply(Object, Object) - Method in class org.infinispan.cache.impl.BiFunctionMapper
 
apply(String, MapSession) - Method in class org.infinispan.spring.common.session.SessionUpdateRemappingFunction
 
apply(Void) - Method in class org.infinispan.xsite.irac.IracExecutor
apply(Consumer<T>) - Method in class org.infinispan.commons.configuration.attributes.Attribute
 
apply(K) - Method in class org.infinispan.cache.impl.EncoderKeyMapper
 
apply(K, V) - Method in class org.infinispan.persistence.remote.upgrade.MigrationTask.EntryWriter
 
apply(InvocationContext, C, Object) - Method in interface org.infinispan.interceptors.InvocationSuccessFunction
Process the result from a successful invocation stage and either return a simple value, return a new InvocationStage, or throw an exception.
apply(InvocationContext, C, Object, Throwable) - Method in interface org.infinispan.interceptors.InvocationCallback
Process the result or the exception from an invocation stage and either return a simple value, return a new InvocationStage, or throw an exception.
apply(InvocationContext, C, Object, Throwable) - Method in interface org.infinispan.interceptors.InvocationExceptionFunction
 
apply(InvocationContext, C, Object, Throwable) - Method in interface org.infinispan.interceptors.InvocationFinallyAction
 
apply(InvocationContext, C, Object, Throwable) - Method in interface org.infinispan.interceptors.InvocationSuccessAction
 
apply(InvocationContext, C, Object, Throwable) - Method in interface org.infinispan.interceptors.InvocationSuccessFunction
 
apply(InvocationContext, C, Throwable) - Method in interface org.infinispan.interceptors.InvocationExceptionFunction
Process the result from a successful invocation stage and either return a simple value, return a new InvocationStage, or throw an exception.
apply(EntryView.ReadWriteEntryView<CacheXid, TxState>) - Method in class org.infinispan.server.hotrod.tx.table.functions.ConditionalMarkAsRollbackFunction
 
apply(EntryView.ReadWriteEntryView<CacheXid, TxState>) - Method in class org.infinispan.server.hotrod.tx.table.functions.CreateStateFunction
 
apply(EntryView.ReadWriteEntryView<CacheXid, TxState>) - Method in class org.infinispan.server.hotrod.tx.table.functions.PreparingDecisionFunction
 
apply(EntryView.ReadWriteEntryView<CacheXid, TxState>) - Method in class org.infinispan.server.hotrod.tx.table.functions.SetCompletedTransactionFunction
 
apply(EntryView.ReadWriteEntryView<CacheXid, TxState>) - Method in class org.infinispan.server.hotrod.tx.table.functions.SetDecisionFunction
 
apply(EntryView.ReadWriteEntryView<CacheXid, TxState>) - Method in class org.infinispan.server.hotrod.tx.table.functions.SetPreparedFunction
 
apply(EmbeddedCacheManager) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerRemoveCallable
 
apply(EmbeddedCacheManager) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerReplicateCallable
 
apply(EmbeddedCacheManager) - Method in class org.infinispan.persistence.remote.upgrade.AddSourceRemoteStoreTask
 
apply(EmbeddedCacheManager) - Method in class org.infinispan.persistence.remote.upgrade.CheckRemoteStoreTask
 
apply(EmbeddedCacheManager) - Method in class org.infinispan.persistence.remote.upgrade.DisconnectRemoteStoreTask
 
apply(EmbeddedCacheManager) - Method in class org.infinispan.persistence.remote.upgrade.MigrationTask
 
apply(EmbeddedCacheManager) - Method in class org.infinispan.rest.distribution.CacheDistributionRunnable
 
apply(SegmentPublisherSupplier.Notification<CacheEntry<K, V>>) - Method in interface org.infinispan.notifications.cachelistener.QueueingSegmentListener
This should be invoked on a notification before actually processing the data.
apply(Publisher<Object>) - Method in class org.infinispan.stream.impl.CacheIntermediatePublisher
 
apply(Publisher<Object>) - Method in class org.infinispan.stream.impl.CacheStreamIntermediateReducer
 
apply(T) - Method in class org.infinispan.cache.impl.EncoderEntryMapper
 
apply(T) - Method in interface org.infinispan.commons.dataconversion.internal.Json.Function
Applies this function to the given argument.
apply(V) - Method in class org.infinispan.cache.impl.EncoderValueMapper
 
APPLY_DELTA - Static variable in interface org.infinispan.commons.marshall.Ids
 
applyAsInt(Object) - Method in interface org.infinispan.distribution.ch.KeyPartitioner
 
applyListener(Caffeine<K, InternalCacheEntry<K, V>>, AbstractInternalDataContainer.DefaultEvictionListener) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
applyState(XSiteState[]) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateConsumer
It applies state from other site.
applyState(XSiteState[]) - Method in class org.infinispan.xsite.statetransfer.XSiteStateConsumerImpl
 
applyTo(BlockHound.Builder) - Method in class org.infinispan.commons.internal.CommonsBlockHoundIntegration
 
applyTo(BlockHound.Builder) - Method in class org.infinispan.lock.impl.ClusteredLockBlockHoundIntegration
 
applyTo(BlockHound.Builder) - Method in class org.infinispan.persistence.remote.internal.RemoteStoreBlockHoundIntegration
 
applyTo(BlockHound.Builder) - Method in class org.infinispan.persistence.rocksdb.internal.RocksDBBlockHoundIntegration
 
applyTo(BlockHound.Builder) - Method in class org.infinispan.query.internal.QueryBlockHoundIntegration
 
applyTo(BlockHound.Builder) - Method in class org.infinispan.rest.ServerRestBlockHoundIntegration
 
applyTo(BlockHound.Builder) - Method in class org.infinispan.server.core.ServerCoreBlockHoundIntegration
 
applyTo(BlockHound.Builder) - Method in class org.infinispan.server.hotrod.ServerHotRodBlockHoundIntegration
 
applyTo(BlockHound.Builder) - Method in class org.infinispan.util.CoreBlockHoundIntegration
 
applyVersion(Metadata, Metadata) - Static method in class org.infinispan.metadata.Metadatas
Applies version in source metadata to target metadata, if no version in target metadata.
APPROXIMATE_ENTRIES - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Approximate current number of entry replicas in the cache on the server that receives the request.
APPROXIMATE_ENTRIES_UNIQUE - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Approximate current number of entries for which the server that receives the request is the primary owner.
approximateSize(Predicate<? super StoreConfiguration>, IntSet) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
 
approximateSize(IntSet) - Method in class org.infinispan.persistence.async.AsyncNonBlockingStore
 
approximateSize(IntSet) - Method in class org.infinispan.persistence.file.SingleFileStore
 
approximateSize(IntSet) - Method in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
 
approximateSize(IntSet) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
approximateSize(IntSet) - Method in class org.infinispan.persistence.remote.RemoteStore
 
approximateSize(IntSet) - Method in class org.infinispan.persistence.rocksdb.RocksDBStore
 
approximateSize(IntSet) - Method in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
 
approximateSize(IntSet) - Method in interface org.infinispan.persistence.spi.NonBlockingStore
Returns an estimation of the amount of entries that map to the given segments in the store.
approximateSize(IntSet) - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
 
approximateSize(IntSet) - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
 
array() - Static method in class org.infinispan.commons.dataconversion.internal.Json
 
array() - Method in class org.infinispan.commons.dataconversion.internal.Json.DefaultFactory
 
array() - Method in interface org.infinispan.commons.dataconversion.internal.Json.Factory
Construct and return a JSON object.
array(ByteBuf) - Static method in class org.infinispan.server.hotrod.Intrinsics
 
array(Object...) - Static method in class org.infinispan.commons.dataconversion.internal.Json
Return a new JSON array filled up with the list of arguments.
ArrayCollector - Class in org.infinispan.commons.util
 
ArrayCollector(Object[]) - Constructor for class org.infinispan.commons.util.ArrayCollector
 
ArrayMap<K,V> - Class in org.infinispan.commons.util
Base for classes that implement hash map by storing keys in one array and values in another.
ArrayMap() - Constructor for class org.infinispan.commons.util.ArrayMap
 
ARRAYS - Static variable in interface org.infinispan.commons.marshall.Ids
 
arraysEqual(byte[], int, int, byte[], int, int) - Static method in class org.infinispan.commons.util.Util
This method is to be replaced by Java 9 Arrays#equals with the same arguments.
ARRIVAL_RATE - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
 
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 - Enum constant in enum org.infinispan.query.dsl.SortOrder
Deprecated.
 
asChar() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
asCompletionException(Throwable) - Static method in class org.infinispan.commons.util.concurrent.CompletableFutures
 
asCounterManager(RemoteCacheManager) - Static method in class org.infinispan.client.hotrod.RemoteCounterManagerFactory
 
asCounterManager(EmbeddedCacheManager) - Static method in class org.infinispan.counter.EmbeddedCounterManagerFactory
 
asDouble() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
asDoubleStream() - Method in interface org.infinispan.IntCacheStream
asDoubleStream() - Method in interface org.infinispan.LongCacheStream
asDoubleStream() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
asDoubleStream() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
asDoubleStream() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
asDoubleStream() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
asExecutor(String) - Method in interface org.infinispan.util.concurrent.BlockingManager
Returns an executor that will run the given tasks on a blocking thread as required.
asExecutor(String) - Method in class org.infinispan.util.concurrent.BlockingManagerImpl
 
asFloat() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
asInteger() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
asIterator(Traversable<T>) - Static method in class org.infinispan.functional.impl.Traversables
 
asJsonList() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
asJsonMap() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
asList() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
asLong() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
asLongStream() - Method in interface org.infinispan.IntCacheStream
asLongStream() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
asLongStream() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
asMap() - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader
 
asMap() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
asPrepareResponse(Object) - Static method in class org.infinispan.remoting.responses.PrepareResponse
 
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
 
assertBatchingSupported(Configuration) - Static method in class org.infinispan.batch.AutoBatchSupport
 
assertCorrectlyConfigured() - Method in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
 
assertKeyNotNull(Object) - Static method in class org.infinispan.commons.util.AbstractMap
 
assertNotNullEntries(Collection<?>, String) - Static method in class org.infinispan.commons.util.InfinispanCollections
 
assertNotNullEntries(Map<?, ?>, String) - Static method in class org.infinispan.commons.util.InfinispanCollections
 
assertRemoteCacheManagerIsStarted() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
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
 
assignOwner(int, int, int, int[]) - Method in class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory.Builder
 
asString() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
asString() - Method in class org.infinispan.rest.ByteBufContentSource
 
asString() - Method in interface org.infinispan.rest.framework.ContentSource
 
asThreadPoolConfigurationBuilder() - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
 
asThreadPoolConfigurationBuilder() - Method in class org.infinispan.configuration.global.CachedThreadPoolConfigurationBuilder
 
asThreadPoolConfigurationBuilder() - Method in class org.infinispan.configuration.global.ScheduledThreadPoolConfigurationBuilder
 
asThreadPoolConfigurationBuilder() - Method in interface org.infinispan.configuration.global.ThreadPoolBuilderAdapter
 
async - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
async() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
Configuration for the async cache loader.
async() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
Configuration for the async cache store.
async() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
 
async() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
Configuration for the async cache loader.
async() - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
Configuration for the async cache store.
ASYNC - Enum constant in enum org.infinispan.configuration.cache.BackupConfiguration.BackupStrategy
 
ASYNC - Enum constant in enum org.infinispan.configuration.parsing.CacheParser.Mode
 
ASYNC - Enum constant in enum org.infinispan.configuration.parsing.Element
 
ASYNC - Enum constant in enum org.infinispan.expiration.TouchMode
Send touch commands to other owners, but do not wait for their confirmation.
ASYNC - Enum constant in enum org.infinispan.functional.Param.ReplicationMode
Invoking node does not know when the owners are updated nor if the command fails.
ASYNC_COMPLETE_NOTIFY_TIME - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
 
ASYNC_EXECUTOR - Enum constant in enum org.infinispan.configuration.parsing.Attribute
Deprecated, for removal: This API element is subject to removal in a future version.
ASYNC_EXECUTOR - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
 
ASYNC_EXECUTOR_FACTORY - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
ASYNC_MARSHALLING - Enum constant in enum org.infinispan.configuration.parsing.Attribute
Deprecated, for removal: This API element is subject to removal in a future version.
ASYNC_NOTIFICATION_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
ASYNC_TRANSPORT_EXECUTOR - Enum constant in enum org.infinispan.persistence.remote.configuration.Element
 
asyncAfterCompletion(int) - Method in interface org.infinispan.commons.tx.AsyncSynchronization
 
asyncAfterCompletion(int) - Method in class org.infinispan.transaction.synchronization.SynchronizationAdapter
 
asyncBackOff() - Method in interface org.infinispan.util.ExponentialBackOff
It returns a CompletionStage which is completed a certain amount of time before retries the request.
asyncBackOff() - Method in class org.infinispan.util.ExponentialBackOffImpl
 
asyncBackups(Configuration) - Static method in class org.infinispan.xsite.irac.DefaultIracManager
 
asyncBackupsStream() - Method in class org.infinispan.configuration.cache.SitesConfiguration
 
asyncBeforeCompletion() - Method in interface org.infinispan.commons.tx.AsyncSynchronization
 
asyncBeforeCompletion() - Method in class org.infinispan.transaction.synchronization.SynchronizationAdapter
 
AsyncCache<K,V> - Interface in org.infinispan.commons.api
AsyncCache.
asyncCommit(XidImpl, boolean) - Method in interface org.infinispan.commons.tx.AsyncXaResource
 
asyncCommit(XidImpl, boolean) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
asyncEnd(XidImpl, int) - Method in interface org.infinispan.commons.tx.AsyncXaResource
 
asyncEnd(XidImpl, int) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
asyncExecutor(String) - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
 
asyncExecutorFactory() - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
asyncExecutorFactory() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
asyncExecutorFactory() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
asyncExecutorFactory() - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Configuration for the executor service used for asynchronous work on the Transport, including asynchronous marshalling and Cache 'async operations' such as Cache.putAsync().
asyncExecutorFactory() - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
asyncExecutorFactory() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
asyncExecutorFactory() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
asyncExecutorFactory() - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
Configuration for the executor service used for asynchronous work on the Transport, including asynchronous marshalling and Cache 'async operations' such as Cache.putAsync().
ASYNCHRONOUS - Enum constant in enum org.infinispan.remoting.rpc.ResponseMode
 
Asynchronous operations - Search tag in interface org.infinispan.Cache
Section
asyncInterceptor() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
AsyncInterceptor - Interface in org.infinispan.interceptors
Interface for sequential interceptors.
AsyncInterceptorChain - Interface in org.infinispan.interceptors
Interceptor chain using AsyncInterceptors.
asyncInvokeNext(InvocationContext, VisitableCommand, Collection<? extends CompletionStage<?>>) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
Suspend invocation until all delays complete, then if successful invoke the next interceptor.
asyncInvokeNext(InvocationContext, VisitableCommand, CompletionStage<?>) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
Suspend the invocation until delay completes, then if successful invoke the next interceptor.
asyncInvokeNext(InvocationContext, VisitableCommand, InvocationStage) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
Suspend the invocation until invocationStage completes, then if successful invoke the next interceptor.
asyncMassIndexerStarted() - Method in interface org.infinispan.rest.logging.Log
 
asyncMassIndexerSuccess() - Method in interface org.infinispan.rest.logging.Log
 
AsyncNonBlockingStore<K,V> - Class in org.infinispan.persistence.async
A delegating NonBlockingStore implementation that batches write operations and runs the resulting batches on the delegate store in a non overlapping manner.
AsyncNonBlockingStore(NonBlockingStore<K, V>) - Constructor for class org.infinispan.persistence.async.AsyncNonBlockingStore
 
asyncPrepare(XidImpl) - Method in interface org.infinispan.commons.tx.AsyncXaResource
 
asyncPrepare(XidImpl) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
asyncProcessor - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl
 
AsyncProviderState - Class in org.infinispan.xsite.statetransfer
A XSiteStateProviderState for asynchronous cross-site replication state transfer (IRAC).
asyncRollback(XidImpl) - Method in interface org.infinispan.commons.tx.AsyncXaResource
 
asyncRollback(XidImpl) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
AsyncStoreConfiguration - Class in org.infinispan.configuration.cache
Configuration for the async cache store.
AsyncStoreConfiguration(AttributeSet) - Constructor for class org.infinispan.configuration.cache.AsyncStoreConfiguration
 
AsyncStoreConfigurationBuilder<S> - Class in org.infinispan.configuration.cache
Configuration for the async cache store.
AsyncSynchronization - Interface in org.infinispan.commons.tx
Non-blocking Synchronization.
asyncThreadPool() - Method in class org.infinispan.configuration.global.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.GlobalJmxStatisticsConfigurationBuilder
 
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.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 org.infinispan.reactive.publisher.impl.DeliveryGuarantee
The in between guarantee that provides a view of all data, but may return duplicates during a toplogy change.
AT_MOST_ONCE - Enum constant in enum org.infinispan.reactive.publisher.impl.DeliveryGuarantee
The least strict guarantee that ensures that data is never read more than once, but may be missed.
atDel(int) - Method in class org.infinispan.commons.dataconversion.internal.Json
Remove the element at the specified index from a Json array and return that element.
atDel(String) - Method in class org.infinispan.commons.dataconversion.internal.Json
Remove the specified property from a Json object and return that property.
ATOMIC_FINE_GRAINED_MAP_FUNCTIONS - Static variable in interface org.infinispan.commons.marshall.Ids
 
ATOMIC_KEY_SET - Static variable in interface org.infinispan.commons.marshall.Ids
 
ATOMIC_MAP_FUNCTIONS - Static variable in interface org.infinispan.commons.marshall.Ids
 
attachFactory(Json.Factory) - Static method in class org.infinispan.commons.dataconversion.internal.Json
Attach a thread-local Json Json.Factory to be used specifically by this thread.
attachTo(Json) - Method in class org.infinispan.commons.dataconversion.internal.Json
Explicitly set the parent of this element.
attribute(Enum<?>) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
Returns the named attribute
attribute(String) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
Returns the named attribute
attribute(AttributeDefinition<T>) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
Returns the attribute identified by the supplied AttributeDefinition
Attribute<T> - Class in org.infinispan.commons.configuration.attributes
Attribute.
Attribute - Enum in org.infinispan.configuration.parsing
Enumerates the attributes used in Infinispan
Attribute - Enum in org.infinispan.counter.configuration
 
Attribute - Enum in org.infinispan.lock.configuration
 
Attribute - Enum in org.infinispan.persistence.jdbc.common.configuration
Enumerates the attributes used by the JDBC cache stores configuration
Attribute - Enum in org.infinispan.persistence.remote.configuration
Enumerates the attributes used by the Remote cache store configuration
Attribute - Enum in org.infinispan.persistence.rocksdb.configuration
Enumerates the attributes used by the LevelDB cache stores configuration
Attribute - Enum in org.infinispan.server.hotrod.configuration
 
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.configuration.cache.AbstractStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.ClusterLoaderConfiguration
Deprecated.
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.Configuration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.ContentTypeConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.CustomStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.MemoryStorageConfiguration
Deprecated.
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.ExecutorFactoryConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.GlobalStateConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.GlobalStatePathConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.GlobalStorageConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.JGroupsConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.PrincipalRoleMapperConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.RolePermissionMapperConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.StackConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.StackFileConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.TemporaryGlobalStatePathConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.counter.configuration.StrongCounterConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.counter.configuration.WeakCounterConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.rocksdb.configuration.RocksDBExpirationConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.sifs.configuration.DataConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.sifs.configuration.IndexConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.rest.configuration.AuthenticationConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.rest.configuration.CorsRuleConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.rest.configuration.RestServerConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.core.configuration.EncryptionConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.core.configuration.SniConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.core.configuration.SslConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.hotrod.configuration.AuthenticationConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.hotrod.configuration.SaslConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.hotrod.configuration.TopologyCacheConfiguration
 
attributeDefinitionSet() - Static method in class org.infinispan.server.memcached.configuration.MemcachedServerConfiguration
 
AttributeInitializer<T> - Interface in org.infinispan.commons.configuration.attributes
AttributeInitializer.
AttributeListener<T> - Interface in org.infinispan.commons.configuration.attributes
An AttributeListener will be invoked whenever an attribute has been modified.
AttributeMetadata(String, String, boolean, boolean, String, boolean, Function<?, ?>, BiConsumer<?, ?>) - Constructor for class org.infinispan.factories.impl.MBeanMetadata.AttributeMetadata
 
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.AbstractStoreConfiguration
 
attributes - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
attributes - Variable in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
attributes - Variable in class org.infinispan.persistence.jdbc.common.configuration.AbstractUnmanagedConnectionFactoryConfiguration
 
attributes - Variable in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
attributes - Variable in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.ClusterConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.NearCacheConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.SecurityConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.ServerConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.StatisticsConfiguration
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.StatisticsConfigurationBuilder
 
attributes() - Method in class org.infinispan.client.hotrod.configuration.TransactionConfigurationBuilder
Deprecated.
 
attributes() - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
 
attributes() - Method in class org.infinispan.commons.configuration.attributes.ConfigurationElement
 
attributes() - Method in interface org.infinispan.commons.configuration.Builder
 
attributes() - Method in class org.infinispan.commons.configuration.Combine
 
attributes() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.ClusterLoaderConfiguration
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfiguration
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.IndexReaderConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.MemoryStorageConfiguration
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.cache.MemoryStorageConfigurationBuilder
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.QueryConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.SecurityConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.SecurityConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.StatisticsConfigurationBuilder
 
attributes() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
 
attributes() - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.AllowListConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.AllowListConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.CachedThreadPoolConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.GlobalJmxConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.GlobalJmxConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.GlobalMetricsConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.GlobalMetricsConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.GlobalSecurityConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.GlobalStatePathConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.GlobalStatePathConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.GlobalStorageConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.GlobalStorageConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.JGroupsConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.JGroupsConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.PrincipalRoleMapperConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.PrincipalRoleMapperConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.RolePermissionMapperConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.RolePermissionMapperConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.ScheduledThreadPoolConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.SerializationConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.ShutdownConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.global.StackConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.StackConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.StackFileConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.TemporaryGlobalStatePathConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.TemporaryGlobalStatePathConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.ThreadFactoryConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
attributes() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
attributes() - Method in class org.infinispan.configuration.global.WhiteListConfiguration
Deprecated.
 
attributes() - Method in class org.infinispan.configuration.global.WhiteListConfigurationBuilder
Deprecated.
 
attributes() - Method in class org.infinispan.counter.configuration.AbstractCounterConfiguration
 
attributes() - Method in class org.infinispan.counter.configuration.CounterManagerConfigurationBuilder
 
attributes() - Method in class org.infinispan.counter.configuration.StrongCounterConfigurationBuilder
 
attributes() - Method in class org.infinispan.counter.configuration.WeakCounterConfigurationBuilder
 
attributes() - Method in class org.infinispan.lock.configuration.ClusteredLockConfigurationBuilder
 
attributes() - Method in class org.infinispan.lock.configuration.ClusteredLockManagerConfigurationBuilder
 
attributes() - Method in class org.infinispan.metrics.config.MicrometerMeterRegisterConfigurationBuilder
 
attributes() - Method in 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.AuthenticationConfiguration
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfiguration
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfiguration
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.MechanismConfiguration
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.MechanismConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfiguration
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.TrustStoreConfiguration
 
attributes() - Method in class org.infinispan.persistence.remote.configuration.TrustStoreConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBExpirationConfiguration
 
attributes() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBExpirationConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfiguration
 
attributes() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.sifs.configuration.DataConfiguration
 
attributes() - Method in class org.infinispan.persistence.sifs.configuration.DataConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.sifs.configuration.IndexConfiguration
 
attributes() - Method in class org.infinispan.persistence.sifs.configuration.IndexConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfigurationBuilder
 
attributes() - Method in class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfigurationBuilder
 
attributes() - Method in class org.infinispan.rest.configuration.AuthenticationConfigurationBuilder
 
attributes() - Method in class org.infinispan.rest.configuration.CorsConfigurationBuilder
 
attributes() - Method in class org.infinispan.rest.configuration.CorsRuleConfigurationBuilder
 
attributes() - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
 
attributes() - Method in class org.infinispan.security.impl.CreatePermissionConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.core.configuration.EncryptionConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.core.configuration.IpFilterConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.core.configuration.SniConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.core.configuration.SslEngineConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfiguration
 
attributes() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.hotrod.configuration.SaslConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.hotrod.configuration.TopologyCacheConfigurationBuilder
 
attributes() - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
 
AttributeSerializer<T> - Interface in org.infinispan.commons.configuration.attributes
AttributeSerializer.
attributeSet() - Static method in class org.infinispan.commons.configuration.AbstractTypedPropertiesConfiguration
 
attributeSet() - Static method in class org.infinispan.persistence.jdbc.common.configuration.AbstractUnmanagedConnectionFactoryConfiguration
 
attributeSet() - Static method in class org.infinispan.persistence.jdbc.common.configuration.ManagedConnectionFactoryConfiguration
 
attributeSet() - Static method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfiguration
 
AttributeSet - Class in org.infinispan.commons.configuration.attributes
AttributeSet is a container for Attributes.
AttributeSet(Class<?>, Enum<?>, AttributeDefinition<?>...) - Constructor for class org.infinispan.commons.configuration.attributes.AttributeSet
 
AttributeSet(Class<?>, String, AttributeSet, AttributeDefinition<?>[]) - Constructor for class org.infinispan.commons.configuration.attributes.AttributeSet
 
AttributeSet(Class<?>, String, AttributeSet, AttributeDefinition<?>[], AttributeSet.RemovedAttribute[]) - Constructor for class org.infinispan.commons.configuration.attributes.AttributeSet
 
AttributeSet(Class<?>, AttributeDefinition<?>...) - Constructor for class org.infinispan.commons.configuration.attributes.AttributeSet
 
AttributeSet(Class<?>, AttributeSet, AttributeDefinition<?>...) - Constructor for class org.infinispan.commons.configuration.attributes.AttributeSet
 
AttributeSet(String, AttributeDefinition<?>...) - Constructor for class org.infinispan.commons.configuration.attributes.AttributeSet
 
AttributeSet(String, AttributeSet, AttributeDefinition<?>[]) - Constructor for class org.infinispan.commons.configuration.attributes.AttributeSet
 
AttributeSet.RemovedAttribute - Class in org.infinispan.commons.configuration.attributes
 
attributeUri - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
AttributeValidator<T> - Interface in org.infinispan.commons.configuration.attributes
AttributeValidator.
attributeValue - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
audit(Subject, AuditContext, String, AuthorizationPermission, AuditResponse) - Method in class org.infinispan.security.audit.LoggingAuditLogger
 
audit(Subject, AuditContext, String, AuthorizationPermission, AuditResponse) - Method in class org.infinispan.security.audit.NullAuditLogger
 
audit(Subject, AuditContext, String, AuthorizationPermission, AuditResponse) - Method in interface org.infinispan.security.AuditLogger
 
AUDIT_LOGGER - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
AUDIT_LOGGER - Static variable in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
auditContext() - Method in class org.infinispan.rest.framework.impl.InvocationImpl
 
auditContext() - Method in interface org.infinispan.rest.framework.Invocation
 
auditContext(AuditContext) - Method in class org.infinispan.rest.framework.impl.InvocationImpl.Builder
 
AuditContext - Enum in org.infinispan.security
AuditContext.
auditLogger() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
auditLogger(AuditLogger) - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
The instance of an AuditLogger to be used to track operations performed on caches and cachemanagers.
AuditLogger - Interface in org.infinispan.security
AuditLogger.
auditMessage(AuditResponse, Principal, AuthorizationPermission, AuditContext, String) - Method in interface org.infinispan.security.impl.AuditMessages
 
AuditMessages - Interface in org.infinispan.security.impl
AuditMessages.
AuditResponse - Enum in org.infinispan.security
 
auth - Variable in class org.infinispan.server.hotrod.HotRodDecoder
 
auth(HotRodHeader, String, byte[]) - Method in class org.infinispan.server.hotrod.Authentication
 
AUTH - Enum constant in enum org.infinispan.client.hotrod.configuration.SaslQop
 
AUTH - Enum constant in enum org.infinispan.server.hotrod.configuration.QOP
 
AUTH - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
AUTH_CALLBACK_HANDLER - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
AUTH_CLIENT_SUBJECT - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
AUTH_CONF - Enum constant in enum org.infinispan.client.hotrod.configuration.SaslQop
 
AUTH_CONF - Enum constant in enum org.infinispan.server.hotrod.configuration.QOP
 
AUTH_DIGEST - Enum constant in enum org.infinispan.persistence.remote.configuration.Element
 
AUTH_EXTERNAL - Enum constant in enum org.infinispan.persistence.remote.configuration.Element
 
AUTH_INT - Enum constant in enum org.infinispan.client.hotrod.configuration.SaslQop
 
AUTH_INT - Enum constant in enum org.infinispan.server.hotrod.configuration.QOP
 
AUTH_MECH_LIST - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
AUTH_MECH_LIST_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
AUTH_PASSWORD - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
AUTH_PLAIN - Enum constant in enum org.infinispan.persistence.remote.configuration.Element
 
AUTH_REALM - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
AUTH_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
AUTH_SERVER_NAME - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
AUTH_TOKEN - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
AUTH_USERNAME - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
authenticate(String) - Method in class org.infinispan.rest.NettyRestResponse.Builder
 
authenticate(String, String) - Method in interface org.infinispan.rest.authentication.SecurityDomain
Returns Subject based on user/password combination.
authentication() - Method in class org.infinispan.client.hotrod.configuration.AbstractSecurityConfigurationChildBuilder
 
authentication() - Method in class org.infinispan.client.hotrod.configuration.SecurityConfiguration
 
authentication() - Method in class org.infinispan.client.hotrod.configuration.SecurityConfigurationBuilder
 
authentication() - Method in class org.infinispan.persistence.remote.configuration.AbstractSecurityConfigurationChildBuilder
 
authentication() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfiguration
 
authentication() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfigurationBuilder
 
authentication() - Method in class org.infinispan.rest.configuration.RestServerConfiguration
 
authentication() - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
 
authentication() - Method in class org.infinispan.server.hotrod.configuration.AbstractHotRodServerChildConfigurationBuilder
 
authentication() - Method in interface org.infinispan.server.hotrod.configuration.HotRodServerChildConfigurationBuilder
Configures authentication for this endpoint
authentication() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
 
authentication() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
 
Authentication - Class in org.infinispan.server.hotrod
Handler that when added will make sure authentication is applied to requests.
Authentication(Channel, Executor, HotRodServer) - Constructor for class org.infinispan.server.hotrod.Authentication
 
AUTHENTICATION - Enum constant in enum org.infinispan.persistence.remote.configuration.Element
 
AUTHENTICATION - Enum constant in enum org.infinispan.server.hotrod.configuration.Element
 
AuthenticationConfiguration - Class in org.infinispan.client.hotrod.configuration
AuthenticationConfiguration.
AuthenticationConfiguration - Class in org.infinispan.persistence.remote.configuration
AuthenticationConfiguration.
AuthenticationConfiguration - Class in org.infinispan.rest.configuration
AuthenticationConfiguration.
AuthenticationConfiguration - Class in org.infinispan.server.hotrod.configuration
AuthenticationConfiguration.
AuthenticationConfiguration(CallbackHandler, Subject, boolean, String, Map<String, String>, String) - Constructor for class org.infinispan.client.hotrod.configuration.AuthenticationConfiguration
 
AuthenticationConfiguration(AttributeSet, MechanismConfiguration) - Constructor for class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
 
AuthenticationConfigurationBuilder - Class in org.infinispan.client.hotrod.configuration
AuthenticationConfigurationBuilder.
AuthenticationConfigurationBuilder - Class in org.infinispan.persistence.remote.configuration
AuthenticationConfigurationBuilder.
AuthenticationConfigurationBuilder - Class in org.infinispan.rest.configuration
AuthenticationConfigurationBuilder.
AuthenticationConfigurationBuilder - Class in org.infinispan.server.hotrod.configuration
AuthenticationConfigurationBuilder.
AuthenticationConfigurationBuilder(SecurityConfigurationBuilder) - Constructor for class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
 
AuthenticationConfigurationBuilder(SecurityConfigurationBuilder) - Constructor for class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
 
authenticationException(Throwable) - Method in interface org.infinispan.server.hotrod.logging.Log
 
authenticationWithoutAuthenticator() - Method in interface org.infinispan.rest.logging.Log
 
authenticator() - Method in class org.infinispan.rest.configuration.AuthenticationConfiguration
 
authenticator(Authenticator) - Method in class org.infinispan.rest.configuration.AuthenticationConfigurationBuilder
 
Authenticator - Interface in org.infinispan.rest.authentication
Authentication mechanism.
authMechList(HotRodHeader) - Method in class org.infinispan.server.hotrod.Authentication
 
authMechListResponse(HotRodHeader, HotRodServer, Channel, Set<String>) - Method in class org.infinispan.server.hotrod.Encoder4x
 
authMechListResponse(HotRodHeader, HotRodServer, Channel, Set<String>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
 
authorization() - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
authorization() - Method in class org.infinispan.configuration.cache.SecurityConfiguration
 
authorization() - Method in class org.infinispan.configuration.cache.SecurityConfigurationBuilder
 
authorization() - Method in interface org.infinispan.configuration.cache.SecurityConfigurationChildBuilder
 
authorization() - Method in class org.infinispan.configuration.global.GlobalSecurityConfiguration
 
authorization() - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
 
authorization() - Method in interface org.infinispan.configuration.global.GlobalSecurityConfigurationChildBuilder
Defines global roles as groups of permissions
AUTHORIZATION - Enum constant in enum org.infinispan.configuration.parsing.Element
 
AUTHORIZATION - Enum constant in enum org.infinispan.rest.RequestHeader
 
AUTHORIZATION_PERMISSION - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
AuthorizationConfiguration - Class in org.infinispan.configuration.cache
AuthorizationConfiguration.
AuthorizationConfigurationBuilder - Class in org.infinispan.configuration.cache
AuthorizationConfigurationBuilder.
AuthorizationConfigurationBuilder(SecurityConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
AuthorizationManager - Interface in org.infinispan.security
The AuthorizationManager is a cache-scoped component which verifies that the Subject associated with the current AccessControlContext, or explicitly specified, has the requested permissions.
AuthorizationManagerFactory - Class in org.infinispan.factories
 
AuthorizationManagerFactory() - Constructor for class org.infinispan.factories.AuthorizationManagerFactory
 
AuthorizationManagerImpl - Class in org.infinispan.security.impl
AuthorizationManagerImpl.
AuthorizationManagerImpl() - Constructor for class org.infinispan.security.impl.AuthorizationManagerImpl
 
AuthorizationMapperContext - Interface in org.infinispan.security
 
AuthorizationMapperContextImpl - Class in org.infinispan.security.impl
PrincipalRoleMapperContextImpl.
AuthorizationMapperContextImpl(EmbeddedCacheManager) - Constructor for class org.infinispan.security.impl.AuthorizationMapperContextImpl
 
authorizationNotEnabled() - Method in interface org.infinispan.rest.logging.Log
 
AuthorizationPermission - Enum in org.infinispan.security
AuthorizationPermission.
AuthorizationPermission$___Marshaller_e4a67ef18a1f2ebc30b0d1e396f24e2098535911da768fa734361c9903b14240 - Class in org.infinispan.security
 
AuthorizationPermission$___Marshaller_e4a67ef18a1f2ebc30b0d1e396f24e2098535911da768fa734361c9903b14240() - Constructor for class org.infinispan.security.AuthorizationPermission$___Marshaller_e4a67ef18a1f2ebc30b0d1e396f24e2098535911da768fa734361c9903b14240
 
Authorizer - Class in org.infinispan.security.impl
Authorizer.
Authorizer(GlobalSecurityConfiguration, AuditContext, String, Map<CacheSubjectPair, SubjectACL>) - Constructor for class org.infinispan.security.impl.Authorizer
 
AuthorizingCallbackHandler - Interface in org.infinispan.server.core.security
AuthorizingCallbackHandler.
authResponse(HotRodHeader, HotRodServer, Channel, byte[]) - Method in class org.infinispan.server.hotrod.Encoder4x
 
authResponse(HotRodHeader, HotRodServer, Channel, byte[]) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
 
AUTO - Enum constant in enum org.infinispan.configuration.cache.IndexStartupMode
With this configuration Infinispan will try to run the right action to align cache data and indexes.
AUTO - Enum constant in enum org.infinispan.configuration.cache.XSiteStateTransferMode
Cross-site state transfer is triggered automatically.
AUTO_COMMIT - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
AUTO_COMMIT - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
 
AUTO_CONFIG - Enum constant in enum org.infinispan.configuration.parsing.Attribute
Deprecated, for removal: This API element is subject to removal in a future version.
AUTO_CONFIG - Static variable in class org.infinispan.configuration.cache.IndexingConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
since 11.0
AutoBatchSupport - Class in org.infinispan.batch
Enables for automatic batching.
AutoBatchSupport() - Constructor for class org.infinispan.batch.AutoBatchSupport
 
autoCommit - Variable in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations.FlowableConnection
 
autoCommit() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
If the cache is transactional (i.e.
autoCommit(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
If the cache is transactional (i.e.
autoConfig() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
Since 11.0, with no replacement.
autoConfig() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 11.0, with no replacement.
autoConfig(boolean) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 11.0 with no replacement.
AutoInstantiableFactory - Interface in org.infinispan.factories
Component factories that implement this interface can be instantiated automatically by component registries when looking up components.
autoPersist(boolean) - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition.Builder
 
AutoStateTransferResponse - Class in org.infinispan.xsite.response
A Response implementation for command XSiteAutoTransferStatusCommand.
AutoStateTransferResponse(boolean, XSiteStateTransferMode) - Constructor for class org.infinispan.xsite.response.AutoStateTransferResponse
 
AutoStateTransferResponseCollector - Class in org.infinispan.xsite.response
AutoStateTransferResponseCollector(boolean, XSiteStateTransferMode, boolean) - Constructor for class org.infinispan.xsite.response.AutoStateTransferResponseCollector
 
AVAILABILITY_INTERVAL - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
AVAILABILITY_INTERVAL - Static variable in class org.infinispan.configuration.cache.PersistenceConfiguration
 
AVAILABILITY_MODE - Static variable in interface org.infinispan.commons.marshall.Ids
 
AvailabilityException - Exception 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
 
AvailabilityMode - Enum in org.infinispan.partitionhandling
 
AvailabilityMode.Externalizer - Class in org.infinispan.partitionhandling
 
AvailabilityStrategy - Interface in org.infinispan.partitionhandling.impl
Implementations decide what to do when the cache membership changes, either because new nodes joined, nodes left, or there was a merge.
AvailabilityStrategyContext - Interface in org.infinispan.partitionhandling.impl
Contains information about the current state of the cache.
available() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
 
available() - Method in interface org.infinispan.configuration.cache.JMXStatisticsConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
since 10.1.3. This method will be removed in a future version.
available() - Method in class org.infinispan.configuration.cache.StatisticsConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
since 10.1.3. This method will be removed in a future version.
available() - Method in class org.infinispan.io.GridInputStream
Deprecated.
 
available() - Method in class org.infinispan.io.UnclosableObjectInputStream
Deprecated.
 
available() - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
 
available(boolean) - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
since 10.1.3. This method will be removed in a future version.
available(boolean) - Method in class org.infinispan.configuration.cache.StatisticsConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
since 10.1.3. This method will be removed in a future version.
AVAILABLE - Enum constant in enum org.infinispan.counter.configuration.Reliability
If the cluster splits in multiple partition, all of them are allowed to continue read/update the counter.
AVAILABLE - Enum constant in enum org.infinispan.lock.configuration.Reliability
 
AVAILABLE - Enum constant in enum org.infinispan.partitionhandling.AvailabilityMode
Regular operation mode
AVAILABLE - Static variable in class org.infinispan.configuration.cache.StatisticsConfiguration
 
AvailablePartitionHandlingManager - Class in org.infinispan.partitionhandling.impl
PartitionHandlingManager implementation when the cluster is always available.
availableProcessors() - Static method in class org.infinispan.commons.jdkspecific.ProcessorInfo
 
availableProcessors() - Static method in class org.infinispan.commons.util.ProcessorInfo
Returns the number of processors available to this process.
average() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
average() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
average() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
average() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
average() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
average() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
avg(String) - Static method in interface org.infinispan.query.dsl.Expression
Deprecated.
 
await() - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
await(long, TimeUnit) - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
await(CompletableFuture<?>, long, TimeUnit) - Static method in class org.infinispan.commons.util.concurrent.CompletableFutures
It waits until the CompletableFuture is completed.
await(CompletableFuture<T>) - Static method in class org.infinispan.client.hotrod.impl.Util
 
await(CompletableFuture<T>) - Static method in class org.infinispan.commons.util.concurrent.CompletableFutures
Wait for a long time until the CompletableFuture is completed.
await(CompletableFuture<T>, long) - Static method in class org.infinispan.client.hotrod.impl.Util
 
await(CompletionStage<T>) - Static method in class org.infinispan.client.hotrod.impl.Util
 
await(CompletionStage<T>) - Static method in class org.infinispan.util.concurrent.CompletionStages
 
AWAIT_INITIAL_RETRIEVAL - Enum constant in enum org.infinispan.server.hotrod.configuration.Attribute
 
AWAIT_INITIAL_TRANSFER - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
AWAIT_INITIAL_TRANSFER - Static variable in class org.infinispan.configuration.cache.StateTransferConfiguration
 
awaitCounterOperation(CompletionStage<T>) - Static method in class org.infinispan.counter.impl.Util
Awaits for the counter operation and throws any exception as CounterException.
awaitInitialTransfer() - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
If true, this will cause the first call to method CacheManager.getCache() on the joiner node to block and wait until the joining is complete and the cache has finished receiving state from neighboring caches (if fetchInMemoryState is enabled).
awaitInitialTransfer() - Method in class org.infinispan.server.hotrod.configuration.TopologyCacheConfiguration
 
awaitInitialTransfer(boolean) - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
If true, this will cause the first call to method CacheManager.getCache() on the joiner node to block and wait until the joining is complete and the cache has finished receiving state from neighboring caches (if fetchInMemoryState is enabled).
awaitInitialTransfer(boolean) - Method in class org.infinispan.server.hotrod.configuration.TopologyCacheConfigurationBuilder
 
awaitPendingTransactionsForAllKeys(TxInvocationContext<?>, Collection<Object>, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultPendingLockManager
 
awaitPendingTransactionsForAllKeys(TxInvocationContext<?>, Collection<Object>, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.NoOpPendingLockManager
 
awaitPendingTransactionsForAllKeys(TxInvocationContext<?>, Collection<Object>, long, TimeUnit) - Method in interface org.infinispan.util.concurrent.locks.PendingLockManager
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, the blocking variants will be removed
awaitPendingTransactionsForKey(TxInvocationContext<?>, Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultPendingLockManager
 
awaitPendingTransactionsForKey(TxInvocationContext<?>, Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.NoOpPendingLockManager
 
awaitPendingTransactionsForKey(TxInvocationContext<?>, Object, long, TimeUnit) - Method in interface org.infinispan.util.concurrent.locks.PendingLockManager
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, the blocking variants will be removed
awaitTermination(long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
awaitTermination(long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
awaitTermination(long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
awaitTermination(long, TimeUnit) - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
 
awaitTermination(long, TimeUnit) - Method in class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
 
awaitTermination(long, TimeUnit) - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
AZURE(Properties) - Static method in class org.infinispan.remoting.transport.jgroups.BuiltinJGroupsChannelConfigurator
 

B

backArrayOffset() - Method in class org.infinispan.commons.marshall.WrappedByteArray
 
backArrayOffset() - Method in interface org.infinispan.commons.marshall.WrappedBytes
The offset of where data starts in the backed array.
backgroundTaskFinished(Callable<T>) - Method in class org.infinispan.executors.SemaphoreCompletionService
Signal that a task that called SemaphoreCompletionService.continueTaskInBackground() has finished and optionally execute another task on the just-freed thread.
backup() - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
backup() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
 
backup() - Method in interface org.infinispan.server.core.backup.ContainerResource
Writes the backup files for the BackupManager.Resources.Type to the local filesystem, where it can then be packaged for distribution.
backup() - Method in class org.infinispan.server.core.backup.resources.CacheResource
 
backup() - Method in class org.infinispan.server.core.backup.resources.CounterResource
 
BACKUP - Enum constant in enum org.infinispan.configuration.parsing.Element
 
BACKUP - Enum constant in enum org.infinispan.distribution.Ownership
this node is the backup owner.
BACKUP_FAILURE_POLICY - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
BACKUP_FOR - Enum constant in enum org.infinispan.configuration.parsing.Element
 
BACKUP_WRITE - Enum constant in enum org.infinispan.context.Flag
Signals that a WriteCommand was sent from the primary as a backup operation.
BACKUP_WRITE - Static variable in class org.infinispan.context.impl.FlagBitSets
 
backupAck(long, Address, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
Acknowledges a write operation completion in the backup owner.
backupAddress - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
backupAlreadyExists(String) - Method in interface org.infinispan.server.core.logging.Log
 
backupComplete(String) - Method in interface org.infinispan.server.core.logging.Log
 
BackupConfiguration - Class in org.infinispan.configuration.cache
 
BackupConfiguration(AttributeSet, TakeOfflineConfiguration, XSiteStateTransferConfiguration) - Constructor for class org.infinispan.configuration.cache.BackupConfiguration
 
BackupConfiguration.BackupStrategy - Enum in org.infinispan.configuration.cache
 
BackupConfigurationBuilder - Class in org.infinispan.configuration.cache
 
BackupConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
backupDeleted(String) - Method in interface org.infinispan.server.core.logging.Log
 
backupDeleteFailed() - Method in interface org.infinispan.rest.logging.Log
 
backupFailed() - Method in interface org.infinispan.rest.logging.Log
 
backupFailurePolicy() - Method in class org.infinispan.configuration.cache.BackupConfiguration
 
backupFailurePolicy(BackupFailurePolicy) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
Configures the policy for handling failed requests.
BackupFailurePolicy - Enum in org.infinispan.configuration.cache
Defines the possible behaviour in case of failure during x-site.
backupFor() - Method in class org.infinispan.configuration.cache.SitesConfiguration
 
backupFor() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
BackupForBuilder - Class in org.infinispan.configuration.cache
 
BackupForBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.BackupForBuilder
 
BackupForConfiguration - Class in org.infinispan.configuration.cache
Defines the remote caches for which this cache acts as a backup.
BackupForConfiguration(AttributeSet) - Constructor for class org.infinispan.configuration.cache.BackupForConfiguration
 
backupFrom(CommandsFactory, ReadWriteKeyCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, ReadWriteKeyValueCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, ReadWriteManyCommand<K, V, R>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, ReadWriteManyEntriesCommand<K, V, T, R>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, WriteOnlyKeyCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, WriteOnlyKeyValueCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, WriteOnlyManyCommand<K, V>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, WriteOnlyManyEntriesCommand<K, V, T>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, ComputeCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, ComputeIfAbsentCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, IracPutKeyValueCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, PutKeyValueCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, PutMapCommand, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, RemoveCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupFrom(CommandsFactory, ReplaceCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
backupInProgress() - Method in interface org.infinispan.server.core.logging.Log
 
BackupManager - Interface in org.infinispan.server.core
Handles all tasks related to the creation/restoration of server backups.
BackupManager.Resources - Interface in org.infinispan.server.core
An interface to encapsulate the various arguments required by the BackupManager in order to include/exclude resources from a backup/restore operation.
BackupManager.Resources.Type - Enum in org.infinispan.server.core
 
BackupManager.Status - Enum in org.infinispan.server.core
An enum representing the current state of a Backup operation.
BackupManagerImpl - Class in org.infinispan.server.core.backup
 
BackupManagerImpl(BlockingManager, DefaultCacheManager, Path) - Constructor for class org.infinispan.server.core.backup.BackupManagerImpl
 
BackupManagerResources - Class in org.infinispan.server.core.backup
 
BackupManagerResources(Map<BackupManager.Resources.Type, Set<String>>) - Constructor for class org.infinispan.server.core.backup.BackupManagerResources
 
BackupManagerResources.Builder - Class in org.infinispan.server.core.backup
 
backupQueue - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
backupRemotely(Collection<XSiteBackup>, XSiteRequest<?>) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
backupRemotely(Collection<XSiteBackup>, XSiteRequest<?>) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
backupRemotely(Collection<XSiteBackup>, XSiteRequest<?>) - Method in interface org.infinispan.remoting.transport.Transport
Deprecated, for removal: This API element is subject to removal in a future version.
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.
BackupResponse - Interface in org.infinispan.remoting.transport
Represents a response from a backup replication call.
backups() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
BACKUPS - Enum constant in enum org.infinispan.configuration.parsing.Element
 
BALANCING_STRATEGY - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
 
balancingStrategy() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
balancingStrategy(Class<? extends FailoverRequestBalancingStrategy>) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
balancingStrategy(Class<? extends FailoverRequestBalancingStrategy>) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
balancingStrategy(Class<? extends FailoverRequestBalancingStrategy>) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
For replicated (vs distributed) Hot Rod server clusters, the client balances requests to the servers according to this strategy.
balancingStrategy(String) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
balancingStrategy(String) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
balancingStrategy(String) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
For replicated (vs distributed) Hot Rod server clusters, the client balances requests to the servers according to this strategy.
balancingStrategy(String) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
balancingStrategy(String) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
balancingStrategy(String) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
For replicated (vs distributed) Hot Rod server clusters, the client balances requests to the servers according to this strategy.
balancingStrategy(Supplier<FailoverRequestBalancingStrategy>) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
balancingStrategy(Supplier<FailoverRequestBalancingStrategy>) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
balancingStrategy(Supplier<FailoverRequestBalancingStrategy>) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
For replicated (vs distributed) Hot Rod server clusters, the client balances requests to the servers according to this strategy.
balancingStrategyFactory() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
BARE_COLLECTIONS - Enum constant in enum org.infinispan.commons.configuration.io.ConfigurationFormatFeature
The underlying format supports collections without the need for wrapping in a container element.
BASE_64 - Static variable in class org.infinispan.commons.dataconversion.MediaType
 
Base16Codec - Class in org.infinispan.commons.dataconversion
 
BaseAsyncInterceptor - Class in org.infinispan.interceptors
Base class for an interceptor in the new asynchronous invocation chain.
BaseAsyncInterceptor() - Constructor for class org.infinispan.interceptors.BaseAsyncInterceptor
 
BaseCacheEntryListenerInvocation(EncoderRegistry, ListenerInvocation<Event<K, V>>, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, ?>, Class<? extends Annotation>, boolean, boolean, UUID, boolean, Listener.Observation, Set<Class<? extends Annotation>>, DataConversion, DataConversion, boolean) - Constructor for class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
BaseCacheListener(Cache<?, ?>) - Constructor for class org.infinispan.rest.resources.CacheResourceV2.BaseCacheListener
 
BaseCacheResource - Class in org.infinispan.rest.resources
Handle basic cache operations.
BaseCacheResource(InvocationHelper, RestTelemetryService) - Constructor for class org.infinispan.rest.resources.BaseCacheResource
 
BaseCacheStream<T,S> - 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
 
BaseExtendedStatisticsContainer - Class in org.infinispan.extendedstats.container
Common logic for the ExtendedStatisticsContainer
BaseExtendedStatisticsContainer(int) - Constructor for class org.infinispan.extendedstats.container.BaseExtendedStatisticsContainer
 
BaseJdbcStore<K,V,C> - 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
 
BaseServerManagement - Class in org.infinispan.server.core
 
BaseServerManagement() - Constructor for class org.infinispan.server.core.BaseServerManagement
 
BaseTableOperations<K,V> - Class in org.infinispan.persistence.jdbc.common.sql
 
BaseTableOperations(int, int, int) - Constructor for class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
 
BaseTableOperations.FlowableConnection - Class in org.infinispan.persistence.jdbc.common.sql
 
BaseTableOperations.ResultSetEntryIterator - Class in org.infinispan.persistence.jdbc.common.sql
 
BaseXSiteStateProviderState<T> - Class in org.infinispan.xsite.statetransfer
Common code for AsyncProviderState and SyncProviderState implementation.
BaseXSiteStateProviderState(XSiteBackup, XSiteStateTransferConfiguration) - Constructor for class org.infinispan.xsite.statetransfer.BaseXSiteStateProviderState
 
BASIC - Enum constant in enum org.infinispan.client.hotrod.configuration.ClientIntelligence
 
BasicAuthenticator - Class in org.infinispan.rest.authentication.impl
BASIC authentication mechanism.
BasicAuthenticator(SecurityDomain, String) - Constructor for class org.infinispan.rest.authentication.impl.BasicAuthenticator
 
BasicCache<K,V> - Interface in org.infinispan.commons.api
BasicCache provides the common building block for the two different types of caches that Infinispan provides: embedded and remote.
BasicCacheContainer - Interface in org.infinispan.commons.api
BasicCacheContainer defines the methods used to obtain a BasicCache.
BasicCallbackHandler - Class in org.infinispan.client.hotrod.security
BasicCallbackHandler() - Constructor for class org.infinispan.client.hotrod.security.BasicCallbackHandler
 
BasicCallbackHandler(String, char[]) - Constructor for class org.infinispan.client.hotrod.security.BasicCallbackHandler
 
BasicCallbackHandler(String, String, char[]) - Constructor for class org.infinispan.client.hotrod.security.BasicCallbackHandler
 
basicComponentRegistry - Variable in class org.infinispan.factories.AbstractNamedCacheComponentFactory
 
basicComponentRegistry - Variable in class org.infinispan.server.core.factories.NettyIOFactory
 
BasicComponentRegistry - Interface in org.infinispan.factories.impl
Basic dependency injection container.
BasicComponentRegistryImpl - Class in org.infinispan.factories.impl
 
BasicComponentRegistryImpl(ModuleRepository, boolean, BasicComponentRegistry) - Constructor for class org.infinispan.factories.impl.BasicComponentRegistryImpl
 
BasicConfiguration - Interface in org.infinispan.commons.configuration
BasicConfiguration provides the basis for concrete configurations.
BasicLogFactory - Class in org.infinispan.commons.logging
Factory that creates Log instances.
BasicLogFactory() - Constructor for class org.infinispan.commons.logging.BasicLogFactory
 
BasicMultimapCache<K,V> - Interface in org.infinispan.multimap.api
BasicMultimapCache provides the common API for the two different types of multimap caches that Infinispan provides: embedded and remote.
batch(int, Publisher<NonBlockingStore.SegmentedPublisher<Object>>, Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>>) - Method in class org.infinispan.persistence.async.AsyncNonBlockingStore
 
batch(int, Publisher<NonBlockingStore.SegmentedPublisher<Object>>, Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>>) - Method in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
 
batch(int, Publisher<NonBlockingStore.SegmentedPublisher<Object>>, Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>>) - Method in class org.infinispan.persistence.remote.RemoteStore
 
batch(int, Publisher<NonBlockingStore.SegmentedPublisher<Object>>, Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>>) - Method in class org.infinispan.persistence.rocksdb.RocksDBStore
 
batch(int, Publisher<NonBlockingStore.SegmentedPublisher<Object>>, Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>>) - Method in interface org.infinispan.persistence.spi.NonBlockingStore
Writes and removes the entries provided by the Publishers into the store.
batch(int, Publisher<NonBlockingStore.SegmentedPublisher<Object>>, Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>>) - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
 
batch(int, Publisher<NonBlockingStore.SegmentedPublisher<Object>>, Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>>) - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
 
BATCH - Enum constant in enum org.infinispan.configuration.parsing.CacheParser.TransactionMode
 
BATCH_SIZE - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
 
BATCH_SIZE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
BATCH_SIZE - Static variable in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
batchContainer - Variable in class org.infinispan.batch.AutoBatchSupport
 
batchContainer - Variable in class org.infinispan.cache.impl.CacheImpl
 
batchContainer - Variable in class org.infinispan.cache.impl.InvocationHelper
 
BatchContainer - Class in org.infinispan.batch
A container for holding thread locals for batching, to be used with the BatchingCache.startBatch() and BatchingCache.endBatch(boolean) calls.
BatchContainer() - Constructor for class org.infinispan.batch.BatchContainer
 
BatchingCache - Interface in org.infinispan.commons.api
The BatchingCache is implemented by all caches which support batching
BatchingClusterEventManagerImpl<K,V> - Class in org.infinispan.notifications.cachelistener.cluster.impl
 
BatchingClusterEventManagerImpl() - Constructor for class org.infinispan.notifications.cachelistener.cluster.impl.BatchingClusterEventManagerImpl
 
BatchingClusterEventManagerImpl.UnicastEventContext<K,V> - Class in org.infinispan.notifications.cachelistener.cluster.impl
 
BatchModeTransactionManager - Class in org.infinispan.transaction.tm
Not really a transaction manager in the truest sense of the word.
BatchModification - Class in org.infinispan.persistence.support
A simple wrapper class, necessary for Transactional stores, which allows MarshalledEntries and Object keys to be passed to a store implementation in order.
BatchModification(Set<Object>) - Constructor for class org.infinispan.persistence.support.BatchModification
 
batchSize - Variable in class org.infinispan.commons.reactive.AbstractAsyncPublisherHandler
 
batchSize() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
batchSize() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
Deprecated, 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() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
before(Class<? extends AsyncInterceptor>) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
Deprecated.
Dictates that the custom interceptor appears immediately before the specified interceptor.
BEFORE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
BEFORE - Enum constant in enum org.infinispan.container.versioning.InequalVersionComparisonResult
Denotes a version that was created temporally before another version.
BEFORE - Static variable in class org.infinispan.configuration.cache.InterceptorConfiguration
 
beforeCompletion() - Method in class org.infinispan.transaction.synchronization.SynchronizationAdapter
 
beforeCompletion(LocalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
 
beforeTopologyInstalled(int, ConsistentHash, ConsistentHash) - Method in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
begin() - Method in class org.infinispan.commons.tx.TransactionManagerImpl
 
begin() - Method in class org.infinispan.transaction.tm.EmbeddedUserTransaction
 
beginTransaction(GlobalTransaction, boolean) - Method in class org.infinispan.extendedstats.CacheStatisticManager
Signals the start of a transaction.
between(Object, Object) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Deprecated.
Checks that the left argument is between the given range limits.
BI_FUNCTION_MAPPER - Static variable in interface org.infinispan.commons.marshall.Ids
 
BIAS_ACQUISITION - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
BIAS_ACQUISITION - Static variable in class org.infinispan.configuration.cache.ClusteringConfiguration
 
BIAS_LIFESPAN - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
BIAS_LIFESPAN - Static variable in class org.infinispan.configuration.cache.ClusteringConfiguration
 
BIAS_REVOCATION_RESPONSE - Static variable in interface org.infinispan.commons.marshall.Ids
 
biasAcquisition() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
For scattered cache, specifies if the nodes is allowed to cache the entry, serving reads locally.
biasAcquisition(BiasAcquisition) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
Used in scattered cache.
BiasAcquisition - Enum in org.infinispan.configuration.cache
Specifies when is a node allowed to acquire a bias on an entry, serving further reads to the same key locally (despite not being an owner).
biased() - Method in interface org.infinispan.scattered.BiasManager.Revocation
 
biasLifespan() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
For scattered cache, specifies how long is the node allowed to read the cached entry locally.
biasLifespan(long, TimeUnit) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
Used in scattered cache.
BiasManager - Interface in org.infinispan.scattered
This component tracks if this node can read the data stored locally despite not being an owner and which nodes will read the local data that is primary-owned by this node.
BiasManager.Revocation - Interface in org.infinispan.scattered
 
BiasManagerImpl - Class in org.infinispan.scattered.impl
 
BiasManagerImpl() - Constructor for class org.infinispan.scattered.impl.BiasManagerImpl
 
BiasRevocationResponse - Class in org.infinispan.remoting.responses
 
BiasRevocationResponse(Object, Address[]) - Constructor for class org.infinispan.remoting.responses.BiasRevocationResponse
 
BiasRevocationResponse.Externalizer - Class in org.infinispan.remoting.responses
 
BiFunctionMapper - Class in org.infinispan.cache.impl
A Bifuncion wrapper that uses the cache's underlying DataConversion objects to perform its operations.
BiFunctionMapper(BiFunction, DataConversion, DataConversion) - Constructor for class org.infinispan.cache.impl.BiFunctionMapper
 
BiFunctionMapper.Externalizer - Class in org.infinispan.cache.impl
 
BINARY - Enum constant in enum org.infinispan.configuration.cache.StorageType
Deprecated, 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 org.infinispan.configuration.parsing.Element
 
BINARY - Static variable in interface org.infinispan.commons.dataconversion.EncoderIds
Deprecated.
 
BINARY_CONVERTER - Static variable in class org.infinispan.server.core.ExternalizerIds
 
BINARY_FILTER - Static variable in class org.infinispan.server.core.ExternalizerIds
 
BINARY_FILTER_CONVERTER - Static variable in class org.infinispan.server.core.ExternalizerIds
 
BINARY_KEYED_JDBC_STORE - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
 
binaryParam() - Method in interface org.infinispan.filter.ParamKeyValueFilterConverterFactory
 
BinaryTranscoder - Class in org.infinispan.commons.dataconversion
Deprecated, 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 org.infinispan.server.hotrod.tx.ControlByte
 
Bits - Class in org.infinispan.container.offheap
Utility method for inserting and retrieving values from to/from a byte[]
Bits() - Constructor for class org.infinispan.container.offheap.Bits
 
bitSetOf(Enum<?>) - Static method in class org.infinispan.commons.util.EnumUtil
 
bitSetOf(Enum<?>[]) - Static method in class org.infinispan.commons.util.EnumUtil
 
bitSetOf(Enum<?>, Enum<?>) - Static method in class org.infinispan.commons.util.EnumUtil
 
bitSetOf(Enum<?>, Enum<?>, Enum<?>...) - Static method in class org.infinispan.commons.util.EnumUtil
 
bitSetOf(Collection<E>) - Static method in class org.infinispan.commons.util.EnumUtil
 
bitSetSize(long) - Static method in class org.infinispan.commons.util.EnumUtil
 
BitShift - Class in org.infinispan.server.hotrod
 
BitShift() - Constructor for class org.infinispan.server.hotrod.BitShift
 
BLOCK_SIZE - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.Attribute
 
BLOCKED - Enum constant in enum org.infinispan.scattered.ScatteredVersionManager.SegmentState
 
BlockHoundUtil - Class in org.infinispan.commons.internal
 
BlockHoundUtil() - Constructor for class org.infinispan.commons.internal.BlockHoundUtil
 
blocking(CompletionStage<T>) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticRpcManager
 
blocking(CompletionStage<T>) - Method in interface org.infinispan.remoting.rpc.RpcManager
Block on a request and return its result.
blocking(CompletionStage<T>) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
BLOCKING_BOUNDED_QUEUE_THREAD_POOL - Enum constant in enum org.infinispan.configuration.parsing.Element
 
BLOCKING_EXECUTOR - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
BLOCKING_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
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 - Interface in org.infinispan.util.concurrent
Manager utility for blocking operations that runs tasks on the blocking executor and returns a CompletionStage or Publisher that continues on the non-blocking executor, similar to stage.handleAsync(callback, blockingExecutor).whenCompleteAsync(NOOP, nonBlockingExecutor).
BlockingManager.BlockingExecutor - Interface in org.infinispan.util.concurrent
Executor interface that submits task to a blocking pool that returns a stage that is guaranteed to run any chained stages on a non-blocking thread if the stage is not yet complete.
BlockingManagerImpl - Class in org.infinispan.util.concurrent
 
BlockingManagerImpl() - Constructor for class org.infinispan.util.concurrent.BlockingManagerImpl
 
blockingPublisher(Publisher<V>) - Method in interface org.infinispan.util.concurrent.BlockingManager
Provided a publisher that is known to block when subscribed to.
blockingPublisher(Publisher<V>) - Method in class org.infinispan.util.concurrent.BlockingManagerImpl
 
blockingPublisherToVoidStage(Publisher<V>, Object) - Method in interface org.infinispan.util.concurrent.BlockingManager
Subscribes to the provided blocking publisher using the the blocking executor, ignoring all elements and returning a CompletionStage with a value of null which completes on a non-blocking thread.
blockingPublisherToVoidStage(Publisher<V>, Object) - Method in class org.infinispan.util.concurrent.BlockingManagerImpl
 
BlockingRejectedExecutionHandler - Class in org.infinispan.commons.util.concurrent
A handler for rejected tasks that runs the task if the current thread is a blocking thread otherwise it rejects the task.
BlockingResource - Interface in org.infinispan.commons.executors
Interface to designate the resource is a blocking one.
BlockingRunnable - Interface in org.infinispan.util.concurrent
A special Runnable that is only sent to a thread when it is ready to be executed without blocking the thread
BlockingTaskAwareExecutorService - Interface in org.infinispan.util.concurrent
Executor service that is aware of BlockingRunnable and only dispatch the runnable to a thread when it has low (or no) probability of blocking the thread.
BlockingTaskAwareExecutorServiceImpl - Class in org.infinispan.util.concurrent
A special executor service that accepts a BlockingRunnable.
BlockingTaskAwareExecutorServiceImpl(ExecutorService, TimeService) - Constructor for class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
 
BlockingThreadFactory - Class in org.infinispan.factories.threads
 
BlockingThreadFactory(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.GlobalJmxStatisticsConfigurationBuilder
 
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.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() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfiguration
 
blockSize(int) - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
 
bloomFilter() - Method in class org.infinispan.client.hotrod.configuration.NearCacheConfiguration
 
bloomFilter(boolean) - Method in class org.infinispan.client.hotrod.configuration.NearCacheConfigurationBuilder
Specifies whether bloom filter should be used for near cache to limit the number of write notifications for unrelated keys.
BloomFilter<E> - Class in org.infinispan.commons.util
 
bloomFilterRequiresMaxActiveOneAndWait(int, ExhaustedAction) - Method in interface org.infinispan.client.hotrod.logging.Log
 
bool(boolean) - Method in class org.infinispan.commons.dataconversion.internal.Json.DefaultFactory
 
bool(boolean) - Method in interface org.infinispan.commons.dataconversion.internal.Json.Factory
Construct and return a JSON boolean.
bool(ByteBuf) - Static method in class org.infinispan.server.hotrod.Intrinsics
 
BOOL - Enum constant in enum org.infinispan.persistence.sql.AbstractSchemaJdbcStore.ProtostreamFieldType
 
Boolean(boolean) - Constructor for class org.infinispan.commons.util.ByRef.Boolean
 
booleanKnnPredicates() - Method in interface org.infinispan.query.logging.Log
 
booleanResponse(HotRodHeader, HotRodServer, Channel, boolean) - Method in class org.infinispan.server.hotrod.Encoder4x
 
booleanResponse(HotRodHeader, HotRodServer, Channel, boolean) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
 
booleanStage(boolean) - Static method in class org.infinispan.commons.util.concurrent.CompletableFutures
 
bootstrapComponents() - Method in class org.infinispan.factories.ComponentRegistry
This is a good place to register components that don't have any dependency.
BORLAND_SUN - Enum constant in enum org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
 
BOTH - Enum constant in enum org.infinispan.notifications.Listener.Observation
Observation level used to be notified of an operation before and after it occurs
BOUNDED_STRONG - Enum constant in enum org.infinispan.counter.api.CounterType
A strong consistent and bounded counter.
boundedDataContainer(int, long, EntrySizeCalculator<? super K, ? super V>) - Static method in class org.infinispan.container.impl.DefaultDataContainer
 
boundedDataContainer(int, long, EvictionType) - Static method in class org.infinispan.container.impl.DefaultDataContainer
 
BoundedExecutors - Class in org.infinispan.util.concurrent
Similar to JDK Executors except that the factory methods here allow you to specify the size of the blocking queue that backs the executor.
BoundedExecutors() - Constructor for class org.infinispan.util.concurrent.BoundedExecutors
 
BoundedOffHeapDataContainer - Class in org.infinispan.container.offheap
 
BoundedOffHeapDataContainer(long, EvictionType) - Constructor for class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
BoundedSegmentedDataContainer<K,V> - Class in org.infinispan.container.impl
Bounded implementation of segmented data container.
BoundedSegmentedDataContainer(int, long, EntrySizeCalculator<? super K, ? super InternalCacheEntry<K, V>>) - Constructor for class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
BoundedSegmentedDataContainer(int, long, EvictionType) - Constructor for class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
BoundedThreadPoolConfigurationBuilder - Class in org.infinispan.configuration.global
 
boundedThreadPools() - Method in class org.infinispan.configuration.global.ThreadsConfiguration
 
boxed() - Method in interface org.infinispan.DoubleCacheStream
boxed() - Method in interface org.infinispan.IntCacheStream
boxed() - Method in interface org.infinispan.LongCacheStream
boxed() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
boxed() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
boxed() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
boxed() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
boxed() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
boxed() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
branchQualifierLength() - Method in class org.infinispan.commons.tx.XidImpl
 
branchQualifierOffset() - Method in class org.infinispan.commons.tx.XidImpl
 
brandName() - Method in class org.infinispan.commons.util.Version
 
brandVersion() - Method in class org.infinispan.commons.util.Version
 
bringSiteOnline(String) - Method in class org.infinispan.xsite.status.DefaultTakeOfflineManager
 
bringSiteOnline(String) - Method in class org.infinispan.xsite.status.NoOpTakeOfflineManager
 
bringSiteOnline(String) - Method in interface org.infinispan.xsite.status.TakeOfflineManager
It changes the site siteName to online.
BringSiteOnlineResponse - Enum in org.infinispan.xsite.status
broadcastShutdownCache(String) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
BROUGHT_ONLINE - Enum constant in enum org.infinispan.xsite.status.BringSiteOnlineResponse
 
Bucket<V> - Class in org.infinispan.multimap.impl
Bucket used to store MultiMap values, required as HashSet cannot be directly marshalled via ProtoStream.
Bucket() - Constructor for class org.infinispan.multimap.impl.Bucket
 
Bucket(V) - Constructor for class org.infinispan.multimap.impl.Bucket
 
Bucket$___Marshaller_686dc55729a31972fef7d4722c2e90e0421789a20c8a9d4176be1714ac94d28c - Class in org.infinispan.multimap.impl
WARNING: Generated code! Do not edit!
Bucket$___Marshaller_686dc55729a31972fef7d4722c2e90e0421789a20c8a9d4176be1714ac94d28c() - Constructor for class org.infinispan.multimap.impl.Bucket$___Marshaller_686dc55729a31972fef7d4722c2e90e0421789a20c8a9d4176be1714ac94d28c
 
buf - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
bufAbsoluteStart - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
bufEnd - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
buffer(int) - Static method in class org.infinispan.server.core.transport.ExtendedByteBuf
 
buffer(int) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
 
BufferSizePredictor - Interface in org.infinispan.commons.marshall
Buffer size predictor
bufLoadFactor - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
bufSoftLimit - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
bufStart - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
build() - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
build() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
build() - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Builds a configuration object
build() - Method in class org.infinispan.client.hotrod.DataFormat.Builder
 
build() - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition.Builder
 
build() - Method in class org.infinispan.commons.configuration.io.ConfigurationReader.Builder
 
build() - Method in class org.infinispan.commons.configuration.io.ConfigurationWriter.Builder
 
build() - Method in interface org.infinispan.commons.marshall.MarshallUtil.UnboundedCollectionBuilder
 
build() - Method in class org.infinispan.configuration.cache.AbstractCustomInterceptorsConfigurationChildBuilder
 
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.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.CustomInterceptorsConfigurationBuilder
 
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.IndexWriterConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
 
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.configuration.cache.JMXStatisticsConfigurationBuilder
 
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.ManagedConnectionFactoryConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.remote.configuration.MechanismConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.MemoryStorageConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.QueryConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.SecurityConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.parsing.SFSToSIFSConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.StatisticsConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
 
build() - Method in class org.infinispan.persistence.remote.configuration.TrustStoreConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
build() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
build() - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.CachedThreadPoolConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.GlobalJmxConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.GlobalMetricsConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.GlobalStatePathConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.GlobalStorageConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.JGroupsConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.PrincipalRoleMapperConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.RolePermissionMapperConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.ScheduledThreadPoolConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.StackConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.StackFileConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.TemporaryGlobalStatePathConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.ThreadFactoryConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
build() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
build() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
Builds a GlobalConfiguration object using the settings applied to this builder
build() - Method in class org.infinispan.counter.api.CounterConfiguration.Builder
 
build() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
build() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
build() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata.Builder
 
build() - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
 
build() - Method in class org.infinispan.metadata.impl.PrivateMetadata.Builder
 
build() - Method in interface org.infinispan.metadata.Metadata.Builder
Build a metadata instance.
build() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
build() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.DelegatingCacheInvocationBuilder
 
build() - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl.DefaultBuilder
 
build() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
build() - Method in interface org.infinispan.query.dsl.QueryBuilder
Deprecated.
Builds the query object.
build() - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
 
build() - Method in interface org.infinispan.rest.framework.impl.RestRequestBuilder
 
build() - Method in interface org.infinispan.rest.framework.impl.RestResponseBuilder
 
build() - Method in class org.infinispan.rest.framework.impl.SimpleRestResponse.Builder
 
build() - Method in class org.infinispan.rest.NettyRestResponse.Builder
 
build() - Method in class org.infinispan.search.mapper.search.loading.context.impl.InfinispanLoadingContext.Builder
 
build() - Method in class org.infinispan.server.core.backup.BackupManagerResources.Builder
 
build() - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
 
build() - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
Builds a configuration object
build() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
 
build() - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
 
build() - Method in class org.infinispan.xsite.status.AbstractSiteStatusBuilder
 
build(boolean) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
build(boolean) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
build(boolean) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
 
build(boolean) - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
 
build(boolean) - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
 
build(int) - Method in interface org.infinispan.commons.marshall.MarshallUtil.ArrayBuilder
 
build(int) - Method in interface org.infinispan.commons.marshall.MarshallUtil.CollectionBuilder
 
build(int) - Method in interface org.infinispan.commons.marshall.MarshallUtil.EnumBuilder
 
build(int) - Method in interface org.infinispan.commons.marshall.MarshallUtil.MapBuilder
 
build(Optional<SearchIntegration>) - Method in class org.infinispan.search.mapper.mapping.SearchMappingBuilder
 
build(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
build(InvocationImpl.Builder) - Method in class org.infinispan.rest.framework.impl.Invocations.Builder
 
buildBackupAckCommand(long, int) - Method in interface org.infinispan.commands.CommandsFactory
 
buildBackupAckCommand(long, int) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildBackupMultiKeyAckCommand(long, int, int) - Method in interface org.infinispan.commands.CommandsFactory
 
buildBackupMultiKeyAckCommand(long, int, int) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildBackupNoopCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildBackupNoopCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildCancelPublisherCommand(String) - Method in interface org.infinispan.commands.CommandsFactory
 
buildCancelPublisherCommand(String) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildCheckTransactionRpcCommand(Collection<GlobalTransaction>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildCheckTransactionRpcCommand(Collection<GlobalTransaction>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildClearCommand(long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ClearCommand
buildClearCommand(long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildClusteredGetAllCommand(List<?>, long, GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ClusteredGetAllCommand, which is a remote lookup command
buildClusteredGetAllCommand(List<?>, long, GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildClusteredGetCommand(Object, Integer, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ClusteredGetCommand, which is a remote lookup command
buildClusteredGetCommand(Object, Integer, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildCommitCommand(GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Builds a CommitCommand
buildCommitCommand(GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildCompleteTransactionCommand(XidImpl, boolean) - Method in interface org.infinispan.commands.CommandsFactory
Builds a CompleteTransactionCommand command.
buildCompleteTransactionCommand(XidImpl, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildComputeCommand(Object, BiFunction, boolean, int, Metadata, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ComputeCommand
buildComputeCommand(Object, BiFunction, boolean, int, Metadata, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildComputeIfAbsentCommand(Object, Function, int, Metadata, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ComputeIfAbsentCommand
buildComputeIfAbsentCommand(Object, Function, int, Metadata, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildConflictResolutionStartCommand(int, IntSet) - Method in interface org.infinispan.commands.CommandsFactory
 
buildConflictResolutionStartCommand(int, IntSet) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildEntryReductionPublisherCommand(boolean, DeliveryGuarantee, IntSet, Set<K>, Set<K>, long, Function<? super Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>>, Function<? super Publisher<R>, ? extends CompletionStage<R>>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildEntryReductionPublisherCommand(boolean, DeliveryGuarantee, IntSet, Set<K>, Set<K>, long, Function<? super Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>>, Function<? super Publisher<R>, ? extends CompletionStage<R>>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildEntrySetCommand(long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a EntrySetCommand
buildEntrySetCommand(long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
builder - Variable in class org.infinispan.configuration.cache.AbstractCustomInterceptorsConfigurationChildBuilder
 
builder - Variable in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.AbstractPersistenceConfigurationChildBuilder
 
builder - Variable in class org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.AbstractTransportConfigurationChildBuilder
 
builder - Variable in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.BackupForBuilder
 
builder - Variable in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
 
builder - Variable in class org.infinispan.security.impl.CreatePermissionConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.CustomStoreConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.HashConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.IndexReaderConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
 
builder - Variable in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.LockingConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.MemoryStorageConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
builder - Variable in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.QueryConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
 
builder - Variable in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
builder - Variable in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.SecurityConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.parsing.SFSToSIFSConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
builder - Variable in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.StatisticsConfigurationBuilder
 
builder - Variable in class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
 
builder - Variable in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
 
builder - Variable in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
builder - Variable in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
 
builder() - Static method in class org.infinispan.client.hotrod.DataFormat
 
builder() - Method in class org.infinispan.container.entries.RemoteMetadata
 
builder() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
 
builder() - Method in class org.infinispan.metadata.EmbeddedMetadata
 
builder() - Method in class org.infinispan.metadata.EmbeddedMetadata.EmbeddedExpirableMetadata
 
builder() - Method in class org.infinispan.metadata.EmbeddedMetadata.EmbeddedLifespanExpirableMetadata
 
builder() - Method in class org.infinispan.metadata.EmbeddedMetadata.EmbeddedMaxIdleExpirableMetadata
 
builder() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
Deprecated.
 
builder() - Method in class org.infinispan.metadata.impl.L1Metadata
 
builder() - Method in class org.infinispan.metadata.impl.PrivateMetadata
 
builder() - Method in interface org.infinispan.metadata.Metadata
Returns an instance of Metadata.Builder which can be used to build new instances of Metadata instance which are full copies of this Metadata.
builder(Enum<?>, T) - Static method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
 
builder(Enum<?>, T, Class<T>) - Static method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
 
builder(String, T) - Static method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
 
builder(String, T, Class<T>) - Static method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
 
builder(PojoBootstrapIntrospector) - Method in class org.infinispan.search.mapper.mapping.SearchMappingCommonBuilding
 
builder(PojoBootstrapIntrospector, ClassLoader, Collection<ProgrammaticSearchMappingProvider>, BlockingManager, NonBlockingManager) - Static method in interface org.infinispan.search.mapper.mapping.SearchMapping
 
builder(CounterType) - Static method in class org.infinispan.counter.api.CounterConfiguration
 
Builder<T> - Interface in org.infinispan.commons.configuration
Builder.
Builder() - Constructor for class org.infinispan.client.hotrod.DataFormat.Builder
 
Builder() - Constructor for class org.infinispan.functional.impl.MetaParamsInternalMetadata.Builder
 
Builder() - Constructor for class org.infinispan.metadata.EmbeddedMetadata.Builder
 
Builder() - Constructor for class org.infinispan.metadata.impl.PrivateMetadata.Builder
 
Builder() - Constructor for class org.infinispan.rest.framework.impl.Invocations.Builder
 
Builder() - Constructor for class org.infinispan.rest.framework.impl.SimpleRestResponse.Builder
 
Builder() - Constructor for class org.infinispan.server.core.backup.BackupManagerResources.Builder
 
Builder(int, int, List<Address>, Map<Address, Float>) - Constructor for class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
Builder(int, int, List<Address>, Map<Address, Float>) - Constructor for class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory.Builder
 
Builder(int, List<Address>, Map<Address, Float>) - Constructor for class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
Builder(FullHttpRequest, boolean) - Constructor for class org.infinispan.rest.NettyRestResponse.Builder
 
Builder(PojoSelectionEntityLoader<E>) - Constructor for class org.infinispan.search.mapper.search.loading.context.impl.InfinispanLoadingContext.Builder
 
Builder(DefaultConsistentHash) - Constructor for class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
Builder(DefaultConsistentHashFactory.Builder) - Constructor for class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
Builder(DefaultConsistentHash, List<Address>, Map<Address, Float>) - Constructor for class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
Builder(ScatteredConsistentHash) - Constructor for class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
Builder(ScatteredConsistentHashFactory.Builder) - Constructor for class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
Builder(ScatteredConsistentHash, List<Address>, Map<Address, Float>) - Constructor for class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
Builder(RestRequest, boolean) - Constructor for class org.infinispan.rest.NettyRestResponse.Builder
 
builderFor(B) - Static method in class org.infinispan.commons.configuration.ConfigurationUtils
Returns the builder that was used to build this class.
builderForNonStrict(B) - Static method in class org.infinispan.commons.configuration.ConfigurationUtils
The same as ConfigurationUtils.builderFor(Object) except that it won't throw an exception if no builder class is found.
buildEventLoop(int, ThreadFactory, String) - Static method in class org.infinispan.server.core.transport.NettyTransport
 
buildEvictCommand(Object, int, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds an EvictCommand
buildEvictCommand(Object, int, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildExceptionAckCommand(long, Throwable, int) - Method in interface org.infinispan.commands.CommandsFactory
 
buildExceptionAckCommand(long, Throwable, int) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildFuture() - Method in interface org.infinispan.rest.framework.impl.RestResponseBuilder
 
buildGetAllCommand(Collection<?>, long, boolean) - Method in interface org.infinispan.commands.CommandsFactory
Builds a GetAllCommand
buildGetAllCommand(Collection<?>, long, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildGetCacheEntryCommand(Object, int, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a GetCacheEntryCommand
buildGetCacheEntryCommand(Object, int, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildGetInDoubtTransactionsCommand() - Method in interface org.infinispan.commands.CommandsFactory
Builds a GetInDoubtTransactionsCommand.
buildGetInDoubtTransactionsCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildGetInDoubtTxInfoCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildGetInDoubtTxInfoCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildGetKeyValueCommand(Object, int, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a GetKeyValueCommand
buildGetKeyValueCommand(Object, int, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildInitialPublisherCommand(String, DeliveryGuarantee, int, IntSet, Set<K>, Set<K>, long, boolean, boolean, Function<? super Publisher<I>, ? extends Publisher<R>>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildInitialPublisherCommand(String, DeliveryGuarantee, int, IntSet, Set<K>, Set<K>, long, boolean, boolean, Function<? super Publisher<I>, ? extends Publisher<R>>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildInvalidateCommand(long, Object...) - Method in interface org.infinispan.commands.CommandsFactory
Builds an InvalidateCommand
buildInvalidateCommand(long, Object...) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildInvalidateFromL1Command(long, Collection<Object>) - Method in interface org.infinispan.commands.CommandsFactory
Builds an InvalidateFromL1Command
buildInvalidateFromL1Command(long, Collection<Object>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildInvalidateFromL1Command(Address, long, Collection<Object>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildInvalidateFromL1Command(Address, long, Collection<Object>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildInvalidateVersionsCommand(int, Object[], int[], long[], boolean) - Method in interface org.infinispan.commands.CommandsFactory
 
buildInvalidateVersionsCommand(int, Object[], int[], long[], boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracCleanupKeyCommand(Collection<? extends IracManagerKeyInfo>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracCleanupKeyCommand(Collection<? extends IracManagerKeyInfo>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracClearKeysCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracClearKeysCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracMetadataRequestCommand(int, IracEntryVersion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracMetadataRequestCommand(int, IracEntryVersion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracPutKeyValueCommand(Object, int, Object, Metadata, PrivateMetadata) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracPutKeyValueCommand(Object, int, Object, Metadata, PrivateMetadata) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracPutManyCommand(int) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracPutManyCommand(int) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracRequestStateCommand(IntSet) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracRequestStateCommand(IntSet) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracStateResponseCommand(int) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracStateResponseCommand(int) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracTombstoneCheckRequest(List<Object>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracTombstoneCheckRequest(List<Object>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracTombstoneCleanupCommand(int) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracTombstoneCleanupCommand(int) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracTombstonePrimaryCheckCommand(Collection<IracTombstoneInfo>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracTombstonePrimaryCheckCommand(Collection<IracTombstoneInfo>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracTombstoneRemoteSiteCheckCommand(List<Object>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracTombstoneRemoteSiteCheckCommand(List<Object>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracTombstoneStateResponseCommand(Collection<IracTombstoneInfo>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracTombstoneStateResponseCommand(Collection<IracTombstoneInfo>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracTouchCommand(Object) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracTouchCommand(Object) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildIracUpdateVersionCommand(Map<Integer, IracEntryVersion>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildIracUpdateVersionCommand(Map<Integer, IracEntryVersion>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildKeyReductionPublisherCommand(boolean, DeliveryGuarantee, IntSet, Set<K>, Set<K>, long, Function<? super Publisher<K>, ? extends CompletionStage<R>>, Function<? super Publisher<R>, ? extends CompletionStage<R>>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildKeyReductionPublisherCommand(boolean, DeliveryGuarantee, IntSet, Set<K>, Set<K>, long, Function<? super Publisher<K>, ? extends CompletionStage<R>>, Function<? super Publisher<R>, ? extends CompletionStage<R>>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildKeySetCommand(long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a KeySetCommand
buildKeySetCommand(long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildLockControlCommand(Object, long, GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Same as CommandsFactory.buildLockControlCommand(Collection, long, GlobalTransaction) but for locking a single key vs a collection of keys.
buildLockControlCommand(Object, long, GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildLockControlCommand(Collection<?>, long) - Method in interface org.infinispan.commands.CommandsFactory
 
buildLockControlCommand(Collection<?>, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildLockControlCommand(Collection<?>, long, GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Builds a LockControlCommand to control explicit remote locking
buildLockControlCommand(Collection<?>, long, GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildMetadata(long, TimeUnitValue, long, TimeUnitValue) - Method in class org.infinispan.server.hotrod.HotRodServer
 
buildMetadata2x(long, TimeUnitValue, long, TimeUnitValue) - Method in class org.infinispan.server.hotrod.HotRodServer
 
buildMultiClusterEventCommand(Map<UUID, Collection<ClusterEvent<K, V>>>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildMultiClusterEventCommand(Map<UUID, Collection<ClusterEvent<K, V>>>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildMultiEntriesFunctionalBackupWriteCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildMultiEntriesFunctionalBackupWriteCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildMultiKeyFunctionalBackupWriteCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildMultiKeyFunctionalBackupWriteCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildNextPublisherCommand(String) - Method in interface org.infinispan.commands.CommandsFactory
 
buildNextPublisherCommand(String) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildPrepareCommand(GlobalTransaction, List<WriteCommand>, boolean) - Method in interface org.infinispan.commands.CommandsFactory
Builds a PrepareCommand
buildPrepareCommand(GlobalTransaction, List<WriteCommand>, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildPutKeyValueCommand(Object, Object, int, Metadata, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a PutKeyValueCommand
buildPutKeyValueCommand(Object, Object, int, Metadata, long, boolean) - Method in interface org.infinispan.commands.CommandsFactory
 
buildPutKeyValueCommand(Object, Object, int, Metadata, long, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildPutMapBackupWriteCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildPutMapBackupWriteCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildPutMapCommand(Map<?, ?>, Metadata, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a PutMapCommand
buildPutMapCommand(Map<?, ?>, Metadata, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReadOnlyKeyCommand(Object, Function<EntryView.ReadEntryView<K, V>, R>, int, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildReadOnlyKeyCommand(Object, Function<EntryView.ReadEntryView<K, V>, R>, int, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReadOnlyManyCommand(Collection<?>, Function<EntryView.ReadEntryView<K, V>, R>, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildReadOnlyManyCommand(Collection<?>, Function<EntryView.ReadEntryView<K, V>, R>, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReadWriteKeyCommand(Object, Function<EntryView.ReadWriteEntryView<K, V>, R>, int, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildReadWriteKeyCommand(Object, Function<EntryView.ReadWriteEntryView<K, V>, R>, int, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReadWriteKeyValueCommand(Object, Object, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>, int, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildReadWriteKeyValueCommand(Object, Object, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>, int, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReadWriteManyCommand(Collection<?>, Function<EntryView.ReadWriteEntryView<K, V>, R>, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildReadWriteManyCommand(Collection<?>, Function<EntryView.ReadWriteEntryView<K, V>, R>, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReadWriteManyEntriesCommand(Map<?, ?>, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildReadWriteManyEntriesCommand(Map<?, ?>, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRemoveCommand(Object, Object, int, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a RemoveCommand
buildRemoveCommand(Object, Object, int, long, boolean) - Method in interface org.infinispan.commands.CommandsFactory
 
buildRemoveCommand(Object, Object, int, long, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRemoveExpiredCommand(Object, Object, int, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds an expired remove command that is used to remove only a specific entry when it expires via maxIdle
buildRemoveExpiredCommand(Object, Object, int, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRemoveExpiredCommand(Object, Object, int, Long, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds an expired remove command that is used to remove only a specific entry when it expires via lifespan
buildRemoveExpiredCommand(Object, Object, int, Long, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRenewBiasCommand(Object[]) - Method in interface org.infinispan.commands.CommandsFactory
 
buildRenewBiasCommand(Object[]) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildReplaceCommand(Object, Object, Object, int, Metadata, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ReplaceCommand
buildReplaceCommand(Object, Object, Object, int, Metadata, long, boolean) - Method in interface org.infinispan.commands.CommandsFactory
Builds a ReplaceCommand
buildReplaceCommand(Object, Object, Object, int, Metadata, long, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRevokeBiasCommand(Address, long, int, Collection<Object>) - Method in interface org.infinispan.commands.CommandsFactory
 
buildRevokeBiasCommand(Address, long, int, Collection<Object>) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildRollbackCommand(GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Builds a RollbackCommand
buildRollbackCommand(GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildScatteredStateConfirmRevokeCommand(int, IntSet) - Method in interface org.infinispan.commands.CommandsFactory
 
buildScatteredStateConfirmRevokeCommand(int, IntSet) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildScatteredStateGetKeysCommand(int, IntSet) - Method in interface org.infinispan.commands.CommandsFactory
 
buildScatteredStateGetKeysCommand(int, IntSet) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildSingleKeyBackupWriteCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildSingleKeyBackupWriteCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildSingleKeyFunctionalBackupWriteCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildSingleKeyFunctionalBackupWriteCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildSingleRpcCommand(ReplicableCommand) - Method in interface org.infinispan.commands.CommandsFactory
Deprecated, for removal: This API element is subject to removal in a future version.
buildSingleRpcCommand(VisitableCommand) - Method in interface org.infinispan.commands.CommandsFactory
Builds a SingleRpcCommand "envelope" containing a single ReplicableCommand
buildSingleRpcCommand(VisitableCommand) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildSingleXSiteRpcCommand(VisitableCommand) - Method in interface org.infinispan.commands.CommandsFactory
Builds SingleRpcCommand used to perform VisitableCommand on the backup site,
buildSingleXSiteRpcCommand(VisitableCommand) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildSizeCommand(IntSet, long) - Method in interface org.infinispan.commands.CommandsFactory
Builds a SizeCommand
buildSizeCommand(IntSet, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildStateResponseCommand(int, Collection<StateChunk>, boolean, boolean) - Method in interface org.infinispan.commands.CommandsFactory
Builds a StateResponseCommand used for pushing cache entries to another node.
buildStateResponseCommand(int, Collection<StateChunk>, boolean, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildStateTransferCancelCommand(int, IntSet) - Method in interface org.infinispan.commands.CommandsFactory
 
buildStateTransferCancelCommand(int, IntSet) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildStateTransferGetListenersCommand(int) - Method in interface org.infinispan.commands.CommandsFactory
 
buildStateTransferGetListenersCommand(int) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildStateTransferGetTransactionsCommand(int, IntSet) - Method in interface org.infinispan.commands.CommandsFactory
 
buildStateTransferGetTransactionsCommand(int, IntSet) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildStateTransferStartCommand(int, IntSet) - Method in interface org.infinispan.commands.CommandsFactory
 
buildStateTransferStartCommand(int, IntSet) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildTouchCommand(Object, int, boolean, long) - Method in interface org.infinispan.commands.CommandsFactory
 
buildTouchCommand(Object, int, boolean, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildTxCompletionNotificationCommand(long) - Method in interface org.infinispan.commands.CommandsFactory
 
buildTxCompletionNotificationCommand(long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildTxCompletionNotificationCommand(XidImpl, GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Builds a TxCompletionNotificationCommand.
buildTxCompletionNotificationCommand(XidImpl, GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildTxReadOnlyKeyCommand(Object, Function<EntryView.ReadEntryView<K, V>, R>, List<Mutation<K, V, ?>>, int, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildTxReadOnlyKeyCommand(Object, Function<EntryView.ReadEntryView<K, V>, R>, List<Mutation<K, V, ?>>, int, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildTxReadOnlyManyCommand(Collection<?>, List<List<Mutation<K, V, ?>>>, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildTxReadOnlyManyCommand(Collection<?>, List<List<Mutation<K, V, ?>>>, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildVersionedCommitCommand(GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
Builds a VersionedCommitCommand
buildVersionedCommitCommand(GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildVersionedPrepareCommand(GlobalTransaction, List<WriteCommand>, boolean) - Method in interface org.infinispan.commands.CommandsFactory
Builds a VersionedPrepareCommand
buildVersionedPrepareCommand(GlobalTransaction, List<WriteCommand>, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildWriteOnlyKeyCommand(Object, Consumer<EntryView.WriteEntryView<K, V>>, int, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildWriteOnlyKeyCommand(Object, Consumer<EntryView.WriteEntryView<K, V>>, int, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildWriteOnlyKeyValueCommand(Object, Object, BiConsumer<T, EntryView.WriteEntryView<K, V>>, int, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildWriteOnlyKeyValueCommand(Object, Object, BiConsumer<T, EntryView.WriteEntryView<K, V>>, int, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildWriteOnlyManyCommand(Collection<?>, Consumer<EntryView.WriteEntryView<K, V>>, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildWriteOnlyManyCommand(Collection<?>, Consumer<EntryView.WriteEntryView<K, V>>, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildWriteOnlyManyEntriesCommand(Map<?, ?>, BiConsumer<T, EntryView.WriteEntryView<K, V>>, Params, DataConversion, DataConversion) - Method in interface org.infinispan.commands.CommandsFactory
 
buildWriteOnlyManyEntriesCommand(Map<?, ?>, BiConsumer<T, EntryView.WriteEntryView<K, V>>, Params, DataConversion, DataConversion) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteAmendOfflineStatusCommand(String, Integer, Long) - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteAmendOfflineStatusCommand(String, Integer, Long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteAutoTransferStatusCommand(String) - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteAutoTransferStatusCommand(String) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteBringOnlineCommand(String) - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteBringOnlineCommand(String) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteOfflineStatusCommand(String) - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteOfflineStatusCommand(String) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteSetStateTransferModeCommand(String, XSiteStateTransferMode) - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteSetStateTransferModeCommand(String, XSiteStateTransferMode) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteStatePushCommand(XSiteState[]) - Method in interface org.infinispan.commands.CommandsFactory
Builds XSiteStatePushCommand used to transfer a single chunk of data between sites.
buildXSiteStatePushCommand(XSiteState[]) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteStatePushRequest(XSiteState[], long) - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteStatePushRequest(XSiteState[], long) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteStateTransferCancelSendCommand(String) - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteStateTransferCancelSendCommand(String) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteStateTransferClearStatusCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteStateTransferClearStatusCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteStateTransferControlRequest(boolean) - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteStateTransferControlRequest(boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteStateTransferFinishReceiveCommand(String) - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteStateTransferFinishReceiveCommand(String) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteStateTransferFinishSendCommand(String, boolean) - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteStateTransferFinishSendCommand(String, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteStateTransferRestartSendingCommand(String, int) - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteStateTransferRestartSendingCommand(String, int) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteStateTransferStartReceiveCommand(String) - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteStateTransferStartReceiveCommand(String) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteStateTransferStartSendCommand(String, int) - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteStateTransferStartSendCommand(String, int) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteStateTransferStatusRequestCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteStateTransferStatusRequestCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteStatusCommand() - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteStatusCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
buildXSiteTakeOfflineCommand(String) - Method in interface org.infinispan.commands.CommandsFactory
 
buildXSiteTakeOfflineCommand(String) - Method in class org.infinispan.commands.CommandsFactoryImpl
 
BuiltBy - Annotation Type in org.infinispan.commons.configuration
BuiltBy.
builtIn() - Method in class org.infinispan.configuration.global.StackFileConfiguration
 
BuiltinJGroupsChannelConfigurator - Class in org.infinispan.remoting.transport.jgroups
 
BULK_GET - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
BULK_GET_KEYS - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
BULK_GET_KEYS_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
BULK_GET_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
BULK_READ - Enum constant in enum org.infinispan.persistence.spi.NonBlockingStore.Characteristic
If this store supports bulk read operations.
BULK_READ - Enum constant in enum org.infinispan.security.AuthorizationPermission
Allows bulk-read operations (e.g.
BULK_WRITE - Enum constant in enum org.infinispan.security.AuthorizationPermission
Allows bulk-write operations (e.g.
bulkGetKeysResponse(HotRodHeader, HotRodServer, Channel, CloseableIterator<byte[]>) - Method in class org.infinispan.server.hotrod.Encoder4x
 
bulkGetKeysResponse(HotRodHeader, HotRodServer, Channel, CloseableIterator<byte[]>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
 
bulkGetResponse(HotRodHeader, HotRodServer, Channel, int, CacheSet<Map.Entry<byte[], byte[]>>) - Method in class org.infinispan.server.hotrod.Encoder4x
 
bulkGetResponse(HotRodHeader, HotRodServer, Channel, int, CacheSet<Map.Entry<byte[], byte[]>>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
 
bulkUpdate(Publisher<MarshallableEntry<? extends K, ? extends V>>) - Method in interface org.infinispan.persistence.spi.CacheWriter
Deprecated.
Persist all provided entries to the store in chunks, with the size of each chunk determined by the store implementation.
bulkUpdate(Publisher<MarshallableEntry<? extends K, ? extends V>>) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
ByRef<T> - Class in org.infinispan.commons.util
This class can be used to pass an argument by reference.
ByRef(T) - Constructor for class org.infinispan.commons.util.ByRef
 
ByRef.Boolean - Class in org.infinispan.commons.util
Implementation for primitive type
ByRef.Integer - Class in org.infinispan.commons.util
 
ByRef.Long - Class in org.infinispan.commons.util
 
byte_(ByteBuf) - Static method in class org.infinispan.server.hotrod.Intrinsics
 
BYTE_ARRAY_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
Deprecated, for removal: This API element is subject to removal in a future version.
BYTE_ARRAY_WRAPPER - Static variable in interface org.infinispan.commons.dataconversion.WrapperIds
 
BYTE_BUFFER - Static variable in interface org.infinispan.commons.marshall.Ids
 
BYTE_STRING - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
ByteArrayWrapper - Class in org.infinispan.commons.dataconversion
Wraps byte[] on a WrappedByteArray to provide equality and hashCode support, leaving other objects unchanged.
ByteArrayWrapper() - Constructor for class org.infinispan.commons.dataconversion.ByteArrayWrapper
 
ByteBufContentSource - Class in org.infinispan.rest
 
ByteBuffer - Interface in org.infinispan.commons.io
A byte buffer that exposes the internal byte array with minimal copying.
ByteBufferFactory - Interface in org.infinispan.commons.io
Used for building instances of ByteBuffer.
ByteBufferFactoryImpl - Class in org.infinispan.commons.io
 
ByteBufferFactoryImpl() - Constructor for class org.infinispan.commons.io.ByteBufferFactoryImpl
 
ByteBufferImpl - Class in org.infinispan.commons.io
A byte buffer that exposes the internal byte array with minimal copying
ByteBufferImpl.Externalizer - Class in org.infinispan.commons.io
 
ByteQuantity - Class in org.infinispan.commons.util
Parser human-readable quantity of bytes.
ByteQuantity() - Constructor for class org.infinispan.commons.util.ByteQuantity
 
BYTES - Enum constant in enum org.infinispan.commons.util.MemoryUnit
Deprecated.
 
BYTES - Enum constant in enum org.infinispan.persistence.sql.AbstractSchemaJdbcStore.ProtostreamFieldType
 
bytes2obj(Marshaller, byte[], boolean, ClassAllowList) - Static method in class org.infinispan.client.hotrod.marshall.MarshallerUtil
 
BytesOnlyMarshaller - Class in org.infinispan.client.hotrod.marshall
Marshaller that only supports byte[] instances writing them as is
bytesToHex(byte[]) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
Deprecated, for removal: This API element is subject to removal in a future version.
bytesToKey(byte[], ClassAllowList) - Method in interface org.infinispan.client.hotrod.marshall.MediaTypeMarshaller
Unmarshall the byte array into the object form.
bytesToValue(byte[], ClassAllowList) - Method in interface org.infinispan.client.hotrod.marshall.MediaTypeMarshaller
Unmarshall the byte array into the object form.
ByteString - Class in org.infinispan.util
A simple class which encapsulates a byte[] representation of a String using a predefined encoding (currently UTF-8).
ByteString$___Marshaller_8e599c0fc1e9a512b7cdb7c05fb5529744ecac265708e69fd30c5e989237252a - Class in org.infinispan.util
WARNING: Generated code! Do not edit!
ByteString$___Marshaller_8e599c0fc1e9a512b7cdb7c05fb5529744ecac265708e69fd30c5e989237252a() - Constructor for class org.infinispan.util.ByteString$___Marshaller_8e599c0fc1e9a512b7cdb7c05fb5529744ecac265708e69fd30c5e989237252a
 
BZLIB2 - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.CompressionType
 

C

cache - Variable in class org.infinispan.cache.impl.AbstractCacheBackedSet
 
cache - Variable in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
cache - Variable in class org.infinispan.cache.impl.AbstractDelegatingCache
 
cache - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
cache - Variable in class org.infinispan.interceptors.BaseCustomAsyncInterceptor
 
cache - Variable in class org.infinispan.query.impl.IndexedQueryImpl
 
cache - Variable in class org.infinispan.reactive.publisher.impl.LocalPublisherManagerImpl
 
cache - Variable in class org.infinispan.reactive.publisher.impl.PartitionAwareClusterPublisherManager
 
cache - Variable in class org.infinispan.rest.resources.CacheResourceV2.BaseCacheListener
 
cache - Variable in class org.infinispan.server.core.CacheInfo
 
cache - Variable in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository
 
cache() - Method in interface org.infinispan.functional.FunctionalMap
 
cache() - Method in class org.infinispan.functional.impl.ReadOnlyMapImpl
 
cache() - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
 
cache() - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
cache() - Method in class org.infinispan.functional.impl.FunctionalMapImpl
 
cache(String) - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
cache(Cache<?, ?>) - Method in class org.infinispan.tasks.TaskContext
The cache against which this task will be executed.
cache(HotRodServer.ExtendedCacheInfo, HotRodHeader, Subject) - Method in class org.infinispan.server.hotrod.HotRodServer
 
Cache<K,V> - Interface in org.infinispan
The central interface of Infinispan.
CACHE - Enum constant in enum org.infinispan.configuration.parsing.ParserScope
The cache scope
CACHE - Enum constant in enum org.infinispan.persistence.remote.configuration.Element
 
CACHE - Enum constant in enum org.infinispan.security.AuditContext
 
CACHE_BACKUP_ENTRY - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
CACHE_BI_CONSUMERS - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_CONFIGURATION - Static variable in class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
 
CACHE_CONFIGURATION_SUFFIX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
CACHE_CONFIGURATION_URI_SUFFIX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
CACHE_CONTAINER - Enum constant in enum org.infinispan.configuration.parsing.Element
 
CACHE_CONTAINER - Enum constant in enum org.infinispan.configuration.parsing.ParserScope
The cache-container scope
CACHE_CONTROL_HEADER - Enum constant in enum org.infinispan.rest.RequestHeader
 
CACHE_CONTROL_HEADER - Enum constant in enum org.infinispan.rest.ResponseHeader
 
CACHE_CREATE - Enum constant in enum org.infinispan.server.core.admin.AdminOperation
 
CACHE_DEPENDENCY_GRAPH - Static variable in class org.infinispan.factories.KnownComponentNames
 
CACHE_DISTRIBUTION_INFO - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
CACHE_DISTRIBUTION_RUNNABLE - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
CACHE_ENTRY_ACTIVATED - Enum constant in enum org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_ENTRY_CREATED - Enum constant in enum org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_ENTRY_CREATED_EVENT - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
CACHE_ENTRY_EVICTED - Enum constant in enum org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_ENTRY_EXPIRED - Enum constant in enum org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_ENTRY_EXPIRED_EVENT - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
CACHE_ENTRY_GROUP_PREDICATE - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_ENTRY_INVALIDATED - Enum constant in enum org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_ENTRY_LOADED - Enum constant in enum org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_ENTRY_MODIFIED - Enum constant in enum org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_ENTRY_MODIFIED_EVENT - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
CACHE_ENTRY_PASSIVATED - Enum constant in enum org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_ENTRY_REMOVED - Enum constant in enum org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_ENTRY_REMOVED_EVENT - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
CACHE_ENTRY_VISITED - Enum constant in enum org.infinispan.notifications.cachelistener.event.Event.Type
 
CACHE_EVENT_CONVERTER_AS_CONVERTER - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_EVENT_FILTER_AS_KEY_VALUE_FILTER - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_EVENT_FILTER_CONVERTER_AS_KEY_VALUE_FILTER_CONVERTER - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_FILTERS - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_FORCE_RETURN_VALUES_SUFFIX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
CACHE_JOIN_INFO - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_MANAGER_TAG_NAME - Static variable in interface org.infinispan.metrics.Constants
 
CACHE_MARSHALLER - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
CACHE_MODE_LOCAL - Enum constant in enum org.infinispan.context.Flag
Forces LOCAL mode operation, even if the cache is configured to use a clustered mode like replication, invalidation or distribution.
CACHE_MODE_LOCAL - Static variable in class org.infinispan.context.impl.FlagBitSets
 
CACHE_NAME - Enum constant in enum org.infinispan.server.core.admin.AdminOperationParameter
 
CACHE_NAME - Static variable in class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
 
CACHE_NAME - Static variable in class org.infinispan.factories.KnownComponentNames
 
CACHE_NEAR_CACHE_BLOOM_FILTER_SUFFIX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
CACHE_NEAR_CACHE_FACTORY_SUFFIX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
CACHE_NEAR_CACHE_MAX_ENTRIES_SUFFIX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
CACHE_NEAR_CACHE_MODE_SUFFIX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
CACHE_NOT_FOUND_RESPONSE - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_PREFIX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
CACHE_REMOVE - Enum constant in enum org.infinispan.server.core.admin.AdminOperation
 
CACHE_RPC_COMMAND - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_SCOPE - Static variable in class org.infinispan.globalstate.impl.GlobalConfigurationManagerImpl
 
CACHE_SIZE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
CACHE_SIZE - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.Attribute
 
CACHE_SIZE - Static variable in class org.infinispan.configuration.global.GlobalSecurityConfiguration
 
CACHE_STARTED - Enum constant in enum org.infinispan.notifications.cachemanagerlistener.event.Event.Type
 
CACHE_STATE - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_STATUS_RESPONSE - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_STOP_TIMEOUT - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
 
CACHE_STOPPED - Enum constant in enum org.infinispan.notifications.cachemanagerlistener.event.Event.Type
 
CACHE_STOPPED_TOPOLOGY_ID - Static variable in class org.infinispan.transaction.impl.TransactionTable
 
CACHE_STREAM_INTERMEDIATE_PUBLISHER - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_STREAM_INTERMEDIATE_REDUCER - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_SYNC - Static variable in class org.infinispan.configuration.cache.ClusteringConfiguration
 
CACHE_TAG_NAME - Static variable in interface org.infinispan.metrics.Constants
 
CACHE_TEMPLATE - Enum constant in enum org.infinispan.configuration.parsing.ParserScope
The cache template scope
CACHE_TEMPLATE - Enum constant in enum org.infinispan.server.core.admin.AdminOperationParameter
 
CACHE_TEMPLATE - Static variable in class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
 
CACHE_TEMPLATE_NAME_SUFFIX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
CACHE_TIMEOUT - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
CACHE_TIMEOUT - Static variable in class org.infinispan.configuration.global.GlobalSecurityConfiguration
 
CACHE_TOPOLOGY - Static variable in interface org.infinispan.commons.marshall.Ids
 
CACHE_TRANSACTION_MANAGER_LOOKUP_SUFFIX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
CACHE_TRANSACTION_MODE_SUFFIX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
CACHE_TYPE - Static variable in class org.infinispan.configuration.cache.ClusteringConfiguration
 
CACHE_XID - Static variable in class org.infinispan.server.core.ExternalizerIds
 
CacheAware<K,V> - Interface in org.infinispan.stream
Interface that describes how a cache can be injected into another object.
CacheBackedEntrySet<K,V> - Class in org.infinispan.cache.impl
Entry set backed by a cache.
CacheBackedEntrySet(CacheImpl<K, V>, Object, long) - Constructor for class org.infinispan.cache.impl.CacheBackedEntrySet
 
CacheBackedKeySet<K,V> - Class in org.infinispan.cache.impl
Key set backed by a cache.
CacheBackedKeySet(CacheImpl<K, V>, Object, long) - Constructor for class org.infinispan.cache.impl.CacheBackedKeySet
 
CacheBackpressureFullException - Exception Class in org.infinispan.commons.util.concurrent
A CacheException that is thrown when the backpressure has been filled an unable to process the request.
CacheBackpressureFullException() - Constructor for exception class org.infinispan.commons.util.concurrent.CacheBackpressureFullException
 
CacheBackupEntry() - Constructor for class org.infinispan.server.core.backup.resources.CacheResource.CacheBackupEntry
 
CacheBackupEntry$___Marshaller_b2d0dee2aac68dcec862a9e304f7e24daf8a89e2925ed0f1902a4f7e597df134 - Class in org.infinispan.server.core.backup.resources
WARNING: Generated code! Do not edit!
CacheBackupEntry$___Marshaller_b2d0dee2aac68dcec862a9e304f7e24daf8a89e2925ed0f1902a4f7e597df134() - Constructor for class org.infinispan.server.core.backup.resources.CacheBackupEntry$___Marshaller_b2d0dee2aac68dcec862a9e304f7e24daf8a89e2925ed0f1902a4f7e597df134
 
CacheBiConsumers - Class in org.infinispan.stream.impl
 
CacheBiConsumers.Externalizer - Class in org.infinispan.stream.impl
 
CacheChunkedStream<T> - Class in org.infinispan.rest.stream
 
CacheChunkedStream(Publisher<T>) - Constructor for class org.infinispan.rest.stream.CacheChunkedStream
 
CacheCollection<E> - Interface in org.infinispan
A collection type that returns special Cache based streams that have additional options to tweak behavior.
CacheCollectors - Class in org.infinispan.stream
Helper class designed to be used to create a serializable Collector for use with CacheStream.collect(Collector) from a supplier of a collector.
cacheCompareWrongContent() - Method in interface org.infinispan.rest.logging.Log
 
cacheComponents() - Method in class org.infinispan.factories.ComponentRegistry
Invoked last after all services are wired
cacheConfiguration - Variable in class org.infinispan.interceptors.BaseAsyncInterceptor
 
cacheConfiguration - Variable in class org.infinispan.server.memcached.MemcachedDecoder
 
CacheConfigurationException - Exception Class in org.infinispan.commons
An exception that represents an error in the configuration.
CacheConfigurationException(Exception) - Constructor for exception class org.infinispan.commons.CacheConfigurationException
 
CacheConfigurationException(String) - Constructor for exception class org.infinispan.commons.CacheConfigurationException
 
CacheConfigurationException(String, String) - Constructor for exception class org.infinispan.commons.CacheConfigurationException
Deprecated, for removal: This API element is subject to removal in a future version.
CacheConfigurationException(String, Throwable) - Constructor for exception class org.infinispan.commons.CacheConfigurationException
 
CacheConfigurationMBean - Class in org.infinispan.cache.impl
CacheConfigurationMBeanImpl.
CacheConfigurationMBean() - Constructor for class org.infinispan.cache.impl.CacheConfigurationMBean
 
cacheContainer() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
CacheContainer - Interface in org.infinispan.manager
 
CacheContainerAdmin<C,A> - Interface in org.infinispan.commons.api
Administrative cache container operations.
CacheContainerAdmin.AdminFlag - Enum in org.infinispan.commons.api
Flags which affect only administrative operations
CacheContainerConfigurationBuilder - Class in org.infinispan.configuration.global
 
CacheContainerStats - Interface in org.infinispan.stats
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.1.3. This mixes statistics across unrelated caches so the reported numbers don't have too much relevance. Please use Stats or ClusterCacheStats instead.
CacheContainerStatsImpl - Class in org.infinispan.stats.impl
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.1.3. This mixes statistics across unrelated caches so the reported numbers don't have too much relevance. Please use Stats or ClusterCacheStats instead.
CacheContainerStatsImpl(EmbeddedCacheManager) - Constructor for class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
cacheControl(CacheControl) - Method in interface org.infinispan.rest.framework.impl.RestResponseBuilder
 
cacheControl(CacheControl) - Method in class org.infinispan.rest.framework.impl.SimpleRestResponse.Builder
 
cacheControl(CacheControl) - Method in class org.infinispan.rest.NettyRestResponse.Builder
 
CacheControl - Class in org.infinispan.rest
A helper class for controlling Cache Control headers.
CacheCreateTask - Class in org.infinispan.server.core.admin.embeddedserver
Admin operation to create a cache Parameters: name the name of the cache to create flags any flags, e.g.
CacheCreateTask() - Constructor for class org.infinispan.server.core.admin.embeddedserver.CacheCreateTask
 
CACHED_THREAD_POOL - Enum constant in enum org.infinispan.configuration.parsing.Element
 
CACHED_VALUES - Static variable in enum org.infinispan.functional.Param.ReplicationMode
 
CacheDistributionInfo - Class in org.infinispan.rest.distribution
 
CacheDistributionInfo(String, List<String>, long, long, long) - Constructor for class org.infinispan.rest.distribution.CacheDistributionInfo
 
CacheDistributionInfo$___Marshaller_d29d2c8791a59bb0952e36da57e31d3d06e79a149845ac44d334bd095efcb62c - Class in org.infinispan.rest.distribution
WARNING: Generated code! Do not edit!
CacheDistributionInfo$___Marshaller_d29d2c8791a59bb0952e36da57e31d3d06e79a149845ac44d334bd095efcb62c() - Constructor for class org.infinispan.rest.distribution.CacheDistributionInfo$___Marshaller_d29d2c8791a59bb0952e36da57e31d3d06e79a149845ac44d334bd095efcb62c
 
CacheDistributionRunnable - Class in org.infinispan.rest.distribution
 
CacheDistributionRunnable(String) - Constructor for class org.infinispan.rest.distribution.CacheDistributionRunnable
 
CacheDistributionRunnable$___Marshaller_45f1040aff503b6010c6b926057475925f0a64804eab6e8f0d6f4ba5ddce3a36 - Class in org.infinispan.rest.distribution
WARNING: Generated code! Do not edit!
CacheDistributionRunnable$___Marshaller_45f1040aff503b6010c6b926057475925f0a64804eab6e8f0d6f4ba5ddce3a36() - Constructor for class org.infinispan.rest.distribution.CacheDistributionRunnable$___Marshaller_45f1040aff503b6010c6b926057475925f0a64804eab6e8f0d6f4ba5ddce3a36
 
cacheDoesNotSupportTransactions(String) - Method in interface org.infinispan.client.hotrod.logging.Log
 
CachedThreadPoolConfigurationBuilder - Class in org.infinispan.configuration.global
 
CachedThreadPoolExecutorFactory - Enum in org.infinispan.commons.executors
 
cachedThreadPools() - Method in class org.infinispan.configuration.global.ThreadsConfiguration
 
CacheEntriesEvicted - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when cache entries are evicted.
CacheEntriesEvictedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
This event subtype is passed in to any method annotated with CacheEntriesEvicted.
CacheEntry<K,V> - Interface in org.infinispan.container.entries
An entry that is stored in the data container
CacheEntryActivated - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when a cache entry is activated.
CacheEntryActivatedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
This event subtype is passed in to any method annotated with CacheEntryActivated.
CacheEntryChange() - Constructor for class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntryChange
 
CacheEntryCreated - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when a cache entry is created.
CacheEntryCreatedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
This event subtype is passed in to any method annotated with CacheEntryCreated.
CacheEntryEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
A transactional event subtype that additionally expose a key as such events pertain to a specific cache entry.
CacheEntryExpired - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when a cache entry is expired
CacheEntryExpiredEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
This event subtype is passed in to any method annotated with CacheEntryExpired.
CacheEntryGroupPredicate<K> - Class in org.infinispan.distribution.group.impl
Tests if a CacheEntry belongs to a group.
CacheEntryGroupPredicate(String) - Constructor for class org.infinispan.distribution.group.impl.CacheEntryGroupPredicate
 
CacheEntryInvalidated - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when a cache entry is invalidated.
CacheEntryInvalidatedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
Notifies a listener of an invalidation event.
CacheEntryListenerInvocation<K,V> - Interface in org.infinispan.notifications.cachelistener
Additional listener methods specific to caches.
CacheEntryLoaded - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when a cache entry is loaded from a CacheLoader.
CacheEntryLoadedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
This event subtype is passed in to any method annotated with CacheEntryLoaded.
CacheEntryModified - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when a cache entry has been modified.
CacheEntryModifiedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
This event subtype is passed in to any method annotated with CacheEntryModified
CacheEntryPassivated - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when cache entries are passivated.
CacheEntryPassivatedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
This event subtype is passed in to any method annotated with CacheEntryPassivated.
CacheEntryRemoved - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when a cache entry is removed from the cache.
CacheEntryRemovedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
This event subtype is passed in to any method annotated with CacheEntryRemoved.
cacheEntrySet() - Method in interface org.infinispan.AdvancedCache
Identical to Cache.entrySet() but is typed to return CacheEntries instead of Entries.
cacheEntrySet() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
cacheEntrySet() - Method in class org.infinispan.cache.impl.CacheImpl
 
cacheEntrySet() - Method in class org.infinispan.cache.impl.DecoratedCache
 
cacheEntrySet() - Method in class org.infinispan.cache.impl.EncoderCache
 
cacheEntrySet() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
cacheEntrySet() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
CacheEntrySet() - Constructor for class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntrySet
 
CacheEntrySizeCalculator<K,V> - Class in org.infinispan.container.entries
Implementation of a size calculator that calculates only the size of the value assuming it is an InternalCacheEntry.
CacheEntrySizeCalculator(EntrySizeCalculator<? super K, ? super V>) - Constructor for class org.infinispan.container.entries.CacheEntrySizeCalculator
 
CacheEntryStreamProcessor - Class in org.infinispan.rest.stream
A CacheChunkedStream that reads Map.Entry and produces a JSON output.
CacheEntryStreamProcessor(Publisher<CacheEntry<?, ?>>, boolean, boolean, boolean) - Constructor for class org.infinispan.rest.stream.CacheEntryStreamProcessor
 
CacheEntryVisited - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when a cache entry is visited.
CacheEntryVisitedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
This event subtype is passed in to any method annotated with CacheEntryVisited.
CacheEventConverter<K,V,C> - Interface in org.infinispan.notifications.cachelistener.filter
A converter that can be used to convert the value given for an event.
CacheEventConverterAsConverter<K,V,C> - Class in org.infinispan.notifications.cachelistener.filter
Converter that is implemented by using the provided CacheEventConverter.
CacheEventConverterAsConverter(CacheEventConverter<K, V, C>) - Constructor for class org.infinispan.notifications.cachelistener.filter.CacheEventConverterAsConverter
 
CacheEventConverterAsConverter.Externalizer - Class in org.infinispan.notifications.cachelistener.filter
 
CacheEventConverterFactory - Interface in org.infinispan.notifications.cachelistener.filter
Factory that can produce CacheEventConverters
CacheEventFilter<K,V> - Interface in org.infinispan.notifications.cachelistener.filter
A filter that can be used to tell if an event should be raised or not.
CacheEventFilterAsKeyValueFilter<K,V> - Class in org.infinispan.notifications.cachelistener.filter
KeyValueFilter that is implemented by using the provided CacheEventFilter.
CacheEventFilterAsKeyValueFilter(CacheEventFilter<K, V>) - Constructor for class org.infinispan.notifications.cachelistener.filter.CacheEventFilterAsKeyValueFilter
 
CacheEventFilterAsKeyValueFilter.Externalizer - Class in org.infinispan.notifications.cachelistener.filter
 
CacheEventFilterConverter<K,V,C> - Interface in org.infinispan.notifications.cachelistener.filter
This interface is an optimization that can be used when an event filter and converter are most efficiently used as the same object composing the filtering and conversion in the same method invocation.
CacheEventFilterConverterAsKeyValueFilterConverter<K,V,C> - Class in org.infinispan.notifications.cachelistener.filter
 
CacheEventFilterConverterAsKeyValueFilterConverter(CacheEventFilterConverter<K, V, C>) - Constructor for class org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverterAsKeyValueFilterConverter
 
CacheEventFilterConverterAsKeyValueFilterConverter.Externalizer - Class in org.infinispan.notifications.cachelistener.filter
 
CacheEventFilterConverterFactory - Interface in org.infinispan.notifications.cachelistener.filter
Factory that can produce CacheEventFilterConverter instances.
CacheEventFilterFactory - Interface in org.infinispan.notifications.cachelistener.filter
Factory that can produce CacheEventFilters
CacheException - Exception Class in org.infinispan.commons
Thrown when operations fail unexpectedly.
CacheException() - Constructor for exception class org.infinispan.commons.CacheException
 
CacheException(String) - Constructor for exception class org.infinispan.commons.CacheException
 
CacheException(String, Throwable) - Constructor for exception class org.infinispan.commons.CacheException
 
CacheException(String, Throwable, boolean, boolean) - Constructor for exception class org.infinispan.commons.CacheException
 
CacheException(Throwable) - Constructor for exception class org.infinispan.commons.CacheException
 
cacheExceptionWrapper() - Static method in class org.infinispan.commons.reactive.RxJavaInterop
 
cacheExists(String) - Method in class org.infinispan.manager.DefaultCacheManager
 
cacheExists(String) - Method in interface org.infinispan.manager.EmbeddedCacheManager
A cache is considered to exist if it has been created and started via one of the EmbeddedCacheManager.getCache() methods and has not yet been removed via EmbeddedCacheManager.removeCache(String).
cacheExists(String) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
CacheFilters - Class in org.infinispan.filter
Static factory class that contains utility methods that can be used for performing proper transformations from KeyValueFilter, Converter and KeyValueFilterConverter to appropriate distributed stream instances.
CacheFilters.CacheFiltersExternalizer - Class in org.infinispan.filter
 
CacheFiltersExternalizer() - Constructor for class org.infinispan.filter.CacheFilters.CacheFiltersExternalizer
 
CacheGetOrCreateTask - Class in org.infinispan.server.core.admin.embeddedserver
Admin operation to create a cache Parameters: name the name of the cache to create template the name of the template to use configuration the XML configuration to use flags any flags, e.g.
CacheGetOrCreateTask() - Constructor for class org.infinispan.server.core.admin.embeddedserver.CacheGetOrCreateTask
 
CacheHealth - Interface in org.infinispan.health
Cache health information.
CacheImpl<K,V> - Class in org.infinispan.cache.impl
 
CacheImpl(String) - Constructor for class org.infinispan.cache.impl.CacheImpl
 
CacheInfo<K,V> - Class in org.infinispan.server.core
 
CacheInfo(AdvancedCache<K, V>) - Constructor for class org.infinispan.server.core.CacheInfo
 
CacheIntermediatePublisher<R> - Class in org.infinispan.stream.impl
Function that is used to encapsulate multiple intermediate operations and perform them lazily when the function is applied.
CacheIntermediatePublisher(Iterable<IntermediateOperation<?, ?, ?, ?>>) - Constructor for class org.infinispan.stream.impl.CacheIntermediatePublisher
 
CacheIntermediatePublisher.ReducerExternalizer - Class in org.infinispan.stream.impl
 
CacheInvocationBuilder() - Constructor for class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
cacheIsStoppingNoCommandAllowed(String) - Method in interface org.infinispan.query.logging.Log
 
CacheJmxRegistration - Class in org.infinispan.jmx
If Configuration.statistics() is enabled, then class will register all the MBeans from cache local's ConfigurationRegistry to the MBean server.
CacheJmxRegistration() - Constructor for class org.infinispan.jmx.CacheJmxRegistration
 
CacheJoinException - Exception Class in org.infinispan.topology
Thrown when a cache fails to join a cluster
CacheJoinException() - Constructor for exception class org.infinispan.topology.CacheJoinException
 
CacheJoinException(String) - Constructor for exception class org.infinispan.topology.CacheJoinException
 
CacheJoinException(String, Throwable) - Constructor for exception class org.infinispan.topology.CacheJoinException
 
CacheJoinException(Throwable) - Constructor for exception class org.infinispan.topology.CacheJoinException
 
CacheJoinInfo - Class in org.infinispan.topology
This class contains the information that a cache needs to supply to the coordinator when starting up.
CacheJoinInfo(ConsistentHashFactory, int, int, long, CacheMode, float, PersistentUUID, Optional<Integer>) - Constructor for class org.infinispan.topology.CacheJoinInfo
 
CacheJoinInfo.Externalizer - Class in org.infinispan.topology
 
CacheKeyStreamProcessor - Class in org.infinispan.rest.stream
A CacheChunkedStream that reads from a byte[] and produces a JSON output.
CacheKeyStreamProcessor(Publisher<byte[]>) - Constructor for class org.infinispan.rest.stream.CacheKeyStreamProcessor
 
CacheListenerException - Exception Class in org.infinispan.commons
Wraps exceptions produced by listener implementations.
CacheListenerException() - Constructor for exception class org.infinispan.commons.CacheListenerException
 
CacheListenerException(String) - Constructor for exception class org.infinispan.commons.CacheListenerException
 
CacheListenerException(String, Throwable) - Constructor for exception class org.infinispan.commons.CacheListenerException
 
CacheListenerException(Throwable) - Constructor for exception class org.infinispan.commons.CacheListenerException
 
CacheLoader<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
cacheManager - Variable in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
 
cacheManager - Variable in class org.infinispan.server.core.AbstractProtocolServer
 
cacheManager - Variable in class org.infinispan.server.hotrod.HotRodDecoder
 
cacheManager(EmbeddedCacheManager) - Method in class org.infinispan.tasks.TaskContext
The cache manager with which this task should be executed
CACHEMANAGER - Enum constant in enum org.infinispan.security.AuditContext
 
CacheManagerInfo - Class in org.infinispan.manager
 
CacheManagerInfo(DefaultCacheManager, ConfigurationManager, InternalCacheRegistry, LocalTopologyManager) - Constructor for class org.infinispan.manager.CacheManagerInfo
 
CacheManagerJmxRegistration - Class in org.infinispan.jmx
Registers all the components from global component registry to the mbean server.
CacheManagerJmxRegistration() - Constructor for class org.infinispan.jmx.CacheManagerJmxRegistration
 
cacheManagerName() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
cacheManagerName() - Method in class org.infinispan.configuration.global.GlobalJmxConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.1. please use GlobalConfiguration.cacheManagerName() instead.
cacheManagerName() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.1. please use GlobalConfiguration.cacheManagerName() instead.
cacheManagerName(String) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
cacheManagerName(String) - Method in class org.infinispan.configuration.global.GlobalJmxConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
cacheManagerName(String) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
cacheManagerNames() - Method in interface org.infinispan.server.core.ServerManagement
Deprecated, for removal: This API element is subject to removal in a future version.
Multiple Cache Managers are not supported in the server
cacheManagerNotifier - Variable in class org.infinispan.cache.impl.CacheImpl
 
CacheManagerNotifier - Interface in org.infinispan.notifications.cachemanagerlistener
Notifications for the cache manager
CacheManagerNotifierImpl - Class in org.infinispan.notifications.cachemanagerlistener
Global, shared notifications on the cache manager.
CacheManagerNotifierImpl() - Constructor for class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
CacheManagerNotifierImpl.DefaultBuilder - Class in org.infinispan.notifications.cachemanagerlistener
 
cacheManagerStarted(GlobalComponentRegistry) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheManagerStarted(GlobalComponentRegistry) - Method in class org.infinispan.query.impl.LifecycleManager
 
cacheManagerStarted(GlobalComponentRegistry) - Method in class org.infinispan.server.hotrod.LifecycleCallbacks
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.counter.impl.CounterModuleLifecycle
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.jboss.marshalling.JbossMarshallingModule
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.lock.impl.ClusteredLockModuleLifecycle
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.multimap.impl.MultimapModuleLifecycle
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.persistence.remote.LifecycleCallbacks
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.query.impl.LifecycleManager
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.rest.LifecycleCallbacks
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.server.core.LifecycleCallbacks
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.server.hotrod.LifecycleCallbacks
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.server.memcached.LifecycleCallbacks
 
cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.spring.embedded.SpringEmbeddedModule
 
cacheManagerStopped(GlobalComponentRegistry) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheManagerStopping(GlobalComponentRegistry) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
CacheMixedSiteStatus - Class in org.infinispan.xsite.status
A mixed SiteStatus.
CacheMixedSiteStatus(List<Address>, List<Address>) - Constructor for class org.infinispan.xsite.status.CacheMixedSiteStatus
 
cacheMode() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
Cache mode.
cacheMode() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
cacheMode(CacheMode) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
Cache mode.
CacheMode - Enum in org.infinispan.configuration.cache
Cache replication mode.
cacheModeString() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
 
cacheName - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
cacheName - Variable in class org.infinispan.transaction.xa.XaTransactionTable
 
cacheName - Variable in class org.infinispan.xsite.commands.remote.XSiteCacheRequest
 
cacheName() - Method in class org.infinispan.rest.distribution.CacheDistributionRunnable
 
cacheName() - Element in annotation type org.infinispan.spring.embedded.session.configuration.EnableInfinispanEmbeddedHttpSession
Cache name used for storing session data.
cacheName() - Element in annotation type org.infinispan.spring.remote.session.configuration.EnableInfinispanRemoteHttpSession
Cache name used for storing session data.
cacheNameBytes() - Static method in class org.infinispan.client.hotrod.RemoteCacheManager
 
cacheNameBytes(String) - Static method in class org.infinispan.client.hotrod.RemoteCacheManager
 
CacheNameCollector - Interface in org.infinispan.server.hotrod.tx.table
Used by GlobalTxTable, it collects all the involved cache name when setting a decision for a transaction.
cacheNamePattern() - Method in class org.infinispan.client.hotrod.configuration.NearCacheConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
cacheNamePattern(String) - Method in class org.infinispan.client.hotrod.configuration.NearCacheConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
cacheNamePattern(Pattern) - Method in class org.infinispan.client.hotrod.configuration.NearCacheConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
CacheNamesTask - Class in org.infinispan.server.core.admin.embeddedserver
Admin operation to obtain a list of caches
CacheNamesTask() - Constructor for class org.infinispan.server.core.admin.embeddedserver.CacheNamesTask
 
cacheNotFound(String) - Method in interface org.infinispan.rest.logging.Log
 
CacheNotFoundException - Exception Class in org.infinispan.rest.cachemanager.exceptions
 
CacheNotFoundException(String) - Constructor for exception class org.infinispan.rest.cachemanager.exceptions.CacheNotFoundException
 
CacheNotFoundResponse - Class in org.infinispan.remoting.responses
A response that signals the named cache is not running on the target node.
CacheNotFoundResponse.Externalizer - Class in org.infinispan.remoting.responses
 
cacheNotifier - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
CacheNotifier<K,V> - Interface in org.infinispan.notifications.cachelistener
Public interface with all allowed notifications.
CacheNotifierImpl<K,V> - Class in org.infinispan.notifications.cachelistener
Helper class that handles all notifications to registered listeners.
CacheNotifierImpl() - Constructor for class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
CacheNotifierImpl.BaseCacheEntryListenerInvocation<K,V> - Class in org.infinispan.notifications.cachelistener
 
CacheNotifierImpl.CacheInvocationBuilder - Class in org.infinispan.notifications.cachelistener
 
CacheNotifierImpl.ClusteredListenerInvocation<K,V> - Class in org.infinispan.notifications.cachelistener
This class is to be used with cluster listener invocations only when they have included current state.
CacheNotifierImpl.DelegatingCacheInvocationBuilder - Class in org.infinispan.notifications.cachelistener
 
cacheNotIndexed(String) - Method in interface org.infinispan.rest.logging.Log
 
CacheNotTransactionalException - Exception Class in org.infinispan.client.hotrod.exceptions
When try to create a transactional org.infinispan.client.hotrod.RemoteCache but the cache in the Hot Rod server isn't transactional, this exception is thrown.
CacheNotTransactionalException() - Constructor for exception class org.infinispan.client.hotrod.exceptions.CacheNotTransactionalException
 
CacheNotTransactionalException(String) - Constructor for exception class org.infinispan.client.hotrod.exceptions.CacheNotTransactionalException
 
CacheNotTransactionalException(String, long, int) - Constructor for exception class org.infinispan.client.hotrod.exceptions.CacheNotTransactionalException
 
CacheNotTransactionalException(String, Throwable) - Constructor for exception class org.infinispan.client.hotrod.exceptions.CacheNotTransactionalException
 
CacheNotTransactionalException(Throwable) - Constructor for exception class org.infinispan.client.hotrod.exceptions.CacheNotTransactionalException
 
CacheParser - Class in org.infinispan.configuration.parsing
This class implements the parser for Infinispan/AS7/EAP/JDG schema files
CacheParser() - Constructor for class org.infinispan.configuration.parsing.CacheParser
 
CacheParser.Mode - Enum in org.infinispan.configuration.parsing
 
CacheParser.TransactionMode - Enum in org.infinispan.configuration.parsing
 
CachePermission - Class in org.infinispan.security
CachePermission.
CachePermission(String) - Constructor for class org.infinispan.security.CachePermission
 
CachePermission(AuthorizationPermission) - Constructor for class org.infinispan.security.CachePermission
 
CachePermissionCollection - Class in org.infinispan.security
CachePermissionCollection.
CachePermissionCollection() - Constructor for class org.infinispan.security.CachePermissionCollection
 
cacheProcessor - Variable in class org.infinispan.server.hotrod.HotRodDecoder
 
cacheRef - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
CacheReindexTask - Class in org.infinispan.server.core.admin.embeddedserver
Admin operation to reindex a cache Parameters: name the name of the cache to reindex flags unused
CacheReindexTask() - Constructor for class org.infinispan.server.core.admin.embeddedserver.CacheReindexTask
 
CacheRemoveTask - Class in org.infinispan.server.core.admin.embeddedserver
Admin operation to remove a cache Parameters: name the name of the cache to remove flags
CacheRemoveTask() - Constructor for class org.infinispan.server.core.admin.embeddedserver.CacheRemoveTask
 
CacheResource - Class in org.infinispan.server.core.backup.resources
CacheResource.CacheBackupEntry - Class in org.infinispan.server.core.backup.resources
ProtoStream entity used to represent individual cache entries.
CacheResourceV2 - Class in org.infinispan.rest.resources
REST resource to manage the caches.
CacheResourceV2(InvocationHelper, RestTelemetryService) - Constructor for class org.infinispan.rest.resources.CacheResourceV2
 
CacheResourceV2.BaseCacheListener - Class in org.infinispan.rest.resources
 
CacheResourceV2.StatefulCacheListener - Class in org.infinispan.rest.resources
 
CacheResourceV2.StatelessCacheListener - Class in org.infinispan.rest.resources
 
CacheRoleImpl - Class in org.infinispan.security.impl
CacheRoleImpl.
CacheRoleImpl(String, boolean, Set<AuthorizationPermission>) - Constructor for class org.infinispan.security.impl.CacheRoleImpl
 
CacheRoleImpl(String, boolean, AuthorizationPermission...) - Constructor for class org.infinispan.security.impl.CacheRoleImpl
 
CacheRoleImpl$___Marshaller_8ebe2292503551beeebd9f0cc1e432a19521b4115fff99f8859a58acb74d6d74 - Class in org.infinispan.security.impl
WARNING: Generated code! Do not edit!
CacheRoleImpl$___Marshaller_8ebe2292503551beeebd9f0cc1e432a19521b4115fff99f8859a58acb74d6d74() - Constructor for class org.infinispan.security.impl.CacheRoleImpl$___Marshaller_8ebe2292503551beeebd9f0cc1e432a19521b4115fff99f8859a58acb74d6d74
 
CacheRpcCommandExternalizer - Class in org.infinispan.marshall.exts
Externalizer in charge of marshalling cache specific commands.
CacheRpcCommandExternalizer(GlobalComponentRegistry, ReplicableCommandExternalizer) - Constructor for class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
 
CACHES - Enum constant in enum org.infinispan.configuration.parsing.Element
 
CACHES - Enum constant in enum org.infinispan.server.core.BackupManager.Resources.Type
 
CacheSet<E> - Interface in org.infinispan
A set that also must implement the various CacheCollection methods for streams.
CacheSetMapper<E,R> - Class in org.infinispan.util
A CacheSet that allows for a different set to be mapped as a different instance wtih values replaced on request.
CacheSetMapper(CacheSet<E>, Function<? super E, ? extends R>) - Constructor for class org.infinispan.util.CacheSetMapper
 
cacheShutdown(String) - Method in interface org.infinispan.topology.LocalTopologyManager
Initiates a cluster-wide cache shutdown for the specified cache
cacheShutdown(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
CacheSiteStatusBuilder - Class in org.infinispan.xsite.status
A per-cache SiteStatus builder.
CacheSiteStatusBuilder() - Constructor for class org.infinispan.xsite.status.CacheSiteStatusBuilder
 
cacheSize() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfiguration
 
cacheSize(long) - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
 
cacheStarted(ComponentRegistry, String) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheStarted(ComponentRegistry, String) - Method in class org.infinispan.query.impl.LifecycleManager
 
CacheStarted - Annotation Type in org.infinispan.notifications.cachemanagerlistener.annotation
This annotation should be used on methods that need to be notified when a cache is started.
CacheStartedEvent - Interface in org.infinispan.notifications.cachemanagerlistener.event
This event is passed in to any method annotated with CacheStarted.
cacheStarting(ComponentRegistry, Configuration, String) - Method in class org.infinispan.counter.impl.CounterModuleLifecycle
 
cacheStarting(ComponentRegistry, Configuration, String) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheStarting(ComponentRegistry, Configuration, String) - Method in class org.infinispan.query.impl.LifecycleManager
Registers the Search interceptor in the cache before it gets started
cacheStarting(ComponentRegistry, Configuration, String) - Method in class org.infinispan.server.hotrod.LifecycleCallbacks
 
CacheState - Class in org.infinispan.globalstate.impl
Cache State information stored in a cluster-wide cache
CacheState(String, String, EnumSet<CacheContainerAdmin.AdminFlag>) - Constructor for class org.infinispan.globalstate.impl.CacheState
 
CacheState.Externalizer - Class in org.infinispan.globalstate.impl
 
CacheStatisticCollector - Class in org.infinispan.extendedstats
Collects and maintains all the statistics for a cache.
CacheStatisticCollector(TimeService) - Constructor for class org.infinispan.extendedstats.CacheStatisticCollector
 
CacheStatisticManager - Class in org.infinispan.extendedstats
Manages all the statistics for a single cache.
CacheStatisticManager(Configuration, TimeService) - Constructor for class org.infinispan.extendedstats.CacheStatisticManager
 
CacheStatusResponse - Class in org.infinispan.topology
 
CacheStatusResponse(CacheJoinInfo, CacheTopology, CacheTopology, AvailabilityMode, List<Address>) - Constructor for class org.infinispan.topology.CacheStatusResponse
 
CacheStatusResponse.Externalizer - Class in org.infinispan.topology
 
cacheStopped(ComponentRegistry, String) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheStopped(ComponentRegistry, String) - Method in class org.infinispan.query.impl.LifecycleManager
 
CacheStopped - Annotation Type in org.infinispan.notifications.cachemanagerlistener.annotation
This annotation should be used on methods that need to be notified when a cache is stopped.
CacheStoppedEvent - Interface in org.infinispan.notifications.cachemanagerlistener.event
This event is passed in to any method annotated with CacheStopped.
cacheStopping(ComponentRegistry, String) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
 
cacheStopping(ComponentRegistry, String) - Method in class org.infinispan.query.impl.LifecycleManager
 
cacheStopTimeout() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
If there are any ongoing transactions when a cache is stopped, Infinispan waits for ongoing remote and local transactions to finish.
cacheStopTimeout(long) - Method in class org.infinispan.configuration.cache.TransactionConfiguration
If there are any ongoing transactions when a cache is stopped, Infinispan waits for ongoing remote and local transactions to finish.
cacheStopTimeout(long) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
If there are any ongoing transactions when a cache is stopped, Infinispan waits for ongoing remote and local transactions to finish.
cacheStopTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
If there are any ongoing transactions when a cache is stopped, Infinispan waits for ongoing remote and local transactions to finish.
cacheStream() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
cacheStream() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
cacheStream() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
CacheStream<R> - Interface in org.infinispan
A Stream that has additional operations to monitor or control behavior when used from a Cache.
CacheStreamIntermediateReducer<R> - Class in org.infinispan.stream.impl
Reducer implementation for Distributed Publisher that converts between CacheStream operations to an appropriate Reducer
CacheStreamIntermediateReducer.ReducerExternalizer - Class in org.infinispan.stream.impl
 
CacheSubjectPair - Class in org.infinispan.security.impl
CachePrincipalPair.
cacheSync(boolean) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
CacheTopology - Class in org.infinispan.topology
The status of a cache from a distribution/state transfer point of view.
CacheTopology(int, int, boolean, ConsistentHash, ConsistentHash, ConsistentHash, CacheTopology.Phase, List<Address>, List<PersistentUUID>) - Constructor for class org.infinispan.topology.CacheTopology
 
CacheTopology(int, int, boolean, ConsistentHash, ConsistentHash, CacheTopology.Phase, List<Address>, List<PersistentUUID>) - Constructor for class org.infinispan.topology.CacheTopology
 
CacheTopology(int, int, ConsistentHash, ConsistentHash, ConsistentHash, CacheTopology.Phase, List<Address>, List<PersistentUUID>) - Constructor for class org.infinispan.topology.CacheTopology
 
CacheTopology(int, int, ConsistentHash, ConsistentHash, CacheTopology.Phase, List<Address>, List<PersistentUUID>) - Constructor for class org.infinispan.topology.CacheTopology
 
CacheTopology.Externalizer - Class in org.infinispan.topology
 
CacheTopology.Phase - Enum in org.infinispan.topology
Phase of the rebalance process.
CacheTopologyHandler - Interface in org.infinispan.topology
The link between LocalTopologyManager and StateTransferManager.
CacheTopologyInfo - Interface in org.infinispan.client.hotrod
Contains information about cache topology including servers and owned segments.
CacheTopologyInfoImpl - Class in org.infinispan.client.hotrod.impl
 
CacheTopologyInfoImpl(Map<SocketAddress, Set<Integer>>, Integer, Integer) - Constructor for class org.infinispan.client.hotrod.impl.CacheTopologyInfoImpl
 
CacheTopologyUtil - Enum in org.infinispan.util
Utility methods related to CacheTopology.
CacheTransaction - Interface in org.infinispan.transaction.xa
Defines the state a infinispan transaction should have.
CacheTransaction.TransactionCompletedListener - Interface in org.infinispan.transaction.xa
 
cacheType() - Method in enum org.infinispan.configuration.cache.CacheMode
 
cacheType(CacheType) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
CacheType - Enum in org.infinispan.configuration.cache
Cache replication mode.
cacheUnavailable(String) - Method in interface org.infinispan.rest.logging.Log
 
CacheUnavailableException - Exception Class in org.infinispan.rest.cachemanager.exceptions
 
CacheUnavailableException(String) - Constructor for exception class org.infinispan.rest.cachemanager.exceptions.CacheUnavailableException
 
CacheUnreachableException - Exception Class in org.infinispan.remoting
Signals a backup site was unreachable.
CacheUnreachableException(String) - Constructor for exception class org.infinispan.remoting.CacheUnreachableException
 
CacheUnreachableException(UnreachableException) - Constructor for exception class org.infinispan.remoting.CacheUnreachableException
 
CacheUpdateConfigurationAttributeTask - Class in org.infinispan.server.core.admin.embeddedserver
Administrative operation to update a specific configuration attribute for a given cache with the following parameters: Parameters: name specifies the cache for which its configuration attribute will be updated. attribute the path of the attribute we want to change, e.g.
CacheUpdateConfigurationAttributeTask() - Constructor for class org.infinispan.server.core.admin.embeddedserver.CacheUpdateConfigurationAttributeTask
 
CacheUpdateIndexSchemaTask - Class in org.infinispan.server.core.admin.embeddedserver
Administrative operation to update the index schema for a cache with the following parameters: Parameters: name specifies the cache for which its index schema will be updated. flags unused
CacheUpdateIndexSchemaTask() - Constructor for class org.infinispan.server.core.admin.embeddedserver.CacheUpdateIndexSchemaTask
 
CacheUsageInterceptor - Class in org.infinispan.extendedstats.topK
Intercepts the VisitableCommands to calculate the corresponding top-key values.
CacheUsageInterceptor() - Constructor for class org.infinispan.extendedstats.topK.CacheUsageInterceptor
 
CacheWriter<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
CacheXid - Class in org.infinispan.server.hotrod.tx.table
A key used in the global transaction table.
CacheXid(ByteString, XidImpl) - Constructor for class org.infinispan.server.hotrod.tx.table.CacheXid
 
calculateBloomBits() - Method in class org.infinispan.client.hotrod.near.NearCacheService
 
calculateConflictHash(ConsistentHash, Set<ConsistentHash>, List<Address>) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
 
calculateConflictHash(ConsistentHash, Set<ConsistentHash>, List<Address>) - Method in class org.infinispan.topology.ClusterCacheStatus
 
calculateSize(Object, Object) - Method in class org.infinispan.container.entries.PrimitiveEntrySizeCalculator
 
calculateSize(K, InternalCacheEntry<K, V>) - Method in class org.infinispan.container.entries.CacheEntrySizeCalculator
 
calculateSize(K, V) - Method in interface org.infinispan.commons.util.EntrySizeCalculator
Method used to calculate how much memory in size the key and value use.
calculateSize(K, V) - Method in class org.infinispan.marshall.core.WrappedByteArraySizeCalculator
 
calculateSize(K, V, Metadata) - Method in interface org.infinispan.container.impl.KeyValueMetadataSizeCalculator
Method used to calculate how much memory in size the key, value and metadata use.
calculateSize(K, V, Metadata, PrivateMetadata) - Method in class org.infinispan.container.entries.CacheEntrySizeCalculator
 
calculateSize(K, V, Metadata, PrivateMetadata) - Method in interface org.infinispan.container.impl.KeyValueMetadataSizeCalculator
Method used to calculate how much memory in size the key, value and metadata use.
calculateSize(WrappedBytes, WrappedBytes, Metadata) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
Method used to calculate how much memory in size the key, value and metadata use.
calculateSize(WrappedBytes, WrappedBytes, Metadata, PrivateMetadata) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
Method used to calculate how much memory in size the key, value, metadata and internal metadata use.
calculateSize(WrappedBytes, WrappedBytes, Metadata, PrivateMetadata) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
 
calculateState(long, long, long) - Static method in class org.infinispan.counter.impl.Utils
Calculates the CounterState to use based on the value and the boundaries.
CALIBRATE_BY_DELETES - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
CALIBRATE_BY_DELETES - Static variable in class org.infinispan.configuration.cache.IndexMergeConfiguration
 
calibrateByDeletes() - Method in class org.infinispan.configuration.cache.IndexMergeConfiguration
 
calibrateByDeletes(boolean) - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
 
call() - Method in class org.infinispan.remoting.LocalInvocation
 
call() - Method in class org.infinispan.remoting.transport.AbstractRequest
 
callAsync() - Method in class org.infinispan.remoting.LocalInvocation
 
callbackHandler - Variable in class org.infinispan.server.core.security.SubjectSaslServer
 
callbackHandler() - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfiguration
 
callbackHandler() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
 
callbackHandler(CallbackHandler) - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
Specifies a CallbackHandler to be used during the authentication handshake.
callbackHandler(CallbackHandler) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
Specifies a CallbackHandler to be used during the authentication handshake.
callbackHandlerAndUsernameMutuallyExclusive() - Method in interface org.infinispan.client.hotrod.logging.Log
 
CallerId - Class in org.infinispan.commons.jdkspecific
 
CallerId() - Constructor for class org.infinispan.commons.jdkspecific.CallerId
 
CallerRunsRejectOnShutdownPolicy - Class in org.infinispan.commons.util.concurrent
A handler for rejected tasks that runs the rejected task directly in the calling thread of the execute method.
CallerRunsRejectOnShutdownPolicy() - Constructor for class org.infinispan.commons.util.concurrent.CallerRunsRejectOnShutdownPolicy
 
CAMEL_CASE - Enum constant in enum org.infinispan.commons.configuration.io.NamingStrategy
 
canApply(Set<Class<? extends Annotation>>, Class<? extends Annotation>) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
 
canBlock() - Method in interface org.infinispan.commands.ReplicableCommand
Deprecated, for removal: This API element is subject to removal in a future version.
since 11.0 - All commands will be required to be non blocking!
canBlock() - Method in class org.infinispan.manager.impl.ReplicableManagerFunctionCommand
 
canBlock() - Method in class org.infinispan.manager.impl.ReplicableRunnableCommand
 
canBlock() - Method in class org.infinispan.server.hotrod.command.tx.ForwardCommitCommand
 
canBlock() - Method in class org.infinispan.server.hotrod.command.tx.ForwardRollbackCommand
 
canBlock() - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
 
cancel(boolean) - Method in class org.infinispan.remoting.transport.AbstractRequest
 
cancel(Exception) - Method in class org.infinispan.remoting.transport.AbstractRequest
 
cancel(Exception) - Method in interface org.infinispan.remoting.transport.impl.Request
Complete the request with an exception and release its resources.
cancel(LockState) - Method in interface org.infinispan.util.concurrent.locks.ExtendedLockPromise
It cancels the LockPromise if possible.
CANCELED - Enum constant in enum org.infinispan.remoting.inboundhandler.action.ActionStatus
The action is completed unsuccessfully.
cancelPushState(String) - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateTransferManager
 
cancelPushState(String) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
It cancels a running state transfer.
cancelPushState(String) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
cancelQueuedTasks() - Method in class org.infinispan.executors.SemaphoreCompletionService
When stopping, cancel any queued tasks.
cancelReceive(String) - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateTransferManager
 
cancelReceive(String) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
Sets the cluster to normal state.
cancelReceive(String) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
cancelStateTransfer() - Method in class org.infinispan.xsite.statetransfer.RemoteSiteStatus
 
cancelStateTransfer(String) - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateProvider
 
cancelStateTransfer(String) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateProvider
It cancels the state transfer for the remote site.
cancelStateTransfer(String) - Method in class org.infinispan.xsite.statetransfer.XSiteStateProviderImpl
 
cancelTransfer() - Method in class org.infinispan.xsite.statetransfer.BaseXSiteStateProviderState
 
cancelTransfer() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateProviderState
Cancels any running state transfer.
canDoAutomaticStateTransfer() - Method in class org.infinispan.xsite.response.AutoStateTransferResponse
 
canExecute() - Method in class org.infinispan.io.GridFile
Deprecated.
 
canExpire() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
canExpire() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
canExpire() - Method in interface org.infinispan.container.entries.InternalCacheEntry
 
canExpire() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
canExpire() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
canExpire() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
 
canExpire() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
canExpire() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
 
canExpire() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
canExpire() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
canExpire() - Method in class org.infinispan.container.entries.MortalCacheValue
 
canExpire() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
canExpire() - Method in class org.infinispan.container.entries.TransientCacheValue
 
canExpire() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
canExpireMaxIdle() - Method in interface org.infinispan.container.entries.InternalCacheEntry
 
canExpireMaxIdle() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
canExpireMaxIdle() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
canExpireMaxIdle() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
canExpireMaxIdle() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
CANNOT_ASSUME_DENOM_IS_POWER_OF_TWO - Static variable in class org.infinispan.io.ModularArithmetic
Deprecated.
 
cannotClearData(IOException) - Method in interface org.infinispan.persistence.sifs.Log
 
cannotClearIndex(IOException) - Method in interface org.infinispan.persistence.sifs.Log
 
cannotCloseDeleteFile(int, IOException) - Method in interface org.infinispan.persistence.sifs.Log
 
cannotCloseFile(IOException) - Method in interface org.infinispan.persistence.sifs.Log
 
cannotCreateAsyncThread(int) - Method in interface org.infinispan.client.hotrod.logging.Log
 
cannotCreateClusteredCache() - Method in interface org.infinispan.server.core.logging.Log
 
cannotEnableHotRodWrapping() - Method in interface org.infinispan.persistence.remote.logging.Log
 
cannotInvokeScriptDirectly(String, String) - Method in interface org.infinispan.scripting.logging.Log
 
cannotLoadIndexedClass(String, Throwable) - Method in interface org.infinispan.query.logging.Log
 
cannotLoadKeyFromIndex(Object, Exception) - Method in interface org.infinispan.persistence.sifs.Log
 
cannotOpenIndex(String, IOException) - Method in interface org.infinispan.persistence.sifs.Log
 
cannotRegisterAdminOperationsHandler() - Method in interface org.infinispan.server.core.logging.Log
 
cannotRenamePersistentFile(String, File, Throwable) - Method in interface org.infinispan.counter.logging.Log
 
cannotRunLuceneQueriesIfNotIndexed(String) - Method in interface org.infinispan.query.logging.Log
 
cannotTruncateIndex(IOException) - Method in interface org.infinispan.persistence.sifs.Log
 
canRead() - Method in class org.infinispan.io.GridFile
Deprecated.
 
canRollbackTransactionAfterOriginatorLeave(GlobalTransaction) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
canRollbackTransactionAfterOriginatorLeave(GlobalTransaction) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
It checks if the transaction can be aborted when the originator leaves the cluster.
canRollbackTransactionAfterOriginatorLeave(GlobalTransaction) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
canStoreReferences() - Method in enum org.infinispan.configuration.cache.StorageType
 
canWrite() - Method in class org.infinispan.io.GridFile
Deprecated.
 
capacity() - Method in class org.infinispan.commons.util.SmallIntSet
Deprecated.
 
capacity() - Method in interface org.infinispan.container.DataContainer
Returns the capacity of the underlying container.
capacity() - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
capacity() - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
capacity() - Method in class org.infinispan.container.impl.DefaultDataContainer
 
capacity() - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
CAPACITY - Enum constant in enum org.infinispan.configuration.parsing.Attribute
Deprecated, for removal: This API element is subject to removal in a future version.
CAPACITY_FACTOR - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
CAPACITY_FACTOR - Static variable in class org.infinispan.configuration.cache.HashConfiguration
 
capacityFactor() - Method in class org.infinispan.configuration.cache.HashConfiguration
Controls the proportion of entries that will reside on the local node, compared to the other nodes in the cluster.
capacityFactor(float) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
Controls the proportion of entries that will reside on the local node, compared to the other nodes in the cluster.
capacityFactors - Variable in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
capacityFactors - Variable in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
capacityFactors - Variable in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
Casting - Class in org.infinispan.util
 
Casting() - Constructor for class org.infinispan.util.Casting
 
CAUSE - Static variable in interface org.infinispan.query.remote.json.JSONConstants
 
CDSECT - Static variable in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
A CDATA sections was just read; this token is available only from calls to nextToken().
CERTIFICATE_PASSWORD - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
 
challenge(RestRequest, ChannelHandlerContext) - Method in interface org.infinispan.rest.authentication.Authenticator
Challenges specific RestRequest for authentication.
challenge(RestRequest, ChannelHandlerContext) - Method in class org.infinispan.rest.authentication.impl.BasicAuthenticator
 
challenge(RestRequest, ChannelHandlerContext) - Method in class org.infinispan.rest.authentication.impl.ClientCertAuthenticator
 
CHANGED - Enum constant in enum org.infinispan.container.entries.ReadCommittedEntry.Flags
 
changeListener - Variable in class org.infinispan.reactive.publisher.impl.LocalPublisherManagerImpl
 
changeSessionId() - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository.InfinispanSession
 
channel - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
channel - Variable in class org.infinispan.server.hotrod.BaseRequestProcessor
 
CHANNEL_CONFIGURATOR - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
CHANNEL_LOOKUP - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
channelActive(Channel) - Method in class org.infinispan.server.hotrod.counter.listener.ClientCounterManagerNotificationManager
 
channelActive(ChannelHandlerContext) - Method in class org.infinispan.server.core.transport.AccessControlFilter
 
channelActive(ChannelHandlerContext) - Method in class org.infinispan.server.core.transport.StatsChannelHandler
 
channelActive(ChannelHandlerContext) - Method in class org.infinispan.server.hotrod.HotRodDecoder
 
channelClosed(JChannel) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
channelConfigurator(EmbeddedJGroupsChannelConfigurator) - Method in class org.infinispan.configuration.global.StackConfigurationBuilder
 
channelConnected(JChannel) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
channelDisconnected(JChannel) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
channelFactory - Variable in class org.infinispan.client.hotrod.RemoteCacheManager
 
channelFactory() - Method in class org.infinispan.client.hotrod.event.impl.ClientListenerNotifier
 
channelInactive(SocketAddress, SocketAddress) - Method in interface org.infinispan.client.hotrod.logging.Log
 
channelListeners - Variable in class org.infinispan.remoting.transport.jgroups.AbstractJGroupsChannelConfigurator
 
channelRead(ChannelHandlerContext, Object) - Method in class org.infinispan.rest.CorsHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.infinispan.server.core.transport.StatsChannelHandler
 
channelRead0(ChannelHandlerContext, FullHttpRequest) - Method in class org.infinispan.rest.RestRequestHandler
 
channelRegistered(ChannelHandlerContext) - Method in class org.infinispan.server.core.transport.AccessControlFilter
 
channelStillBound(Channel, SocketAddress) - Method in interface org.infinispan.server.core.logging.Log
 
channelStillConnected(Channel, SocketAddress) - Method in interface org.infinispan.server.core.logging.Log
 
channelWritabilityChanged(ChannelHandlerContext) - Method in class org.infinispan.server.hotrod.HotRodDecoder
 
characteristics() - Method in class org.infinispan.commons.dataconversion.internal.JsonArrayCollector
 
characteristics() - Method in class org.infinispan.commons.util.ArrayCollector
 
characteristics() - Method in class org.infinispan.commons.util.FilterSpliterator
 
characteristics() - Method in class org.infinispan.commons.util.FlattenSpliterator
 
characteristics() - Method in class org.infinispan.commons.util.SpliteratorMapper
 
characteristics() - Method in class org.infinispan.persistence.async.AsyncNonBlockingStore
 
characteristics() - Method in class org.infinispan.persistence.file.SingleFileStore
 
characteristics() - Method in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
 
characteristics() - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
characteristics() - Method in class org.infinispan.persistence.remote.RemoteStore
 
characteristics() - Method in class org.infinispan.persistence.rocksdb.RocksDBStore
 
characteristics() - Method in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
 
characteristics() - Method in interface org.infinispan.persistence.spi.NonBlockingStore
Returns a set of characteristics for this store and its elements.
characteristics() - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
 
characteristics() - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
 
charRefOneCharBuf - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
Charset - Class in org.infinispan.rest.operations.mediatypes
Represents Charset.
CHARSET - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
 
check(ActionState) - Method in interface org.infinispan.remoting.inboundhandler.action.Action
It checks this action.
check(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.TriangleOrderAction
 
CHECK_REMOTE_STORE - Static variable in interface org.infinispan.persistence.remote.ExternalizerIds
 
checkAndTrackExpiration(Object) - Method in class org.infinispan.xsite.irac.DefaultIracManager
 
checkAndTrackExpiration(Object) - Method in interface org.infinispan.xsite.irac.IracManager
Checks if the given key is expired on all other sites.
checkAndTrackExpiration(Object) - Method in enum org.infinispan.xsite.irac.NoOpIracManager
 
checkBulkRead() - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
checkBulkRead() - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
 
checkBulkRead() - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
checkCancelled() - Method in class org.infinispan.commons.reactive.AbstractAsyncPublisherHandler
This method returns whether this subscription has been cancelled
checkCapacityFactors(List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHashFactory
 
checkClear() - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
checkClear() - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
 
checkClear() - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
checkCrossSiteAvailable() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
checkCrossSiteAvailable() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
checkCrossSiteAvailable() - Method in interface org.infinispan.remoting.transport.Transport
Checks if this Transport is able to perform cross-site requests.
CheckedClassResolver - Class in org.infinispan.jboss.marshalling.commons
 
CheckedClassResolver(ClassAllowList, ClassLoader) - Constructor for class org.infinispan.jboss.marshalling.commons.CheckedClassResolver
 
CheckedInputStream - Class in org.infinispan.commons.marshall
 
CheckedInputStream(InputStream, ClassAllowList) - Constructor for class org.infinispan.commons.marshall.CheckedInputStream
 
checkExpiration(InternalCacheEntry<K, V>, long) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
checkExpiredMaxIdle(InternalCacheEntry<?, ?>, int, long) - Method in class org.infinispan.expiration.impl.ClusterExpirationManager
 
checkExpiredMaxIdle(InternalCacheEntry<?, ?>, int, long) - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
Response is whether the value should be treated as expired.
checkForReadyTasks() - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
checkForReadyTasks() - Method in interface org.infinispan.util.concurrent.BlockingTaskAwareExecutorService
It checks for tasks ready to be processed in this ExecutorService.
checkForReadyTasks() - Method in class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
 
checkIfRolledBack() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
checkOpen() - Method in class org.infinispan.search.mapper.search.loading.context.impl.InfinispanLoadingContext
 
checkParentDirs(String, boolean) - Method in class org.infinispan.io.GridFile
Deprecated.
Checks whether the parent directories are present (and are directories).
checkPendingTransactionsForKey(TxInvocationContext<?>, Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultPendingLockManager
 
checkPendingTransactionsForKey(TxInvocationContext<?>, Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.NoOpPendingLockManager
 
checkPendingTransactionsForKey(TxInvocationContext<?>, Object, long, TimeUnit) - Method in interface org.infinispan.util.concurrent.locks.PendingLockManager
checkPendingTransactionsForKeys(TxInvocationContext<?>, Collection<Object>, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultPendingLockManager
 
checkPendingTransactionsForKeys(TxInvocationContext<?>, Collection<Object>, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.NoOpPendingLockManager
 
checkPendingTransactionsForKeys(TxInvocationContext<?>, Collection<Object>, long, TimeUnit) - Method in interface org.infinispan.util.concurrent.locks.PendingLockManager
checkPermission(Subject, AuthorizationPermission) - Method in interface org.infinispan.security.AuthorizationManager
Verifies that the Subject has the requested permission.
checkPermission(Subject, AuthorizationPermission) - Method in class org.infinispan.security.impl.AuthorizationManagerImpl
 
checkPermission(Subject, AuthorizationPermission) - Method in class org.infinispan.security.impl.Authorizer
 
checkPermission(Subject, AuthorizationPermission) - Method in class org.infinispan.security.impl.PermissiveAuthorizationManager
 
checkPermission(Subject, AuthorizationPermission, String) - Method in interface org.infinispan.security.AuthorizationManager
Verifies that the Subject has the requested permission and role.
checkPermission(Subject, AuthorizationPermission, String) - Method in class org.infinispan.security.impl.AuthorizationManagerImpl
 
checkPermission(Subject, AuthorizationPermission, String) - Method in class org.infinispan.security.impl.PermissiveAuthorizationManager
 
checkPermission(Subject, AuthorizationPermission, String, AuditContext) - Method in class org.infinispan.security.impl.Authorizer
 
checkPermission(Subject, AuthorizationPermission, AuditContext) - Method in class org.infinispan.security.impl.Authorizer
 
checkPermission(AuthorizationConfiguration, Subject, String, AuditContext, String, AuthorizationPermission) - Method in class org.infinispan.security.impl.Authorizer
 
checkPermission(AuthorizationConfiguration, Subject, AuthorizationPermission, String) - Method in class org.infinispan.security.impl.Authorizer
 
checkPermission(AuthorizationConfiguration, AuthorizationPermission) - Method in class org.infinispan.security.impl.Authorizer
 
checkPermission(AuthorizationPermission) - Method in interface org.infinispan.security.AuthorizationManager
Verifies that the Subject associated with the current AccessControlContext has the requested permission.
checkPermission(AuthorizationPermission) - Method in class org.infinispan.security.impl.AuthorizationManagerImpl
 
checkPermission(AuthorizationPermission) - Method in class org.infinispan.security.impl.Authorizer
 
checkPermission(AuthorizationPermission) - Method in class org.infinispan.security.impl.PermissiveAuthorizationManager
 
checkPermission(AuthorizationPermission, String) - Method in interface org.infinispan.security.AuthorizationManager
Verifies that the Subject associated with the current AccessControlContext has the requested permission and role.
checkPermission(AuthorizationPermission, String) - Method in class org.infinispan.security.impl.AuthorizationManagerImpl
 
checkPermission(AuthorizationPermission, String) - Method in class org.infinispan.security.impl.Authorizer
 
checkPermission(AuthorizationPermission, String) - Method in class org.infinispan.security.impl.PermissiveAuthorizationManager
 
checkPermission(CachePermission) - Static method in class org.infinispan.security.Security
 
checkProtection() - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
 
checkRead(Object, long) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
checkRead(Object, long) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
 
checkRead(Object, long) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
CheckRemoteStoreTask - Class in org.infinispan.persistence.remote.upgrade
Task to check for the remote store in a cache.
CheckRemoteStoreTask(String) - Constructor for class org.infinispan.persistence.remote.upgrade.CheckRemoteStoreTask
 
CheckRemoteStoreTask.Externalizer - Class in org.infinispan.persistence.remote.upgrade
 
checkResponse(Object, Address, boolean) - Method in class org.infinispan.remoting.transport.AbstractTransport
Deprecated.
 
checkSameHashAndSegments(AbstractConsistentHash) - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
checkStaleTombstone(Collection<? extends IracTombstoneInfo>) - Method in class org.infinispan.container.versioning.irac.DefaultIracTombstoneManager
 
checkStaleTombstone(Collection<? extends IracTombstoneInfo>) - Method in interface org.infinispan.container.versioning.irac.IracTombstoneManager
It receives a Collection of IracTombstoneInfo and sends IracTombstoneCleanupCommand for the tombstone no longer valid.
checkStaleTombstone(Collection<? extends IracTombstoneInfo>) - Method in class org.infinispan.container.versioning.irac.NoOpIracTombstoneManager
 
checkTopology(TopologyAffectedCommand, LocalizedCacheTopology) - Static method in enum org.infinispan.util.CacheTopologyUtil
Check if the current LocalizedCacheTopology is valid for the TopologyAffectedCommand.
checkTotalOrderSupported() - Method in interface org.infinispan.remoting.transport.Transport
Deprecated, for removal: This API element is subject to removal in a future version.
Total order support dropped
checkTransactionSupport(String, OperationsFactory) - Static method in class org.infinispan.client.hotrod.impl.Util
 
checkTransactionSupport(String, OperationsFactory, Log) - Static method in class org.infinispan.client.hotrod.impl.Util
 
checkWrite(Object) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
checkWrite(Object) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
 
checkWrite(Object) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
child(Attribute<?>) - Static method in class org.infinispan.commons.configuration.attributes.ConfigurationElement
 
CHILDLESS - Static variable in class org.infinispan.commons.configuration.attributes.ConfigurationElement
 
children - Variable in class org.infinispan.commons.configuration.attributes.ConfigurationElement
 
children() - Method in class org.infinispan.commons.configuration.attributes.ConfigurationElement
 
children(Collection<T>) - Static method in class org.infinispan.commons.configuration.attributes.ConfigurationElement
 
choose(ProtocolVersion) - Method in enum org.infinispan.client.hotrod.ProtocolVersion
 
CHUNK_CACHE_KEY - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
CHUNK_SIZE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
CHUNK_SIZE - Static variable in class org.infinispan.configuration.cache.StateTransferConfiguration
 
CHUNK_SIZE - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
chunkCounter - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
CHUNKED_FILE - Enum constant in enum org.infinispan.rest.ResponseWriter
 
CHUNKED_STREAM - Enum constant in enum org.infinispan.rest.ResponseWriter
 
chunkSize() - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
The state will be transferred in batches of chunkSize cache entries.
chunkSize() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
chunkSize(int) - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
The state will be transferred in batches of chunkSize cache entries.
chunkSize(int) - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
If > 0, the state will be transferred in batches of chunkSize cache entries.
cidr() - Method in class org.infinispan.server.core.transport.IpSubnetFilterRule
 
ciphers() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
 
ciphers(String...) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
Configures the ciphers Setting this property also implicitly enables SSL/TLS (see SslConfigurationBuilder.enable()
CLASS - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
CLASS - Enum constant in enum org.infinispan.configuration.parsing.Element
 
CLASS - Static variable in interface org.infinispan.commons.marshall.Ids
 
CLASS - Static variable in class org.infinispan.configuration.global.PrincipalRoleMapperConfiguration
 
CLASS - Static variable in class org.infinispan.configuration.global.RolePermissionMapperConfiguration
 
CLASS_LOADER - Static variable in class org.infinispan.factories.KnownComponentNames
 
CLASS_NAME - Static variable in interface org.infinispan.commons.configuration.attributes.AttributeSerializer
 
ClassAllowList - Class in org.infinispan.commons.configuration
The ClassAllowList maintains classes definitions either by name or regular expression and is used for permissioning.
ClassAllowList() - Constructor for class org.infinispan.commons.configuration.ClassAllowList
 
ClassAllowList(Collection<String>, List<String>, ClassLoader) - Constructor for class org.infinispan.commons.configuration.ClassAllowList
 
ClassAllowList(List<String>) - Constructor for class org.infinispan.commons.configuration.ClassAllowList
 
classBuilder(String, Class<T>) - Static method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
 
classes() - Element in annotation type org.infinispan.factories.annotations.DefaultFactoryFor
Components that may be constructed by a factory annotated with this annotation.
ClassExternalizer - Class in org.infinispan.marshall.exts
 
ClassExternalizer(ClassLoader) - Constructor for class org.infinispan.marshall.exts.ClassExternalizer
 
ClassFinder - Class in org.infinispan.commons.util
Find infinispan classes utility
ClassFinder() - Constructor for class org.infinispan.commons.util.ClassFinder
 
classForName(String) - Method in class org.infinispan.search.mapper.mapping.impl.ClassLoaderServiceImpl
 
classLoader - Variable in class org.infinispan.factories.GlobalComponentRegistry
 
classLoader - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
classLoader() - Method in class org.infinispan.client.hotrod.configuration.Configuration
Deprecated, for removal: This API element is subject to removal in a future version.
classLoader() - Method in class org.infinispan.configuration.global.GlobalConfiguration
Get the classloader in use by this configuration.
classLoader(ClassLoader) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
classLoader(ClassLoader) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
classLoader(ClassLoader) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
since 9.0. To be removed in 12.0. If you need to load configuration resources from other locations, you will need to do so yourself and use the appropriate configuration methods (e.g. SslConfigurationBuilder.sslContext(javax.net.ssl.SSLContext))
classLoader(ClassLoader) - Method in class org.infinispan.commons.util.SslContextFactory
 
classLoader(ClassLoader) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
ClassLoaderAwareFilteringListenable<K,V> - Interface in org.infinispan.notifications
Interface that enhances FilteringListenable with the possibility of specifying the ClassLoader which should be set as the context class loader for the invoked listener method
ClassLoaderAwareListenable - Interface in org.infinispan.notifications
Interface that enhances Listenable with the possibility of specifying the ClassLoader which should be set as the context class loader for the invoked listener method
ClassLoaderServiceImpl - Class in org.infinispan.search.mapper.mapping.impl
An implementation of the ClassResolver, ResourceResolver and ServiceResolver contracts that just delegates loading to an actual ClassLoader.
ClassLoaderServiceImpl(ClassLoader) - Constructor for class org.infinispan.search.mapper.mapping.impl.ClassLoaderServiceImpl
 
classNotIndexable(String) - Method in interface org.infinispan.query.logging.Log
 
ClasspathURLStreamHandler - Class in org.infinispan.commons.util
A URLStreamHandlerFactory which can handle classpath: URI schemes.
ClasspathURLStreamHandler() - Constructor for class org.infinispan.commons.util.ClasspathURLStreamHandler
 
ClasspathURLStreamHandlerProvider - Class in org.infinispan.commons.jdkspecific
A URLStreamHandlerProvider which handles URLs with protocol "classpath".
ClasspathURLStreamHandlerProvider() - Constructor for class org.infinispan.commons.jdkspecific.ClasspathURLStreamHandlerProvider
 
ClassWhiteList - Class in org.infinispan.commons.configuration
Deprecated, for removal: This API element is subject to removal in a future version.
since 12.0. Will be removed in 14.0. Use ClassAllowList.
ClassWhiteList() - Constructor for class org.infinispan.commons.configuration.ClassWhiteList
Deprecated.
 
ClassWhiteList(Collection<String>, List<String>, ClassLoader) - Constructor for class org.infinispan.commons.configuration.ClassWhiteList
Deprecated.
 
ClassWhiteList(List<String>) - Constructor for class org.infinispan.commons.configuration.ClassWhiteList
Deprecated.
 
Clean rebalance (after join, no data is lost) - Search tag in package org.infinispan.scattered
Section
cleanup() - Method in class org.infinispan.client.hotrod.counter.operation.AddListenerOperation
 
cleanup() - Static method in class org.infinispan.transaction.lookup.EmbeddedTransactionManagerLookup
 
cleanUp() - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
cleanUp() - Method in class org.infinispan.container.impl.DefaultDataContainer
 
cleanUp() - Method in interface org.infinispan.container.impl.InternalDataContainer
Method used to cleanup any pending data, such as evictions
CLEANUP_TASK_FREQUENCY - Static variable in class org.infinispan.configuration.cache.L1Configuration
 
cleanupBackupLocks() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
cleanupBackupLocks() - Method in interface org.infinispan.transaction.xa.CacheTransaction
It cleans up the backup locks for this transaction.
cleanupLeaverTransactions(List<Address>) - Method in class org.infinispan.transaction.impl.TransactionTable
 
cleanupLeaverTransactions(List<Address>) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
First moves the prepared transactions originated on the leavers into the recovery cache and then cleans up the transactions that are not yet prepared.
cleanupTaskFrequency() - Method in class org.infinispan.configuration.cache.L1Configuration
Determines how often a cleanup thread runs to clean up an internal log of requestors for a specific key
cleanupTaskFrequency(long) - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
How often the L1 requestors map is cleaned up of stale items
cleanupTaskFrequency(long, TimeUnit) - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
How often the L1 requestors map is cleaned up of stale items
clear() - Method in interface org.infinispan.Cache
Removes all mappings from the cache.
clear() - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
 
clear() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
clear() - Method in class org.infinispan.cache.impl.CacheImpl
 
clear() - Method in class org.infinispan.cache.impl.DecoratedCache
 
clear() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
clear() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySetBase
 
clear() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.KeySet
 
clear() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.Values
 
clear() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
clear() - Method in interface org.infinispan.client.hotrod.near.NearCache
 
clear() - Method in class org.infinispan.client.hotrod.near.NearCacheService
 
clear() - Method in class org.infinispan.commons.marshall.MarshallableTypeHints
Clear the cached marshallable type hints.
clear() - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
 
clear() - Method in class org.infinispan.commons.util.AbstractDelegatingMap
 
clear() - Method in class org.infinispan.commons.util.ImmutableIntSet
 
clear() - Method in class org.infinispan.commons.util.ArrayMap
 
clear() - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
 
clear() - Method in class org.infinispan.commons.util.FastCopyHashMap
 
clear() - Method in class org.infinispan.commons.util.FastCopyHashMap.EntrySet
 
clear() - Method in class org.infinispan.commons.util.FastCopyHashMap.KeySet
 
clear() - Method in class org.infinispan.commons.util.FastCopyHashMap.Values
 
clear() - Method in class org.infinispan.commons.util.ForwardingList
 
clear() - Method in class org.infinispan.commons.util.ImmutableHopscotchHashSet
 
clear() - Method in class org.infinispan.commons.util.RangeSet
Deprecated.
 
clear() - Method in class org.infinispan.commons.util.SmallIntSet
Deprecated.
 
clear() - Method in class org.infinispan.commons.util.WeakValueHashMap
 
clear() - Method in class org.infinispan.configuration.global.JGroupsConfigurationBuilder
 
clear() - Method in interface org.infinispan.container.DataContainer
Removes all entries in the container
clear() - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
clear() - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
clear() - Method in class org.infinispan.container.impl.DefaultDataContainer
 
clear() - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
clear() - Method in class org.infinispan.container.impl.L1SegmentedDataContainer
 
clear() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
clear() - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
clear() - Method in class org.infinispan.InternalCacheSet
 
clear() - Method in class org.infinispan.persistence.async.AsyncNonBlockingStore
 
clear() - Method in class org.infinispan.persistence.file.SingleFileStore
 
clear() - Method in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
 
clear() - Method in class org.infinispan.persistence.remote.RemoteStore
 
clear() - Method in class org.infinispan.persistence.rocksdb.RocksDBStore
 
clear() - Method in class org.infinispan.persistence.sifs.FileProvider
 
clear() - Method in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
 
clear() - Method in class org.infinispan.persistence.sifs.TemporaryTable
 
clear() - Method in interface org.infinispan.persistence.spi.AdvancedCacheWriter
Deprecated.
Removes all the data from the storage.
clear() - Method in interface org.infinispan.persistence.spi.NonBlockingStore
Clears all entries from the store.
clear() - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
clear() - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
 
clear() - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
 
clear() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
clear() - Method in interface org.infinispan.scattered.BiasManager
The cache has been cleared and therefore all biases are forgotten.
clear() - Method in class org.infinispan.scattered.impl.BiasManagerImpl
 
clear() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
clear() - Method in class org.infinispan.spring.common.provider.SpringCache
 
clear() - Method in class org.infinispan.util.CollectionMapper
 
clear() - Method in class org.infinispan.util.WriteableCacheCollectionMapper
 
clear(IntSet) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
clear(IntSet) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
clear(IntSet) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
clear(IntSet) - Method in class org.infinispan.container.impl.DefaultDataContainer
 
clear(IntSet) - Method in interface org.infinispan.container.impl.InternalDataContainer
Removes entries from the container whose key maps to one of the provided segments
clear(IntSet) - Method in class org.infinispan.container.impl.L1SegmentedDataContainer
Removes all entries that map to the given segments
clear(IntSet) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
Deprecated.
Removes all the data that maps to the given segments from the storage.
clear(IntSet) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
Clear - Class in org.infinispan.persistence.modifications
 
Clear() - Constructor for class org.infinispan.persistence.modifications.Clear
 
CLEAR - Enum constant in enum org.infinispan.persistence.modifications.Modification.Type
 
CLEAR - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
CLEAR_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
CLEAR_THRESHOLD - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.Attribute
 
clearAll() - Method in class org.infinispan.util.DependencyGraph
 
clearAllStores(Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
 
clearAndPause() - Method in class org.infinispan.persistence.sifs.LogAppender
Clears all the log entries returning a stage when the completion is done.
clearAsync() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
clearAsync() - Method in class org.infinispan.cache.impl.CacheImpl
 
clearAsync() - Method in class org.infinispan.cache.impl.DecoratedCache
 
clearAsync() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
clearAsync() - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
clearAsync() - Method in class org.infinispan.client.hotrod.impl.InvalidatedNearRemoteCache
 
clearAsync() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
clearAsync() - Method in interface org.infinispan.commons.api.AsyncCache
Asynchronous version of Map.clear().
clearAsync() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
ClearCacheEntry<K,V> - Class in org.infinispan.container.entries
Used in ClearInvocationContext to process the ClearCommand.
clearClusterStatus() - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateTransferManager
 
clearClusterStatus() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
Clears the completed state transfer status in all the cluster.
clearClusterStatus() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
clearConnectorIpFilterRules(String) - Method in interface org.infinispan.server.core.ServerStateManager
 
clearCounters() - Method in class org.infinispan.counter.configuration.CounterManagerConfigurationBuilder
Clears all the configured counters.
clearError(Throwable) - Method in interface org.infinispan.persistence.sifs.Log
 
clearGroupers() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
Clear the groupers
clearInvalidations() - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
clearInvalidations() - Method in interface org.infinispan.scattered.ScatteredVersionManager
Forget all non-processed invalidations scheduled through ScatteredVersionManager.scheduleKeyInvalidation(Object, EntryVersion, boolean)
ClearInvocationContext - Class in org.infinispan.context.impl
Implementation of InvocationContext used by the ClearCommand.
ClearInvocationContext(Address) - Constructor for class org.infinispan.context.impl.ClearInvocationContext
 
clearLockedKeys() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
clearLockedKeys() - Method in class org.infinispan.context.impl.ClearInvocationContext
 
clearLockedKeys() - Method in class org.infinispan.context.impl.ImmutableContext
 
clearLockedKeys() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
clearLockedKeys() - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
 
clearLockedKeys() - Method in interface org.infinispan.context.InvocationContext
 
clearLockedKeys() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
clearLockedKeys() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
clearLookedUpEntries() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
clearLookedUpEntries() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
clearModules() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
clearModules() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
clearNearCache() - Method in class org.infinispan.client.hotrod.impl.InvalidatedNearRemoteCache
 
clearOperation() - Method in class org.infinispan.cache.impl.CacheImpl
 
clearProperties() - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
Deprecated.
Clears the interceptor properties
clearProperties() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
Clears the transport properties
clearRemoteLocksAcquired() - Method in class org.infinispan.transaction.impl.LocalTransaction
 
clearStatus() - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateTransferManager
 
clearStatus() - Method in class org.infinispan.xsite.statetransfer.RemoteSiteStatus
 
clearStatus() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
Clears the completed state transfer status.
clearStatus() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
clearStores() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
Removes any configured stores from this builder.
clearTextSecrets - Variable in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
 
clearTextSecrets() - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
 
clearTextSecrets() - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
 
clearTextSecrets(boolean) - Method in class org.infinispan.commons.configuration.io.ConfigurationWriter.Builder
 
clearThreshold() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
Since 12.0, no longer used. Will be removed in 15.0
clearThreshold(int) - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 12.0, no longer used. Will be removed in 15.0
client() - Method in class org.infinispan.client.hotrod.DataFormat
 
CLIENT_ADDRESS - Static variable in class org.infinispan.server.core.ExternalizerIds
 
CLIENT_CACHE_ENTRY_CREATED - Enum constant in enum org.infinispan.client.hotrod.event.ClientEvent.Type
 
CLIENT_CACHE_ENTRY_EXPIRED - Enum constant in enum org.infinispan.client.hotrod.event.ClientEvent.Type
 
CLIENT_CACHE_ENTRY_MODIFIED - Enum constant in enum org.infinispan.client.hotrod.event.ClientEvent.Type
 
CLIENT_CACHE_ENTRY_REMOVED - Enum constant in enum org.infinispan.client.hotrod.event.ClientEvent.Type
 
CLIENT_CACHE_FAILOVER - Enum constant in enum org.infinispan.client.hotrod.event.ClientEvent.Type
 
CLIENT_ENCODING - Static variable in class org.infinispan.server.memcached.configuration.MemcachedServerConfiguration
 
CLIENT_ERROR_BAD_FORMAT - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
 
CLIENT_INTELLIGENCE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
ClientAddress - Class in org.infinispan.server.hotrod.tx.table
A Address implementation for a client transaction.
ClientAddress(Address) - Constructor for class org.infinispan.server.hotrod.tx.table.ClientAddress
 
ClientCacheEntryCreated - Annotation Type in org.infinispan.client.hotrod.annotation
 
ClientCacheEntryCreatedEvent<K> - Interface in org.infinispan.client.hotrod.event
Client side cache entry created events provide information on the created key, and the version of the entry.
ClientCacheEntryCustomEvent<T> - Interface in org.infinispan.client.hotrod.event
The events generated by default contain just enough information to make the event relevant but they avoid cramming too much information in order to reduce the cost of sending them.
ClientCacheEntryExpired - Annotation Type in org.infinispan.client.hotrod.annotation
 
ClientCacheEntryExpiredEvent<K> - Interface in org.infinispan.client.hotrod.event
Client side cache entry expired events provide information on the expired key.
ClientCacheEntryModified - Annotation Type in org.infinispan.client.hotrod.annotation
 
ClientCacheEntryModifiedEvent<K> - Interface in org.infinispan.client.hotrod.event
Client side cache entry modified events provide information on the modified key, and the version of the entry after the modification.
ClientCacheEntryRemoved - Annotation Type in org.infinispan.client.hotrod.annotation
 
ClientCacheEntryRemovedEvent<K> - Interface in org.infinispan.client.hotrod.event
Client side cache entry removed events provide information on the removed key.
ClientCacheFailover - Annotation Type in org.infinispan.client.hotrod.annotation
 
ClientCacheFailoverEvent - Interface in org.infinispan.client.hotrod.event
Event received when the registered listener fails over to a different node.
ClientCertAuthenticator - Class in org.infinispan.rest.authentication.impl
Client Certificate authentication mechanism.
ClientCertAuthenticator() - Constructor for class org.infinispan.rest.authentication.impl.ClientCertAuthenticator
 
ClientCounterEvent - Class in org.infinispan.server.hotrod.counter.listener
A counter event to send to a client.
ClientCounterManagerNotificationManager - Class in org.infinispan.server.hotrod.counter.listener
The CounterManager notification manager.
ClientCounterManagerNotificationManager(CounterManager) - Constructor for class org.infinispan.server.hotrod.counter.listener.ClientCounterManagerNotificationManager
 
clientEncoding() - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfiguration
 
clientEncoding(MediaType) - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
The encoding to be used by clients of the memcached text protocol.
ClientEvent - Interface in org.infinispan.client.hotrod.event
 
ClientEvent.Type - Enum in org.infinispan.client.hotrod.event
 
ClientEventDispatcher - Class in org.infinispan.client.hotrod.event.impl
 
ClientEvents - Class in org.infinispan.client.hotrod.event
 
clientIntelligence() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
clientIntelligence(ClientIntelligence) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
clientIntelligence(ClientIntelligence) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
clientIntelligence(ClientIntelligence) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Specifies the level of "intelligence" the client should have
ClientIntelligence - Enum in org.infinispan.client.hotrod.configuration
ClientIntelligence specifies the level of intelligence used by the client.
ClientListener - Annotation Type in org.infinispan.client.hotrod.annotation
Annotation that marks a class to receive remote events from Hot Rod caches.
clientListenerMustUseDesignatedFilterConverterFactory(String) - Method in interface org.infinispan.client.hotrod.logging.Log
 
clientListenerMustUseRawData(String) - Method in interface org.infinispan.client.hotrod.logging.Log
 
ClientListenerNotifier - Class in org.infinispan.client.hotrod.event.impl
 
ClientListenerNotifier(Marshaller, ChannelFactory, Configuration) - Constructor for class org.infinispan.client.hotrod.event.impl.ClientListenerNotifier
 
clientNotUpdatingTopology(SocketAddress, int) - Method in interface org.infinispan.server.hotrod.logging.Log
 
clientsReport() - Method in interface org.infinispan.server.core.ServerStateManager
 
clientStatistics - Variable in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
clientStatistics() - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
clientStatistics() - Method in interface org.infinispan.client.hotrod.impl.InternalRemoteCache
 
clientStatistics() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
clientStatistics() - Method in interface org.infinispan.client.hotrod.RemoteCache
Returns client-side statistics for this cache.
ClientStatistics - Class in org.infinispan.client.hotrod.impl
 
clientSubject() - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfiguration
 
clientSubject() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
 
clientSubject(Subject) - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
Sets the client subject, necessary for those SASL mechanisms which require it to access client credentials (i.e.
clientSubject(Subject) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
Sets the client subject, necessary for those SASL mechanisms which require it to access client credentials (i.e.
ClientTopology - Class in org.infinispan.client.hotrod.impl
Keeps the Hot Rod client topology information together: topology id and client intelligence.
ClientTopology(int, ClientIntelligence) - Constructor for class org.infinispan.client.hotrod.impl.ClientTopology
 
clone() - Method in class org.infinispan.commons.configuration.attributes.Attribute
 
clone() - Method in class org.infinispan.commons.util.FastCopyHashMap
 
clone() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
clone() - Method in interface org.infinispan.container.entries.CacheEntry
 
clone() - Method in class org.infinispan.container.entries.ClearCacheEntry
 
clone() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
clone() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
clone() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
clone() - Method in interface org.infinispan.container.entries.InternalCacheEntry
 
clone() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
clone() - Method in class org.infinispan.container.entries.MortalCacheValue
 
clone() - Method in interface org.infinispan.container.entries.MVCCEntry
 
clone() - Method in class org.infinispan.container.entries.NullCacheEntry
 
clone() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
clone() - Method in class org.infinispan.container.entries.RepeatableReadEntry
 
clone() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
clone() - Method in class org.infinispan.container.entries.TransientCacheValue
 
clone() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
clone() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
clone() - Method in class org.infinispan.container.entries.VersionedRepeatableReadEntry
 
clone() - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
clone() - Method in class org.infinispan.context.impl.ClearInvocationContext
 
clone() - Method in class org.infinispan.context.impl.ImmutableContext
 
clone() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
clone() - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
 
clone() - Method in interface org.infinispan.context.InvocationContext
Clones the invocation context.
clone() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
clone() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
cloneWithExpiration(MarshallableEntry<K, V>, long, long) - Method in interface org.infinispan.persistence.spi.MarshallableEntryFactory
Clone the provided MarshallableEntry if needed to apply lifespan expiration.
close() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
close() - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
 
close() - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
close() - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
 
close() - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationReader
 
close() - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationReader
 
close() - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader
 
close() - Method in class org.infinispan.commons.io.StringBuilderWriter
 
close() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
 
close() - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
 
close() - Method in interface org.infinispan.commons.util.CloseableIterable
 
close() - Method in interface org.infinispan.commons.util.CloseableIterator
 
close() - Method in interface org.infinispan.commons.util.CloseableSpliterator
 
close() - Method in class org.infinispan.commons.util.ConcatIterator
 
close() - Method in class org.infinispan.commons.util.FilterIterator
 
close() - Method in class org.infinispan.commons.util.FilterSpliterator
 
close() - Method in class org.infinispan.commons.util.IteratorMapper
 
close() - Method in class org.infinispan.commons.util.RemovableCloseableIterator
 
close() - Method in class org.infinispan.commons.util.SpliteratorMapper
 
close() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
close() - Method in class org.infinispan.functional.impl.ReadOnlyMapImpl
 
close() - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
 
close() - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
close() - Method in class org.infinispan.functional.impl.FunctionalMapImpl
 
close() - Method in class org.infinispan.io.GridInputStream
Deprecated.
 
close() - Method in class org.infinispan.io.GridOutputStream
Deprecated.
 
close() - Method in class org.infinispan.io.ReadableGridFileChannel
Deprecated.
 
close() - Method in class org.infinispan.io.UnclosableObjectInputStream
Deprecated.
 
close() - Method in class org.infinispan.io.UnclosableObjectOutputStream
Deprecated.
 
close() - Method in class org.infinispan.io.WritableGridFileChannel
Deprecated.
 
close() - Method in class org.infinispan.manager.DefaultCacheManager
 
close() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
close() - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
 
close() - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations.FlowableConnection
 
close() - Method in class org.infinispan.persistence.sifs.FileProvider.Handle
 
close() - Method in class org.infinispan.persistence.sifs.FileProvider.Log
 
close() - Method in class org.infinispan.query.impl.ScrollerIteratorAdaptor
 
close() - Method in interface org.infinispan.rest.authentication.Authenticator
 
close() - Method in class org.infinispan.rest.EventStream
 
close() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
 
close() - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
 
close() - Method in class org.infinispan.search.mapper.session.impl.InfinispanSearchSession
 
close() - Method in class org.infinispan.search.mapper.work.impl.SearchIndexerImpl
 
close() - Method in interface org.infinispan.search.mapper.work.SearchIndexer
 
close() - Method in class org.infinispan.server.core.dataconversion.xml.MXParserReader
 
close() - Method in class org.infinispan.stream.impl.AbstractCacheStream
 
close() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
close() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
close() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
close() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
close() - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
close() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
close() - Method in class org.infinispan.util.CloseableSuppliedIterator
 
close() - Method in class org.infinispan.util.concurrent.ReclosableLatch
 
close() - Method in interface org.infinispan.util.function.CloseableSupplier
 
close() - Method in class org.infinispan.util.LazyConcatIterator
 
close() - Method in class org.infinispan.xsite.events.XSiteEventSender
 
close(ChannelHandlerContext, ChannelPromise) - Method in class org.infinispan.server.core.transport.SaslQopHandler
 
close(InputStream) - Static method in class org.infinispan.util.stream.Streams
Deprecated.
Attempt to close an InputStream.
close(InputStream[]) - Static method in class org.infinispan.util.stream.Streams
Deprecated.
Attempt to close an array of InputStreams.
close(OutputStream) - Static method in class org.infinispan.util.stream.Streams
Deprecated.
Attempt to close an OutputStream.
close(OutputStream[]) - Static method in class org.infinispan.util.stream.Streams
Deprecated.
Attempt to close an array of OutputStreams.
close(AutoCloseable) - Static method in class org.infinispan.commons.util.Util
 
close(AutoCloseable...) - Static method in class org.infinispan.commons.util.Util
 
close(Object) - Static method in class org.infinispan.util.stream.Streams
Deprecated.
Attempt to close an InputStream or OutputStream.
close(Object[]) - Static method in class org.infinispan.util.stream.Streams
Deprecated.
Attempt to close an array of InputStreama and/or OutputStreams.
close(String) - Method in class org.infinispan.server.hotrod.iteration.DefaultIterationManager
 
close(String) - Method in interface org.infinispan.server.hotrod.iteration.IterationManager
 
close(DatagramSocket) - Method in class org.infinispan.remoting.transport.jgroups.NamedSocketFactory
 
close(ServerSocket) - Method in class org.infinispan.remoting.transport.jgroups.NamedSocketFactory
 
close(Socket) - Static method in class org.infinispan.commons.util.Util
 
close(Socket) - Method in class org.infinispan.remoting.transport.jgroups.NamedSocketFactory
 
close(Context) - Static method in class org.infinispan.commons.util.Util
 
CloseableIterable<E> - Interface in org.infinispan.commons.util
Interface that provides semantics of a Iterable and AutoCloseable interfaces.
CloseableIterator<E> - Interface in org.infinispan.commons.util
Interface that provides semantics of a Iterator and AutoCloseable interfaces.
CloseableIteratorCollection<E> - Interface in org.infinispan.commons.util
A collection that defines an iterator method that returns a CloseableIterator instead of a non closeable one.
CloseableIteratorCollectionAdapter<E> - Class in org.infinispan.commons.util
CloseableIteratorCollectionAdapter(Collection<E>) - Constructor for class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
 
CloseableIteratorSet<E> - Interface in org.infinispan.commons.util
A set that defines an iterator method that returns a CloseableIterator instead of a non closeable one.
CloseableIteratorSetAdapter<E> - Class in org.infinispan.commons.util
CloseableIteratorSetAdapter(Set<E>) - Constructor for class org.infinispan.commons.util.CloseableIteratorSetAdapter
 
Closeables - Class in org.infinispan.commons.util
This class consists exclusively of static methods that operate on or return closeable interfaces.
Closeables - Class in org.infinispan.util
This class is used solely for the purpose of converting classes only in core to corresponding closeable variants.
CloseableSpliterator<T> - Interface in org.infinispan.commons.util
Interface that provides semantics of a Spliterator and AutoCloseable interfaces.
CloseableSuppliedIterator<E> - Class in org.infinispan.util
 
CloseableSuppliedIterator(CloseableSupplier<? extends E>) - Constructor for class org.infinispan.util.CloseableSuppliedIterator
 
CloseableSupplier<T> - Interface in org.infinispan.util.function
 
closeChannel - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
closeChannels(ChannelMatcher) - Method in class org.infinispan.server.core.transport.NettyTransport
 
closeChannels(ChannelMatcher) - Method in interface org.infinispan.server.core.transport.Transport
 
closeMarshaller() - Method in interface org.infinispan.jboss.marshalling.commons.RiverCloseListener
 
closeOnFailure() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapperDelegate
 
closeOnFailure() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMappingPartialBuildState
 
closePublisher(String) - Method in class org.infinispan.reactive.publisher.impl.PublisherHandler
Closes the publisher that maps to the given request id
closeRunnable - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
closeUnmarshaller() - Method in interface org.infinispan.jboss.marshalling.commons.RiverCloseListener
 
closingChannelAfterError(Channel, Throwable) - Method in interface org.infinispan.client.hotrod.logging.Log
 
Cluster() - Constructor for class org.infinispan.distribution.topologyaware.TopologyInfo.Cluster
 
CLUSTER - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
CLUSTER_APPROXIMATE_ENTRIES - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Approximate current number of entry replicas currently in the cache cluster-wide.
CLUSTER_APPROXIMATE_ENTRIES_UNIQUE - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Approximate current number of unique entries in the cache cluster-wide.
CLUSTER_BACKUP_OWNERS_HEADER - Enum constant in enum org.infinispan.rest.ResponseHeader
 
CLUSTER_DISTRIBUTION_INFO - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
CLUSTER_EVENT - Static variable in interface org.infinispan.commons.marshall.Ids
 
CLUSTER_LISTENER_REMOVE_CALLABLE - Static variable in interface org.infinispan.commons.marshall.Ids
 
CLUSTER_LISTENER_REPLICATE_CALLABLE - Static variable in interface org.infinispan.commons.marshall.Ids
 
CLUSTER_LOADER - Enum constant in enum org.infinispan.configuration.parsing.Element
 
CLUSTER_NAME - Static variable in class org.infinispan.configuration.global.TransportConfiguration
 
CLUSTER_NODE_NAME_HEADER - Enum constant in enum org.infinispan.rest.ResponseHeader
 
CLUSTER_PERMISSION_MAPPER - Enum constant in enum org.infinispan.configuration.parsing.Element
 
CLUSTER_PERMISSION_MAPPER_CACHE - Static variable in class org.infinispan.security.mappers.ClusterPermissionMapper
 
CLUSTER_PRIMARY_OWNER_HEADER - Enum constant in enum org.infinispan.rest.ResponseHeader
 
CLUSTER_PROPERTIES_PREFIX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
CLUSTER_PROPERTIES_PREFIX_INTELLIGENCE_REGEX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
CLUSTER_PROPERTIES_PREFIX_REGEX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
CLUSTER_RECOVERY_ATTEMPTS - Static variable in class org.infinispan.topology.ClusterTopologyManagerImpl
 
CLUSTER_ROLE_MAPPER - Enum constant in enum org.infinispan.configuration.parsing.Element
 
CLUSTER_ROLE_MAPPER_CACHE - Static variable in class org.infinispan.security.mappers.ClusterRoleMapper
 
CLUSTER_SERVER_ADDRESS_HEADER - Enum constant in enum org.infinispan.rest.ResponseHeader
 
CLUSTER_STORE - Enum constant in enum org.infinispan.configuration.parsing.Element
 
clusterBackupOwners(String) - Method in class org.infinispan.rest.NettyRestResponse.Builder
 
ClusterCacheNotifier<K,V> - Interface in org.infinispan.notifications.cachelistener.cluster
This interface describes methods required for a cluster listener to be able to be bootstrapped and properly notified when a new event has been raised from the cluster.
ClusterCacheStats - Interface in org.infinispan.stats
Similar to Stats but cluster wide.
ClusterCacheStatsImpl - Class in org.infinispan.stats.impl
 
ClusterCacheStatsImpl() - Constructor for class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
ClusterCacheStatsImpl.DistributedCacheStatsCallableExternalizer - Class in org.infinispan.stats.impl
 
ClusterCacheStatus - Class in org.infinispan.topology
Keeps track of a cache's status: members, current/pending consistent hashes, and rebalance status
ClusterCacheStatus(EmbeddedCacheManager, GlobalComponentRegistry, String, AvailabilityStrategy, RebalanceType, ClusterTopologyManagerImpl, Transport, PersistentUUIDManager, EventLogManager, Optional<ScopedPersistentState>, boolean) - Constructor for class org.infinispan.topology.ClusterCacheStatus
 
clusterClientIntelligence(ClientIntelligence) - Method in class org.infinispan.client.hotrod.configuration.ClusterConfigurationBuilder
 
ClusterConfiguration - Class in org.infinispan.client.hotrod.configuration
 
ClusterConfiguration(List<ServerConfiguration>, String, ClientIntelligence, String) - Constructor for class org.infinispan.client.hotrod.configuration.ClusterConfiguration
 
ClusterConfigurationBuilder - Class in org.infinispan.client.hotrod.configuration
 
ClusterConfigurationBuilder(ConfigurationBuilder, String) - Constructor for class org.infinispan.client.hotrod.configuration.ClusterConfigurationBuilder
 
ClusterContainerStats - Interface in org.infinispan.stats
Cluster wide container statistics.
ClusterContainerStatsImpl - Class in org.infinispan.stats.impl
 
ClusterContainerStatsImpl() - Constructor for class org.infinispan.stats.impl.ClusterContainerStatsImpl
 
clustered - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
clustered - Variable in class org.infinispan.transaction.impl.TransactionTable
 
clustered() - Element in annotation type org.infinispan.notifications.Listener
Defines whether the annotated listener is clustered or not.
CLUSTERED_GET_COMMAND_SIZE - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
 
CLUSTERED_LOCK - Enum constant in enum org.infinispan.lock.configuration.Element
 
CLUSTERED_LOCK_CACHE_NAME - Static variable in class org.infinispan.lock.impl.ClusteredLockModuleLifecycle
 
CLUSTERED_LOCKS - Enum constant in enum org.infinispan.lock.configuration.Element
 
clusteredDefault() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
 
clusteredDefault() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
Helper method that gets you a default constructed GlobalConfiguration, preconfigured to use the default clustering stack.
ClusteredGetResponseValidityFilter - Class in org.infinispan.remoting.responses
A filter that tests the validity of ClusteredGetCommands.
ClusteredGetResponseValidityFilter(Collection<Address>, Address) - Constructor for class org.infinispan.remoting.responses.ClusteredGetResponseValidityFilter
 
ClusteredListenerInvocation(EncoderRegistry, ListenerInvocation<Event<K, V>>, QueueingSegmentListener<K, V, CacheEntryEvent<K, V>>, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, ?>, Class<? extends Annotation>, boolean, UUID, boolean, Listener.Observation, Set<Class<? extends Annotation>>, DataConversion, DataConversion, boolean) - Constructor for class org.infinispan.notifications.cachelistener.CacheNotifierImpl.ClusteredListenerInvocation
 
Clustered Listeners - Search tag in annotation type org.infinispan.notifications.Listener
Section
ClusteredLock - Interface in org.infinispan.lock.api
ClusteredLock is a data structure used for concurrent programming between Infinispan instances in cluster mode.
ClusteredLockBlockHoundIntegration - Class in org.infinispan.lock.impl
 
ClusteredLockBlockHoundIntegration() - Constructor for class org.infinispan.lock.impl.ClusteredLockBlockHoundIntegration
 
ClusteredLockConfiguration - Class in org.infinispan.lock.api
A Clustered Lock can be reentrant and there are different ownership levels.
ClusteredLockConfiguration - Class in org.infinispan.lock.configuration
ClusteredLock configuration.
ClusteredLockConfiguration() - Constructor for class org.infinispan.lock.api.ClusteredLockConfiguration
Default lock is non reentrant and the ownership level is OwnershipLevel.NODE
ClusteredLockConfigurationBuilder - Class in org.infinispan.lock.configuration
ClusteredLock configuration builder.
ClusteredLockConfigurationBuilder() - Constructor for class org.infinispan.lock.configuration.ClusteredLockConfigurationBuilder
 
ClusteredLockConfigurationParser - Class in org.infinispan.lock.configuration
Clustered Locks configuration parser
ClusteredLockConfigurationParser() - Constructor for class org.infinispan.lock.configuration.ClusteredLockConfigurationParser
 
ClusteredLockException - Exception Class in org.infinispan.lock.exception
Exception used to handle errors on clustered locks
ClusteredLockException(String) - Constructor for exception class org.infinispan.lock.exception.ClusteredLockException
 
ClusteredLockException(Throwable) - Constructor for exception class org.infinispan.lock.exception.ClusteredLockException
 
ClusteredLockManager - Interface in org.infinispan.lock.api
Provides the API to define, create and remove ClusteredLocks.
ClusteredLockManagerConfiguration - Class in org.infinispan.lock.configuration
The ClusteredLockManager configuration.
ClusteredLockManagerConfigurationBuilder - Class in org.infinispan.lock.configuration
The ClusteredLockManager configuration builder.
ClusteredLockManagerConfigurationBuilder(GlobalConfigurationBuilder) - Constructor for class org.infinispan.lock.configuration.ClusteredLockManagerConfigurationBuilder
 
ClusteredLockModuleLifecycle - Class in org.infinispan.lock.impl
Locks module configuration
ClusteredLockModuleLifecycle() - Constructor for class org.infinispan.lock.impl.ClusteredLockModuleLifecycle
 
clusteredRequiresBeingShared() - Method in interface org.infinispan.persistence.remote.logging.Log
 
ClusteredTransactionOriginatorChecker - Class in org.infinispan.transaction.impl
A TransactionOriginatorChecker implementation for clustered caches.
ClusteredTransactionOriginatorChecker() - Constructor for class org.infinispan.transaction.impl.ClusteredTransactionOriginatorChecker
 
ClusterEvent<K,V> - Class in org.infinispan.notifications.cachelistener.cluster
This is an event designed for use with cluster listeners solely.
ClusterEvent.Externalizer - Class in org.infinispan.notifications.cachelistener.cluster
 
ClusterEventManager<K,V> - Interface in org.infinispan.notifications.cachelistener.cluster
 
ClusterEventManagerFactory - Class in org.infinispan.notifications.cachelistener.cluster
Constructs the data container.
ClusterEventManagerFactory() - Constructor for class org.infinispan.notifications.cachelistener.cluster.ClusterEventManagerFactory
 
ClusterEventManagerStub<K,V> - Class in org.infinispan.notifications.cachelistener.cluster.impl
 
ClusterEventManagerStub() - Constructor for class org.infinispan.notifications.cachelistener.cluster.impl.ClusterEventManagerStub
 
ClusterExecutionPolicy - Enum in org.infinispan.manager
ClusterExecutionPolicy controls how which nodes commands submitted via ClusterExecutor.
ClusterExecutor - Interface in org.infinispan.manager
A cluster executor that can be used to invoke a given command across the cluster.
ClusterExecutors - Class in org.infinispan.manager.impl
Static factory methods to construct a ClusterExecutor
ClusterExpirationManager<K,V> - Class in org.infinispan.expiration.impl
Allows for cluster based expirations to occur.
ClusterExpirationManager() - Constructor for class org.infinispan.expiration.impl.ClusterExpirationManager
 
ClusterHealth - Interface in org.infinispan.health
Cluster health information.
clustering() - Method in class org.infinispan.configuration.cache.AbstractCustomInterceptorsConfigurationChildBuilder
 
clustering() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationChildBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.AbstractPersistenceConfigurationChildBuilder
 
clustering() - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
clustering() - Method in class org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.remote.configuration.AbstractSecurityConfigurationChildBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.AbstractTransportConfigurationChildBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
 
clustering() - Method in class org.infinispan.security.impl.CreatePermissionConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.CustomStoreConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.IndexReaderConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder.StringTableManipulationConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.jdbc.common.configuration.ManagedConnectionFactoryConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.remote.configuration.MechanismConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.MemoryStorageConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.QueryConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.SecurityConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.parsing.SFSToSIFSConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.StatisticsConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
 
clustering() - Method in class org.infinispan.persistence.remote.configuration.TrustStoreConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
 
clustering() - Method in class org.infinispan.configuration.cache.Configuration
 
clustering() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
clustering() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
CLUSTERING - Enum constant in enum org.infinispan.configuration.parsing.Element
 
ClusteringConfiguration - Class in org.infinispan.configuration.cache
Defines clustered characteristics of the cache.
ClusteringConfigurationBuilder - Class in org.infinispan.configuration.cache
Defines clustered characteristics of the cache.
ClusteringConfigurationChildBuilder - Interface in org.infinispan.configuration.cache
 
ClusteringDependentLogicFactory - Class in org.infinispan.factories
 
ClusteringDependentLogicFactory() - Constructor for class org.infinispan.factories.ClusteringDependentLogicFactory
 
clusterListenerOnPrimaryOnly() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
ClusterListenerRemoveCallable - Class in org.infinispan.notifications.cachelistener.cluster
This DistributedCallable is used to remove registered RemoteClusterListener on each of the various nodes when a cluster listener is unregistered from the cache.
ClusterListenerRemoveCallable(String, UUID) - Constructor for class org.infinispan.notifications.cachelistener.cluster.ClusterListenerRemoveCallable
 
ClusterListenerRemoveCallable.Externalizer - Class in org.infinispan.notifications.cachelistener.cluster
 
ClusterListenerReplicateCallable<K,V> - Class in org.infinispan.notifications.cachelistener.cluster
This DistributedCallable is used to install a RemoteClusterListener on the resulting node.
ClusterListenerReplicateCallable(String, UUID, Address, CacheEventFilter<K, V>, CacheEventConverter<K, V, ?>, boolean, Set<Class<? extends Annotation>>, DataConversion, DataConversion, boolean) - Constructor for class org.infinispan.notifications.cachelistener.cluster.ClusterListenerReplicateCallable
 
ClusterListenerReplicateCallable.Externalizer - Class in org.infinispan.notifications.cachelistener.cluster
 
ClusterLoader - Class in org.infinispan.persistence.cluster
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.
ClusterLoader() - Constructor for class org.infinispan.persistence.cluster.ClusterLoader
Deprecated.
 
ClusterLoaderConfiguration - Class in org.infinispan.configuration.cache
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.
ClusterLoaderConfigurationBuilder - Class in org.infinispan.configuration.cache
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.
ClusterLoaderConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
Deprecated.
 
clusterName() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
clusterName(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
Defines the name of the cluster.
clusterNodeName(String) - Method in class org.infinispan.rest.NettyRestResponse.Builder
 
ClusterPermissionMapper - Class in org.infinispan.security.mappers
ClusterPermissionMapper.
ClusterPermissionMapper() - Constructor for class org.infinispan.security.mappers.ClusterPermissionMapper
 
clusterPrimaryOwner(String) - Method in class org.infinispan.rest.NettyRestResponse.Builder
 
ClusterPublisherManager<K,V> - Interface in org.infinispan.reactive.publisher.impl
Manages distribution of various publisher operations that are ran locally and/or sent to remote nodes.
ClusterPublisherManagerImpl<K,V> - Class in org.infinispan.reactive.publisher.impl
ClusterPublisherManager that determines targets for the given segments and/or keys and then sends to local and remote nodes in parallel collecting results to be returned.
ClusterPublisherManagerImpl() - Constructor for class org.infinispan.reactive.publisher.impl.ClusterPublisherManagerImpl
 
ClusterResource - Class in org.infinispan.rest.resources
 
ClusterResource(InvocationHelper) - Constructor for class org.infinispan.rest.resources.ClusterResource
 
ClusterRoleMapper - Class in org.infinispan.security.impl
Deprecated, for removal: This API element is subject to removal in a future version.
use ClusterRoleMapper instead. This class will be removed in Infinispan 14.0
ClusterRoleMapper - Class in org.infinispan.security.mappers
ClusterRoleMapper.
ClusterRoleMapper() - Constructor for class org.infinispan.security.impl.ClusterRoleMapper
Deprecated.
 
ClusterRoleMapper() - Constructor for class org.infinispan.security.mappers.ClusterRoleMapper
 
ClusterRoleMapper.RoleSet - Class in org.infinispan.security.mappers
 
clusters() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
clusterServerAddress(String) - Method in class org.infinispan.rest.NettyRestResponse.Builder
 
clusterSniHostName(String) - Method in class org.infinispan.client.hotrod.configuration.ClusterConfigurationBuilder
 
clusterStop() - Method in interface org.infinispan.server.core.ServerManagement
 
ClusterTopologyManager - Interface in org.infinispan.topology
Maintains the topology for all the caches in the cluster.
ClusterTopologyManager.ClusterManagerStatus - Enum in org.infinispan.topology
 
ClusterTopologyManagerFactory - Class in org.infinispan.topology
Factory for ClusterTopologyManager implementations.
ClusterTopologyManagerFactory() - Constructor for class org.infinispan.topology.ClusterTopologyManagerFactory
 
ClusterTopologyManagerImpl - Class in org.infinispan.topology
The ClusterTopologyManager implementation.
ClusterTopologyManagerImpl() - Constructor for class org.infinispan.topology.ClusterTopologyManagerImpl
 
clusterView - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
ClusterView - Class in org.infinispan.remoting.transport.jgroups
Information about the JGroups cluster.
cm - Variable in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
collect(Supplier<E>, BiConsumer<E, ? super I>) - Static method in class org.infinispan.reactive.publisher.PublisherReducers
 
collect(Supplier<Collector<? super R, ?, R1>>) - Method in interface org.infinispan.CacheStream
Performs a mutable reduction operation on the elements of this stream using a Collector that is lazily created from the Supplier provided.
collect(Supplier<Collector<? super R, ?, R1>>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
collect(Supplier<R>, BiConsumer<R, ? super T>, BiConsumer<R, R>) - Method in interface org.infinispan.functional.Traversable
A terminal operation that transforms the traversable into a result container, first constructed with the given supplier, and then accumulating elements over it with the given consumer.
collect(Supplier<R>, ObjDoubleConsumer<R>, BiConsumer<R, R>) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
collect(Supplier<R>, ObjDoubleConsumer<R>, BiConsumer<R, R>) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
collect(Supplier<R>, ObjIntConsumer<R>, BiConsumer<R, R>) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
collect(Supplier<R>, ObjIntConsumer<R>, BiConsumer<R, R>) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
collect(Supplier<R>, ObjLongConsumer<R>, BiConsumer<R, R>) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
collect(Supplier<R>, ObjLongConsumer<R>, BiConsumer<R, R>) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
collect(Supplier<R1>, BiConsumer<R1, ? super R>, BiConsumer<R1, R1>) - Method in interface org.infinispan.CacheStream
collect(Supplier<R1>, BiConsumer<R1, ? super R>, BiConsumer<R1, R1>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
Note: this method doesn't pay attention to ordering constraints and any sorting performed on the stream will be ignored by this terminal operator.
collect(Supplier<R1>, BiConsumer<R1, ? super R>, BiConsumer<R1, R1>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
collect(Supplier<R1>, BiConsumer<R1, ? super R>, BiConsumer<R1, R1>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
collect(Collector<? super R, A, R1>) - Method in interface org.infinispan.CacheStream
collect(Collector<? super R, A, R1>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
collect(Collector<? super R, A, R1>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
collect(Collector<? super R, A, R1>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
collect(Collector<? super T, A, R>) - Method in interface org.infinispan.functional.Traversable
A terminal operation that transforms the traversable into a result container using a Collector.
collect(CacheStream<? extends CacheEntry<K, V>>, InvocationContext, String) - Method in interface org.infinispan.distribution.group.impl.GroupManager
Collects all entries belonging to a single group.
collect(CacheStream<? extends CacheEntry<K, V>>, InvocationContext, String) - Method in class org.infinispan.distribution.group.impl.GroupManagerImpl
 
collect(SerializableSupplier<Collector<? super R, ?, R1>>) - Method in interface org.infinispan.CacheStream
Performs a mutable reduction operation on the elements of this stream using a Collector that is lazily created from the SerializableSupplier provided.
collect(SerializableSupplier<Collector<? super R, ?, R1>>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
collect(SerializableSupplier<R>, SerializableObjDoubleConsumer<R>, SerializableBiConsumer<R, R>) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleStream.collect(Supplier, ObjDoubleConsumer, BiConsumer) except that the arguments must also implement Serializable
collect(SerializableSupplier<R>, SerializableObjIntConsumer<R>, SerializableBiConsumer<R, R>) - Method in interface org.infinispan.IntCacheStream
Same as IntStream.collect(Supplier, ObjIntConsumer, BiConsumer) except that the arguments must also implement Serializable
collect(SerializableSupplier<R>, SerializableObjLongConsumer<R>, SerializableBiConsumer<R, R>) - Method in interface org.infinispan.LongCacheStream
Same as LongStream.collect(Supplier, ObjLongConsumer, BiConsumer) except that the arguments must also implement Serializable.
collect(SerializableSupplier<R1>, SerializableBiConsumer<R1, ? super R>, SerializableBiConsumer<R1, R1>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.collect(Supplier, BiConsumer, BiConsumer) except that the various arguments must also implement Serializable
CollectionAttributeCopier<T> - Class in org.infinispan.commons.configuration.attributes
CollectionAttributeCopier.
CollectionAttributeCopier() - Constructor for class org.infinispan.commons.configuration.attributes.CollectionAttributeCopier
 
collectionCopier() - Static method in class org.infinispan.commons.configuration.attributes.CollectionAttributeCopier
 
CollectionExternalizer - Class in org.infinispan.marshall.exts
 
CollectionExternalizer() - Constructor for class org.infinispan.marshall.exts.CollectionExternalizer
 
CollectionMapper<E,R> - Class in org.infinispan.util
A collection that maps another one to a new one of a possibly different type.
CollectionMapper(Collection<E>, Function<? super E, ? extends R>) - Constructor for class org.infinispan.util.CollectionMapper
 
COLLECTIONS - Static variable in interface org.infinispan.commons.marshall.Ids
 
collector(Supplier<Collector<T, ?, R>>) - Static method in class org.infinispan.stream.CacheCollectors
Similar to CacheCollectors.serializableCollector(SerializableSupplier) except that the supplier provided must be marshable through ISPN marshalling techniques.
collectorFinalizer(Collector<?, E, ?>) - Static method in class org.infinispan.reactive.publisher.PublisherReducers
 
collectorFor(Address) - Method in interface org.infinispan.util.concurrent.CommandAckCollector.MultiTargetCollector
 
collectorReducer(Collector<? super I, E, ?>) - Static method in class org.infinispan.reactive.publisher.PublisherReducers
 
collectWithOptions(Json...) - Method in class org.infinispan.commons.dataconversion.internal.Json
Return an object representing the complete configuration of a merge.
column - Variable in exception class org.infinispan.commons.configuration.io.xml.XmlPullParserException
 
columnName(String) - Method in class org.infinispan.persistence.jdbc.configuration.SegmentColumnConfigurationBuilder
 
columnNumber - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
columnType(String) - Method in class org.infinispan.persistence.jdbc.configuration.SegmentColumnConfigurationBuilder
 
combine(JsonArrayCollector) - Method in class org.infinispan.commons.dataconversion.internal.JsonArrayCollector
 
Combine - Class in org.infinispan.commons.configuration
Defines how Attributes and ConfigurationElements are combined when overlaying a configuration (the overlay) on top of another (the template) using Builder.read(Object, Combine).
Combine(Combine.RepeatedAttributes, Combine.Attributes) - Constructor for class org.infinispan.commons.configuration.Combine
 
COMBINE - Enum constant in enum org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.StackCombine
 
Combine.Attributes - Enum in org.infinispan.commons.configuration
 
Combine.RepeatedAttributes - Enum in org.infinispan.commons.configuration
 
combinedBiFunction() - Static method in class org.infinispan.reactive.RxJavaInterop
Provides a BiFunction to be used with methods like CompletionStage.thenCombine(CompletionStage, java.util.function.BiFunction) to convert the values to a Flowable.
combinePredicate(IntSet, KeyPartitioner, Predicate<? super K>) - Static method in class org.infinispan.persistence.internal.PersistenceUtil
 
combiner() - Method in class org.infinispan.commons.dataconversion.internal.JsonArrayCollector
 
combiner() - Method in class org.infinispan.commons.util.ArrayCollector
 
COMMAND_ID - Static variable in class org.infinispan.expiration.impl.TouchCommand
 
COMMAND_ID - Static variable in class org.infinispan.manager.impl.ReplicableManagerFunctionCommand
 
COMMAND_ID - Static variable in class org.infinispan.manager.impl.ReplicableRunnableCommand
 
COMMAND_ID - Static variable in class org.infinispan.notifications.cachelistener.cluster.MultiClusterEventCommand
 
COMMAND_ID - Static variable in class org.infinispan.topology.HeartBeatCommand
 
COMMAND_ID - Static variable in class org.infinispan.xsite.commands.XSiteAmendOfflineStatusCommand
 
COMMAND_ID - Static variable in class org.infinispan.xsite.commands.XSiteAutoTransferStatusCommand
 
COMMAND_ID - Static variable in class org.infinispan.xsite.commands.XSiteBringOnlineCommand
 
COMMAND_ID - Static variable in class org.infinispan.xsite.commands.XSiteLocalEventCommand
 
COMMAND_ID - Static variable in class org.infinispan.xsite.commands.XSiteOfflineStatusCommand
 
COMMAND_ID - Static variable in class org.infinispan.xsite.commands.XSiteSetStateTransferModeCommand
 
COMMAND_ID - Static variable in class org.infinispan.xsite.commands.XSiteStateTransferCancelSendCommand
 
COMMAND_ID - Static variable in class org.infinispan.xsite.commands.XSiteStateTransferClearStatusCommand
 
COMMAND_ID - Static variable in class org.infinispan.xsite.commands.XSiteStateTransferFinishReceiveCommand
 
COMMAND_ID - Static variable in class org.infinispan.xsite.commands.XSiteStateTransferFinishSendCommand
 
COMMAND_ID - Static variable in class org.infinispan.xsite.commands.XSiteStateTransferRestartSendingCommand
 
COMMAND_ID - Static variable in class org.infinispan.xsite.commands.XSiteStateTransferStartReceiveCommand
 
COMMAND_ID - Static variable in class org.infinispan.xsite.commands.XSiteStateTransferStartSendCommand
 
COMMAND_ID - Static variable in class org.infinispan.xsite.commands.XSiteStateTransferStatusRequestCommand
 
COMMAND_ID - Static variable in class org.infinispan.xsite.commands.XSiteStatusCommand
 
COMMAND_ID - Static variable in class org.infinispan.xsite.commands.XSiteTakeOfflineCommand
 
COMMAND_ID - Static variable in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
 
COMMAND_INVOCATION_ID - Static variable in interface org.infinispan.commons.marshall.Ids
 
COMMAND_RETRY - Enum constant in enum org.infinispan.context.Flag
If a write operation encounters a retry due to a topology change this flag should be used to tell the new owner that such a thing happened.
COMMAND_RETRY - Static variable in class org.infinispan.context.impl.FlagBitSets
 
CommandAckCollector - Class in org.infinispan.util.concurrent
An acknowledge collector for Triangle algorithm used in non-transactional caches for write operations.
CommandAckCollector() - Constructor for class org.infinispan.util.concurrent.CommandAckCollector
 
CommandAckCollector.MultiTargetCollector - Interface in org.infinispan.util.concurrent
 
CommandInvocationId - Class in org.infinispan.commands
Represents an unique identified for non-transaction write commands.
commandsBackendInitialized(String) - Method in interface org.infinispan.query.logging.Log
 
commandsFactory - Variable in class org.infinispan.cache.impl.CacheImpl
 
commandsFactory - Variable in class org.infinispan.transaction.impl.TransactionTable
 
CommandsFactory - Interface in org.infinispan.commands
A factory to build commands, initializing and injecting dependencies accordingly.
CommandsFactoryImpl - Class in org.infinispan.commands
 
CommandsFactoryImpl() - Constructor for class org.infinispan.commands.CommandsFactoryImpl
 
COMMENT - Static variable in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
An XML comment was just read.
commit() - Method in class org.infinispan.commons.tx.TransactionImpl
Attempt to commit this transaction.
commit() - Method in class org.infinispan.commons.tx.TransactionManagerImpl
 
commit() - Method in class org.infinispan.transaction.tm.EmbeddedUserTransaction
 
commit(int, InternalDataContainer<K, V>) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
commit(Transaction) - Method in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
 
commit(Transaction) - Method in interface org.infinispan.persistence.spi.NonBlockingStore
Commit changes in the provided transaction to the underlying store.
commit(Transaction) - Method in interface org.infinispan.persistence.spi.TransactionalCacheWriter
Deprecated.
Commit the provided transaction's changes to the underlying store.
commit(Transaction) - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
 
commit(Transaction) - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
 
commit(Xid, boolean) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
Same comment as for TransactionXaAdapter.prepare(javax.transaction.xa.Xid) applies for commit.
commit(XidImpl, boolean) - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
commit(DataContainer) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
commit(DataContainer) - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
commit(DataContainer) - Method in class org.infinispan.container.entries.NullCacheEntry
 
commit(DataContainer<K, V>) - Method in interface org.infinispan.container.entries.CacheEntry
Commits changes
commit(DataContainer<K, V>) - Method in class org.infinispan.container.entries.ClearCacheEntry
 
commit(DataContainer<K, V>) - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
commit(LocalTransaction, boolean) - Method in class org.infinispan.transaction.impl.TransactionCoordinator
 
COMMIT_COMMAND_SIZE - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
 
COMMIT_EXECUTION_TIME - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
 
COMMIT_INTERVAL - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
COMMIT_TX - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
COMMIT_TX - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
commitAllTxStores(TxInvocationContext<AbstractCacheTransaction>, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
 
commitAsync(TransactionResourceConverter) - Method in class org.infinispan.commons.tx.TransactionImpl
 
commitInterval(int) - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
 
commitLocalTransaction(AdvancedCache<?, ?>, XidImpl, long) - Static method in class org.infinispan.server.hotrod.tx.operation.Util
 
COMMITTED - Enum constant in enum org.infinispan.container.entries.ReadCommittedEntry.Flags
 
COMMITTED - Enum constant in enum org.infinispan.server.hotrod.tx.table.Status
The client transaction is committed.
COMMITTED - Enum constant in enum org.infinispan.transaction.impl.TransactionTable.CompletedTransactionStatus
 
CommitTransactionOperation - Class in org.infinispan.server.hotrod.tx.operation
It commits a transaction in all involved caches.
CommitTransactionOperation(HotRodHeader, HotRodServer, Subject, XidImpl, BiConsumer<HotRodHeader, Integer>) - Constructor for class org.infinispan.server.hotrod.tx.operation.CommitTransactionOperation
 
COMMON_NAME_ROLE_MAPPER - Enum constant in enum org.infinispan.configuration.parsing.Element
 
CommonNameRoleMapper - Class in org.infinispan.security.impl
Deprecated.
CommonNameRoleMapper - Class in org.infinispan.security.mappers
CommonNameRoleMapper.
CommonNameRoleMapper() - Constructor for class org.infinispan.security.impl.CommonNameRoleMapper
Deprecated.
 
CommonNameRoleMapper() - Constructor for class org.infinispan.security.mappers.CommonNameRoleMapper
 
COMMONS_LOWER_BOUND - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
CommonsBlockHoundIntegration - Class in org.infinispan.commons.internal
 
CommonsBlockHoundIntegration() - Constructor for class org.infinispan.commons.internal.CommonsBlockHoundIntegration
 
compactedFileNotLongEnough(byte[], int, long, long, EntryHeader) - Method in interface org.infinispan.persistence.sifs.Log
 
COMPACTION_THRESHOLD - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
COMPACTION_THRESHOLD - Static variable in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfiguration
 
compactionThreshold() - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfiguration
 
compactionThreshold(double) - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
If the amount of unused space in some data file gets above this threshold, the file is compacted - entries from that file are copied to a new file and the old file is deleted.
compactorEncounteredException(Throwable, int) - Method in interface org.infinispan.persistence.sifs.Log
 
compactorFailed(Throwable) - Method in interface org.infinispan.persistence.sifs.Log
 
compareAndSet(long, long) - Method in interface org.infinispan.counter.api.StrongCounter
Atomically sets the value to the given updated value if the current value == the expected value.
compareAndSet(long, long) - Method in interface org.infinispan.counter.api.SyncStrongCounter
 
compareAndSwap(long, long) - Method in interface org.infinispan.counter.api.StrongCounter
Atomically sets the value to the given updated value if the current value == the expected value.
compareAndSwap(long, long) - Method in interface org.infinispan.counter.api.SyncStrongCounter
 
compareAndSwap(long, long) - Method in class org.infinispan.counter.impl.SyncStrongCounterAdapter
 
CompareAndSwapOperation - Class in org.infinispan.client.hotrod.counter.operation
CompareAndSwapOperation(ChannelFactory, AtomicReference<ClientTopology>, Configuration, String, long, long, CounterConfiguration) - Constructor for class org.infinispan.client.hotrod.counter.operation.CompareAndSwapOperation
 
compareTo(byte[]) - Static method in class org.infinispan.commons.util.Version
 
compareTo(byte[]) - Static method in class org.infinispan.Version
Deprecated.
 
compareTo(File) - Method in class org.infinispan.io.GridFile
Deprecated.
 
compareTo(EntryVersion) - Method in interface org.infinispan.container.versioning.EntryVersion
Compares the given version against the current instance.
compareTo(EntryVersion) - Method in class org.infinispan.container.versioning.NumericVersion
 
compareTo(EntryVersion) - Method in class org.infinispan.container.versioning.SimpleClusteredVersion
 
compareTo(IracEntryVersion) - Method in class org.infinispan.container.versioning.irac.IracEntryVersion
Compares this instance with another IracEntryVersion instance.
compareTo(IracEntryVersion.MapEntry) - Method in class org.infinispan.container.versioning.irac.IracEntryVersion.MapEntry
 
compareTo(TopologyIracVersion) - Method in class org.infinispan.container.versioning.irac.TopologyIracVersion
 
compareTo(TopologyInfo.Location) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo.Location
 
compareTo(Address) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
compareTo(Address) - Method in class org.infinispan.remoting.transport.LocalModeAddress
 
compareTo(Address) - Method in class org.infinispan.remoting.transport.SiteAddress
 
compareTo(Address) - Method in class org.infinispan.server.hotrod.tx.table.ClientAddress
 
compareTo(Address) - Method in class org.infinispan.topology.PersistentUUID
 
compareTo(ByteString) - Method in class org.infinispan.util.ByteString
 
COMPATIBILITY - Enum constant in enum org.infinispan.configuration.parsing.Element
 
CompletableFutures - Class in org.infinispan.commons.util.concurrent
Utility methods connecting CompletableFuture futures.
complete() - Method in interface org.infinispan.scattered.BiasManager.Revocation
 
complete(Consumer<LogAppender>) - Method in class org.infinispan.persistence.sifs.LogAppender
 
complete(CompletableFuture<? super T>, T) - Method in interface org.infinispan.util.concurrent.NonBlockingManager
Completes the provided future with the given value.
complete(CompletableFuture<? super T>, T) - Method in class org.infinispan.util.concurrent.NonBlockingManagerImpl
 
complete(T) - Method in class org.infinispan.remoting.transport.AbstractRequest
 
COMPLETE - Enum constant in enum org.infinispan.server.core.BackupManager.Status
 
COMPLETE - Enum constant in enum org.infinispan.topology.RebalancingStatus
 
COMPLETE_FUNCTION - Static variable in class org.infinispan.server.core.ExternalizerIds
 
COMPLETED_TX_TIMEOUT - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
COMPLETED_TX_TIMEOUT - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
 
completedEmptyMap() - Static method in class org.infinispan.commons.util.concurrent.CompletableFutures
 
completedExceptionFuture(Throwable) - Static method in class org.infinispan.commons.util.concurrent.CompletableFutures
 
completedFalse() - Static method in class org.infinispan.commons.util.concurrent.CompletableFutures
 
completedFlowableProcessor() - Static method in class org.infinispan.commons.reactive.RxJavaInterop
Returns a FlowableProcessor that is already complete and will ignore any value submitted to it and will immediately cancel any subscriptions it receives.
completedNull() - Static method in class org.infinispan.commons.util.concurrent.CompletableFutures
 
completedNullStage() - Static method in class org.infinispan.interceptors.InvocationStage
 
completedSegment() - Method in interface org.infinispan.reactive.publisher.impl.SegmentPublisherSupplier.Notification
The segment that was complete for this notification
completedTrue() - Static method in class org.infinispan.commons.util.concurrent.CompletableFutures
 
completedTxTimeout() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
 
completedTxTimeout(long) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
The duration (millis) in which to keep information about the completion of a transaction.
completeExceptionally(long, Throwable, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
Acknowledges an exception during the operation execution.
completeExceptionally(Throwable) - Method in class org.infinispan.remoting.transport.AbstractRequest
 
completeExceptionally(CompletableFuture<?>, Throwable) - Method in interface org.infinispan.util.concurrent.NonBlockingManager
Exceptionally completes the provided future with the given throble.
completeExceptionally(CompletableFuture<?>, Throwable) - Method in class org.infinispan.util.concurrent.NonBlockingManagerImpl
 
completeOperation(Object, CompletableFuture<DataOperationOrderer.Operation>, DataOperationOrderer.Operation) - Method in class org.infinispan.util.concurrent.DataOperationOrderer
Completes a given operation and removes all internal references from the orderer
CompletionStages - Class in org.infinispan.util.concurrent
Utility methods for handling CompletionStage instances.
COMPONENT - Static variable in interface org.infinispan.jmx.ObjectNameKeys
 
ComponentAccessor<T> - Class in org.infinispan.factories.impl
Component lifecycle management
ComponentAccessor(String, Integer, boolean, String, List<String>) - Constructor for class org.infinispan.factories.impl.ComponentAccessor
 
ComponentAlias - Class in org.infinispan.factories.impl
 
ComponentFactory - Interface in org.infinispan.factories
Factory for Infinispan components.
ComponentName - Annotation Type in org.infinispan.factories.annotations
Mechanism for specifying the name of components to retrieve
ComponentRef<T> - Interface in org.infinispan.factories.impl
Reference to a component.
componentRegistry - Variable in class org.infinispan.cache.impl.CacheImpl
 
componentRegistry - Variable in class org.infinispan.factories.AbstractNamedCacheComponentFactory
Deprecated, for removal: This API element is subject to removal in a future version.
ComponentRegistry - Class in org.infinispan.factories
Named cache specific components
ComponentRegistry(String, Configuration, AdvancedCache<?, ?>, GlobalComponentRegistry, ClassLoader) - Constructor for class org.infinispan.factories.ComponentRegistry
Creates an instance of the component registry.
ComponentRegistryUtils - Class in org.infinispan.query.impl
Lookup methods for various internal components of search module.
ComponentStatus - Enum in org.infinispan.lifecycle
Different states a component may be in.
ComposedSegmentedLoadWriteStore<K,V,T> - Class in org.infinispan.persistence.support
Segmented store that creates multiple inner stores for each segment.
ComposedSegmentedLoadWriteStore(AbstractSegmentedStoreConfiguration<T>) - Constructor for class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
composeStageIfNeeded(AggregateCompletionStage<Void>, CompletionStage<Void>) - Static method in class org.infinispan.notifications.impl.AbstractListenerImpl
If the given stage is null or normally completed returns the provided aggregateCompletionStage as is.
composeWithExceptions(Runnable, Runnable) - Static method in class org.infinispan.commons.util.Util
Given two Runnables, return a Runnable that executes both in sequence, even if the first throws an exception, and if both throw exceptions, add any exceptions thrown by the second as suppressed exceptions of the first.
composeWithExceptions(Consumer<Supplier<PrimitiveIterator.OfInt>>, Consumer<Supplier<PrimitiveIterator.OfInt>>) - Static method in class org.infinispan.stream.impl.AbstractCacheStream
Given two SegmentCompletionListener, return a SegmentCompletionListener that executes both in sequence, even if the first throws an exception, and if both throw exceptions, add any exceptions thrown by the second as suppressed exceptions of the first.
COMPOSITE_KEY_FILTER - Static variable in interface org.infinispan.commons.marshall.Ids
 
COMPOSITE_KEY_VALUE_FILTER - Static variable in interface org.infinispan.commons.marshall.Ids
 
CompositeAnalysisConfigurer - Class in org.infinispan.search.mapper.mapping.impl
 
CompositeAnalysisConfigurer(Collection<LuceneAnalysisConfigurer>) - Constructor for class org.infinispan.search.mapper.mapping.impl.CompositeAnalysisConfigurer
 
CompositeCacheEventFilter<K,V> - Class in org.infinispan.notifications.cachelistener.filter
Allows AND-composing several cache event filters.
CompositeCacheEventFilter(CacheEventFilter<? super K, ? super V>...) - Constructor for class org.infinispan.notifications.cachelistener.filter.CompositeCacheEventFilter
 
CompositeChannelMatcher - Class in org.infinispan.server.core.transport
 
CompositeChannelMatcher(ChannelMatcher...) - Constructor for class org.infinispan.server.core.transport.CompositeChannelMatcher
 
CompositeKeyValueFilter<K,V> - Class in org.infinispan.filter
Allows AND-composing several key/value filters.
CompositeKeyValueFilter(KeyValueFilter<? super K, ? super V>...) - Constructor for class org.infinispan.filter.CompositeKeyValueFilter
 
CompositeKeyValueFilter.Externalizer - Class in org.infinispan.filter
 
COMPRESSION - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.Element
 
COMPRESSION_LEVEL - Static variable in class org.infinispan.rest.configuration.RestServerConfiguration
 
COMPRESSION_TYPE - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.Attribute
 
COMPRESSION_TYPE - Static variable in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfiguration
 
compressionLevel(int) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
 
compressionType() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfiguration
 
compressionType(CompressionType) - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
 
CompressionType - Enum in org.infinispan.persistence.rocksdb.configuration
 
compute(int, K, DataContainer.ComputeAction<K, V>) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
compute(int, K, DataContainer.ComputeAction<K, V>) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
compute(int, K, DataContainer.ComputeAction<K, V>) - Method in interface org.infinispan.container.impl.InternalDataContainer
Same as DataContainer.compute(Object, ComputeAction) except that the segment of the key can provided to update entries without calculating the segment for the given key.
compute(int, WrappedBytes, DataContainer.ComputeAction<WrappedBytes, WrappedBytes>) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
compute(int, WrappedBytes, DataContainer.ComputeAction<WrappedBytes, WrappedBytes>) - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in interface org.infinispan.Cache
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.CacheImpl
 
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.EncoderCache
 
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
 
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.commons.api.BasicCache
An overloaded form of ConcurrentMap.compute(Object, BiFunction) which takes in lifespan parameters.
compute(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.BasicCache
An overloaded form of ConcurrentMap.compute(Object, BiFunction) which takes in lifespan and maxIdleTime parameters.
compute(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
An overloaded form of
invalid reference
#compute(K, BiFunction)
, which takes in an instance of Metadata which can be used to provide metadata information for the entry being stored, such as lifespan, version of value...etc.
compute(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
compute(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
compute(K, DataContainer.ComputeAction<K, V>) - Method in interface org.infinispan.container.DataContainer
Computes the new value for the key.
compute(K, DataContainer.ComputeAction<K, V>) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
compute(K, DataContainer.ComputeAction<K, V>) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
compute(K, InternalCacheEntry<K, V>, InternalEntryFactory) - Method in interface org.infinispan.container.DataContainer.ComputeAction
Computes the new value for the key.
compute(K, SerializableBiFunction<? super K, ? super V, ? extends V>) - Method in interface org.infinispan.Cache
compute(K, SerializableBiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.Cache
compute(K, SerializableBiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
compute(K, SerializableBiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
compute(K, SerializableBiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
compute(WrappedBytes, BiFunction<? super WrappedBytes, ? super InternalCacheEntry<WrappedBytes, WrappedBytes>, ? extends InternalCacheEntry<WrappedBytes, WrappedBytes>>) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
compute(WrappedBytes, DataContainer.ComputeAction<WrappedBytes, WrappedBytes>) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
compute(WrappedBytes, DataContainer.ComputeAction<WrappedBytes, WrappedBytes>) - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
computeActualNumOwners(int, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in interface org.infinispan.commons.api.AsyncCache
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
Overloaded
invalid reference
#computeAsync(K, BiFunction)
, which stores metadata alongside the value.
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeAsync(K, SerializableBiFunction<? super K, ? super V, ? extends V>) - Method in interface org.infinispan.Cache
computeAsync(K, SerializableBiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.Cache
computeAsync(K, SerializableBiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
computeAsync(K, SerializableBiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
computeAsync(K, SerializableBiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeEntryRemoved(int, K, InternalCacheEntry<K, V>) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
computeEntryRemoved(K, InternalCacheEntry<K, V>) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
This method is invoked every time an entry is removed inside a compute block
computeEntryRemoved(K, InternalCacheEntry<K, V>) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
computeEntryWritten(int, K, InternalCacheEntry<K, V>) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
computeEntryWritten(K, InternalCacheEntry<K, V>) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
This method is invoked every time an entry is written inside a compute block
computeEntryWritten(K, InternalCacheEntry<K, V>) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
computeGroup(T, Object) - Method in interface org.infinispan.distribution.group.Grouper
Compute the group for a given key
computeGroup(T, String) - Method in interface org.infinispan.distribution.group.Grouper
Deprecated, for removal: This API element is subject to removal in a future version.
Since 9.1
computeIfAbsent(Supplier<T>) - Method in class org.infinispan.commons.configuration.attributes.Attribute
 
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in interface org.infinispan.Cache
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
 
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfAbsent(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfAbsent(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfAbsent(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeIfAbsent(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfAbsent(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
computeIfAbsent(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.commons.api.BasicCache
An overloaded form of ConcurrentMap.computeIfAbsent(Object, Function) which takes in lifespan parameters.
computeIfAbsent(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfAbsent(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfAbsent(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfAbsent(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeIfAbsent(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfAbsent(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
computeIfAbsent(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.BasicCache
An overloaded form of ConcurrentMap.computeIfAbsent(Object, Function) which takes in lifespan and maxIdleTime parameters.
computeIfAbsent(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfAbsent(K, Function<? super K, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
An overloaded form of
invalid reference
#computeIfAbsent(K, Function)
, which takes in an instance of Metadata which can be used to provide metadata information for the entry being stored, such as lifespan, version of value...etc.
computeIfAbsent(K, Function<? super K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeIfAbsent(K, Function<? super K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfAbsent(K, Function<? super K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
 
computeIfAbsent(K, Function<? super K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeIfAbsent(K, Function<? super K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfAbsent(K, Function<? super K, ? extends V>, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfAbsent(K, SerializableFunction<? super K, ? extends V>) - Method in interface org.infinispan.Cache
computeIfAbsent(K, SerializableFunction<? super K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.Cache
computeIfAbsent(K, SerializableFunction<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
computeIfAbsent(K, SerializableFunction<? super K, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
computeIfAbsent(K, SerializableFunction<? super K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>) - Method in interface org.infinispan.commons.api.AsyncCache
computeIfAbsentAsync(K, Function<? super K, ? extends V>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
Overloaded
invalid reference
#computeIfAbsentAsync(K, Function)
, which takes in an instance of Metadata which can be used to provide metadata information for the entry being stored, such as lifespan, version of value...etc.
computeIfAbsentAsync(K, Function<? super K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfAbsentAsync(K, Function<? super K, ? extends V>, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfAbsentAsync(K, SerializableFunction<? super K, ? extends V>) - Method in interface org.infinispan.Cache
computeIfAbsentAsync(K, SerializableFunction<? super K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.Cache
computeIfAbsentAsync(K, SerializableFunction<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
computeIfAbsentAsync(K, SerializableFunction<? super K, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
computeIfAbsentAsync(K, SerializableFunction<? super K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeIfAbsentInternal(K, Function<? super K, ? extends V>, ByRef<V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfAbsentInternal(K, Function<? super K, ? extends V>, ByRef<V>) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in interface org.infinispan.Cache
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.commons.api.BasicCache
An overloaded form of ConcurrentMap.computeIfPresent(Object, BiFunction) which takes in lifespan parameters.
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.BasicCache
An overloaded form of ConcurrentMap.computeIfPresent(Object, BiFunction) which takes in lifespan and maxIdleTime parameters.
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
An overloaded form of
invalid reference
#computeIfPresent(K, BiFunction)
, which takes in an instance of Metadata which can be used to provide metadata information for the entry being stored, such as lifespan, version of value...etc.
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfPresent(K, SerializableBiFunction<? super K, ? super V, ? extends V>) - Method in interface org.infinispan.Cache
Overloaded Cache.computeIfPresent(Object, BiFunction) with Infinispan SerializableBiFunction The compiler will pick this overload for lambda parameters, making them Serializable
computeIfPresent(K, SerializableBiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
computeIfPresent(K, SerializableBiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in interface org.infinispan.commons.api.AsyncCache
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
Overloaded
invalid reference
#computeIfPresentAsync(K, BiFunction)
, which takes in an instance of Metadata which can be used to provide metadata information for the entry being stored, such as lifespan, version of value...etc.
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
computeIfPresentAsync(K, SerializableBiFunction<? super K, ? super V, ? extends V>) - Method in interface org.infinispan.Cache
Overloaded AsyncCache.computeIfPresentAsync(Object, BiFunction) with Infinispan SerializableBiFunction The compiler will pick this overload for lambda parameters, making them Serializable
computeIfPresentAsync(K, SerializableBiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
computeIfPresentAsync(K, SerializableBiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
 
computeIfPresentInternal(K, BiFunction<? super K, ? super V, ? extends V>, SimpleCacheImpl.CacheEntryChange<K, V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeIfPresentInternal(K, BiFunction<? super K, ? super V, ? extends V>, SimpleCacheImpl.CacheEntryChange<K, V>) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
computeIndexInfos() - Method in class org.infinispan.query.stats.impl.LocalIndexStatistics
 
computeInternal(K, BiFunction<? super K, ? super V, ? extends V>, SimpleCacheImpl.CacheEntryChange<K, V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
computeInternal(K, BiFunction<? super K, ? super V, ? extends V>, SimpleCacheImpl.CacheEntryChange<K, V>) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
computeLegacyIndexStatistics() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
computeOrphan(Collection<Address>) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
Check's if this transaction's originator is no longer part of the cluster (orphan transaction) and updates RecoveryAwareRemoteTransaction.isOrphan().
computePreferredTopology(Map<Address, CacheStatusResponse>) - Method in class org.infinispan.partitionhandling.impl.PreferAvailabilityStrategy
Ignore the AvailabilityStrategyContext and only compute the preferred topology for testing.
computeSnapshot() - Method in class org.infinispan.query.stats.impl.LocalIndexStatistics
 
computeTotalCapacity(Collection<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
concat(byte[], byte[]) - Static method in class org.infinispan.commons.util.Util
 
ConcatIterator<E> - Class in org.infinispan.commons.util
Iterator that concatenates a bunch of iterables into 1 big iterator.
ConcatIterator(Iterable<? extends Iterable<E>>) - Constructor for class org.infinispan.commons.util.ConcatIterator
 
CONCURRENCY_LEVEL - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
CONCURRENCY_LEVEL - Enum constant in enum org.infinispan.counter.configuration.Attribute
 
CONCURRENCY_LEVEL - Static variable in class org.infinispan.configuration.cache.LockingConfiguration
 
concurrencyLevel() - Method in class org.infinispan.configuration.cache.LockingConfiguration
Concurrency level for lock containers.
concurrencyLevel() - Method in class org.infinispan.counter.api.CounterConfiguration
 
concurrencyLevel() - Method in class org.infinispan.counter.configuration.WeakCounterConfiguration
 
concurrencyLevel(int) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
Concurrency level for lock containers.
concurrencyLevel(int) - Method in class org.infinispan.counter.api.CounterConfiguration.Builder
Sets the concurrency level of the counter.
concurrencyLevel(int) - Method in class org.infinispan.counter.configuration.WeakCounterConfigurationBuilder
Sets the counter's concurrency level.
concurrentCopyFrom(IntSet, int) - Static method in class org.infinispan.commons.util.IntSets
Returns a copy of the given set that supports concurrent operations.
ConcurrentGlobalContainer - Class in org.infinispan.extendedstats.container
Thread safe cache statistics that allows multiple writers and reader at the same time.
ConcurrentGlobalContainer(TimeService) - Constructor for class org.infinispan.extendedstats.container.ConcurrentGlobalContainer
 
concurrentReindexingOnGetStatistics(Throwable) - Method in interface org.infinispan.query.logging.Log
 
concurrentSet(int) - Static method in class org.infinispan.commons.util.IntSets
Returns a concurrent mutable IntSet that can store values in the range of 0..maxExclusive-1
CONDITIONAL_MARK_ROLLBACK_FUNCTION - Static variable in class org.infinispan.server.core.ExternalizerIds
 
ConditionalMarkAsRollbackFunction - Class in org.infinispan.server.hotrod.tx.table.functions
It updates the TxState's status to Status.MARK_ROLLBACK if the current status is the expected.
ConditionalMarkAsRollbackFunction(Status) - Constructor for class org.infinispan.server.hotrod.tx.table.functions.ConditionalMarkAsRollbackFunction
 
ConditionFuture<T> - Class in org.infinispan.util.concurrent
A mixture between a CompletableFuture and a Condition.
ConditionFuture(ScheduledExecutorService) - Constructor for class org.infinispan.util.concurrent.ConditionFuture
 
config - Variable in class org.infinispan.cache.impl.CacheImpl
 
config - Variable in class org.infinispan.cache.impl.InvocationHelper
 
config - Variable in class org.infinispan.context.impl.AbstractInvocationContextFactory
 
config - Variable in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
 
config - Variable in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.ProtoSchemaOptions
 
CONFIG - Static variable in interface org.infinispan.persistence.jdbc.common.logging.Log
 
CONFIG - Static variable in interface org.infinispan.persistence.remote.logging.Log
 
CONFIG_STATE_CACHE_NAME - Static variable in interface org.infinispan.globalstate.GlobalConfigurationManager
 
configToParsedConfig(String, CounterConfiguration) - Static method in class org.infinispan.counter.configuration.ConvertUtil
 
ConfigurableBufferSizeKeywordTokenizerFactory(Map<String, String>) - Constructor for class org.infinispan.search.mapper.mapping.impl.DefaultAnalysisConfigurer.ConfigurableBufferSizeKeywordTokenizerFactory
 
configuration - Variable in class org.infinispan.client.hotrod.counter.impl.BaseCounter
 
configuration - Variable in class org.infinispan.container.impl.AbstractInternalDataContainer
 
configuration - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
configuration - Variable in class org.infinispan.factories.AbstractNamedCacheComponentFactory
 
configuration - Variable in class org.infinispan.persistence.rocksdb.RocksDBStore
 
configuration - Variable in class org.infinispan.remoting.transport.AbstractTransport
Deprecated.
 
configuration - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
configuration - Variable in class org.infinispan.rest.RestRequestHandler
 
configuration - Variable in class org.infinispan.server.core.AbstractProtocolServer
 
configuration - Variable in class org.infinispan.transaction.impl.TransactionTable
 
configuration() - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
 
configuration() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
configuration(String) - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfigurationBuilder
Specifies the declarative configuration to be used to create the cache if it doesn't already exist on the server.
configuration(String) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
Configuration - Class in org.infinispan.client.hotrod.configuration
Configuration.
Configuration - Class in org.infinispan.configuration.cache
 
Configuration(ExecutorFactoryConfiguration, Supplier<FailoverRequestBalancingStrategy>, ClassLoader, ClientIntelligence, ConnectionPoolConfiguration, int, Class<? extends ConsistentHash>[], int, int, int, boolean, int, Marshaller, Class<? extends Marshaller>, ProtocolVersion, List<ServerConfiguration>, int, SecurityConfiguration, boolean, boolean, int, int, NearCacheConfiguration, List<ClusterConfiguration>, List<String>, int, TransactionConfiguration, StatisticsConfiguration, Features, List<SerializationContextInitializer>, Map<String, RemoteCacheConfiguration>, TransportFactory, boolean) - Constructor for class org.infinispan.client.hotrod.configuration.Configuration
 
CONFIGURATION - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
CONFIGURATION - Static variable in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
 
CONFIGURATION - Static variable in class org.infinispan.configuration.cache.Configuration
 
CONFIGURATION_CHANGED - Enum constant in enum org.infinispan.notifications.cachemanagerlistener.event.Event.Type
 
CONFIGURATION_FILE - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
CONFIGURATION_STRING - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
CONFIGURATION_XML - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
ConfigurationBuilder - Class in org.infinispan.client.hotrod.configuration
ConfigurationBuilder used to generate immutable Configuration objects to pass to the RemoteCacheManager(Configuration) constructor.
ConfigurationBuilder - Class in org.infinispan.configuration.cache
 
ConfigurationBuilder() - Constructor for class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
ConfigurationBuilder() - Constructor for class org.infinispan.configuration.cache.ConfigurationBuilder
 
ConfigurationBuilderHolder - Class in org.infinispan.configuration.parsing
 
ConfigurationBuilderHolder() - Constructor for class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
ConfigurationBuilderHolder(ClassLoader) - Constructor for class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
ConfigurationBuilderHolder(ClassLoader, GlobalConfigurationBuilder) - Constructor for class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
ConfigurationChanged - Annotation Type in org.infinispan.notifications.cachemanagerlistener.annotation
This annotation should be used on methods that need to be notified when a configuration is changed.
ConfigurationChangedEvent - Interface in org.infinispan.notifications.cachemanagerlistener.event
This event is passed in to any method annotated with ConfigurationChanged.
ConfigurationChangedEvent.EventType - Enum in org.infinispan.notifications.cachemanagerlistener.event
 
ConfigurationChildBuilder - Interface in org.infinispan.client.hotrod.configuration
ConfigurationChildBuilder.
ConfigurationChildBuilder - Interface in org.infinispan.configuration.cache
 
ConfigurationElement<T> - Class in org.infinispan.commons.configuration.attributes
An abstract class which represents a configuration element, with attributes and child elements.
ConfigurationElement(Enum<?>, AttributeSet, ConfigurationElement<?>...) - Constructor for class org.infinispan.commons.configuration.attributes.ConfigurationElement
 
ConfigurationElement(String, boolean, AttributeSet, ConfigurationElement<?>...) - Constructor for class org.infinispan.commons.configuration.attributes.ConfigurationElement
 
ConfigurationElement(String, AttributeSet, ConfigurationElement<?>...) - Constructor for class org.infinispan.commons.configuration.attributes.ConfigurationElement
 
ConfigurationFor - Annotation Type in org.infinispan.commons.configuration
ConfigurationFor.
ConfigurationFormatFeature - Enum in org.infinispan.commons.configuration.io
 
ConfigurationHolder - Class in org.infinispan.configuration.serializing
ConfigurationHolder.
ConfigurationHolder(GlobalConfiguration, Map<String, Configuration>) - Constructor for class org.infinispan.configuration.serializing.ConfigurationHolder
 
ConfigurationListener(EmbeddedCacheManager, MediaType, boolean, boolean) - Constructor for class org.infinispan.rest.resources.ContainerResource.ConfigurationListener
 
configurationManager - Variable in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
 
ConfigurationManager - Class in org.infinispan.configuration
It manages all the configuration for a specific container.
ConfigurationManager(GlobalConfiguration) - Constructor for class org.infinispan.configuration.ConfigurationManager
 
ConfigurationManager(ConfigurationBuilderHolder) - Constructor for class org.infinispan.configuration.ConfigurationManager
 
configurationMustContainSingleCache(String, String) - Method in interface org.infinispan.server.core.logging.Log
 
configurationNotClustered() - Method in interface org.infinispan.lock.logging.Log
 
ConfigurationParser - Interface in org.infinispan.configuration.parsing
ConfigurationParser.
ConfigurationParserListener - Interface in org.infinispan.configuration.parsing
ConfigurationParserListener.
configurationProperties() - Method in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
 
ConfigurationProperties - Class in org.infinispan.client.hotrod.impl
Encapsulate all config properties here
ConfigurationProperties() - Constructor for class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
ConfigurationProperties(String) - Constructor for class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
ConfigurationProperties(Properties) - Constructor for class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
ConfigurationPropertiesOverrides - Class in org.infinispan.spring.remote
Provides a mechanism to override selected configuration properties using explicit setters for each configuration setting.
ConfigurationPropertiesOverrides() - Constructor for class org.infinispan.spring.remote.ConfigurationPropertiesOverrides
 
ConfigurationReader - Interface in org.infinispan.commons.configuration.io
 
ConfigurationReader.Builder - Class in org.infinispan.commons.configuration.io
 
ConfigurationReader.ElementType - Enum in org.infinispan.commons.configuration.io
 
ConfigurationReaderContext - Interface in org.infinispan.commons.configuration.io
 
ConfigurationReaderException - Exception Class in org.infinispan.commons.configuration.io
 
ConfigurationReaderException(String, Location) - Constructor for exception class org.infinispan.commons.configuration.io.ConfigurationReaderException
 
ConfigurationReaderException(Throwable, Location) - Constructor for exception class org.infinispan.commons.configuration.io.ConfigurationReaderException
 
ConfigurationResourceResolver - Interface in org.infinispan.commons.configuration.io
 
ConfigurationResourceResolvers - Class in org.infinispan.commons.configuration.io
 
Configurations - Class in org.infinispan.configuration.cache
Helper configuration methods.
ConfigurationSchemaVersion - Interface in org.infinispan.commons.configuration.io
 
ConfigurationSerializer<T> - Interface in org.infinispan.configuration.serializing
 
configurationStorage() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
 
configurationStorage() - Method in class org.infinispan.configuration.global.GlobalStorageConfiguration
 
configurationStorage(ConfigurationStorage) - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
Defines the ConfigurationStorage strategy to use.
configurationStorage(ConfigurationStorage) - Method in class org.infinispan.configuration.global.GlobalStorageConfigurationBuilder
 
ConfigurationStorage - Enum in org.infinispan.globalstate
Configuration storage
configurationStorageClass() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
configurationStorageSupplier(Supplier<? extends LocalConfigurationStorage>) - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
configurationURI(URI) - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfigurationBuilder
Specifies a URI pointing to the declarative configuration to be used to create the cache if it doesn't already exist on the server.
ConfigurationUtils - Class in org.infinispan.commons.configuration
ConfigurationUtils.
ConfigurationWriter - Interface in org.infinispan.commons.configuration.io
 
ConfigurationWriter.Builder - Class in org.infinispan.commons.configuration.io
 
ConfigurationWriterException - Exception Class in org.infinispan.commons.configuration.io
 
ConfigurationWriterException(String) - Constructor for exception class org.infinispan.commons.configuration.io.ConfigurationWriterException
 
ConfigurationWriterException(Throwable) - Constructor for exception class org.infinispan.commons.configuration.io.ConfigurationWriterException
 
configurator() - Method in interface org.infinispan.configuration.global.NamedStackConfiguration
 
configurator() - Method in class org.infinispan.configuration.global.StackConfiguration
 
configurator() - Method in class org.infinispan.configuration.global.StackFileConfiguration
 
configurator(String) - Method in class org.infinispan.configuration.global.JGroupsConfiguration
 
configure(LuceneAnalysisConfigurationContext) - Method in class org.infinispan.search.mapper.mapping.impl.CompositeAnalysisConfigurer
 
configure(LuceneAnalysisConfigurationContext) - Method in class org.infinispan.search.mapper.mapping.impl.DefaultAnalysisConfigurer
 
configure(MappingBuildContext, MappingConfigurationCollector<PojoTypeMetadataContributor>) - Method in class org.infinispan.search.mapper.impl.InfinispanMappingInitiator
 
configure(MappingConfigurationContext) - Method in interface org.infinispan.search.mapper.mapping.ProgrammaticSearchMappingProvider
Configure the Hibernate Search mapping as necessary using the given context.
ConfiguredBy - Annotation Type in org.infinispan.commons.configuration
Defines the configuration used to configure the given class instances
configurePipeline(ChannelHandlerContext, String) - Method in class org.infinispan.rest.ALPNHandler
 
configurePipeline(ChannelPipeline, String, RestServer, Map<String, ProtocolServer<?>>) - Static method in class org.infinispan.rest.ALPNHandler
 
confirmRebalancePhase(String, int, int, Throwable) - Method in interface org.infinispan.topology.LocalTopologyManager
Confirm that the local cache cacheName has finished receiving the new data for topology topologyId.
confirmRebalancePhase(String, int, int, Throwable) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
confirmRebalancePhase(Address, int) - Method in class org.infinispan.topology.ClusterCacheStatus
 
confirmRevokedSegments(int) - Method in class org.infinispan.scattered.impl.ScatteredStateProviderImpl
 
confirmRevokedSegments(int) - Method in interface org.infinispan.scattered.ScatteredStateProvider
Confirm that this node has received cache topology with given topologyId and that it has moved all the segments it does not own according to consistent hash to the ScatteredVersionManager.SegmentState.NOT_OWNED state.
confirmStateTransfer(Address, boolean) - Method in class org.infinispan.xsite.statetransfer.RemoteSiteStatus
 
confirmStateTransfer(Address, boolean) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferCollector
 
CONFLICT_RESOLUTION - Enum constant in enum org.infinispan.topology.CacheTopology.Phase
Interim state between NO_REBALANCE → READ_OLD_WRITE_ALL readCh is set locally using previous Topology (of said node) readCH, whilst writeCH contains all members after merge
CONFLICTING - Enum constant in enum org.infinispan.container.versioning.InequalVersionComparisonResult
Denotes a version that was created at the same time as another version, but is not equal.
ConflictManager<K,V> - Interface in org.infinispan.conflict
 
ConflictManagerFactory - Class in org.infinispan.conflict
A ConflictManager factory for cache instances.
ConflictManagerFactory() - Constructor for class org.infinispan.conflict.ConflictManagerFactory
 
connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class org.infinispan.server.core.transport.SaslQopHandler
 
CONNECT_TIMEOUT - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
 
CONNECT_TIMEOUT - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
connectChannel - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
connection - Variable in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations.FlowableConnection
 
CONNECTION_ATTEMPTS - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
CONNECTION_ATTEMPTS - Static variable in class org.infinispan.configuration.cache.PersistenceConfiguration
 
CONNECTION_INTERVAL - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
CONNECTION_INTERVAL - Static variable in class org.infinispan.configuration.cache.PersistenceConfiguration
 
CONNECTION_POOL - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
 
CONNECTION_POOL - Enum constant in enum org.infinispan.persistence.remote.configuration.Element
 
CONNECTION_POOL_EXHAUSTED_ACTION - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
CONNECTION_POOL_MAX_ACTIVE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
CONNECTION_POOL_MAX_PENDING_REQUESTS - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
CONNECTION_POOL_MAX_WAIT - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
CONNECTION_POOL_MIN_EVICTABLE_IDLE_TIME - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
CONNECTION_POOL_MIN_IDLE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
CONNECTION_URL - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
 
CONNECTION_URL - Static variable in class org.infinispan.persistence.jdbc.common.configuration.AbstractUnmanagedConnectionFactoryConfiguration
 
connectionAttempts() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
 
connectionAttempts(int) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
connectionClosed(SocketAddress, SocketAddress) - Method in interface org.infinispan.client.hotrod.logging.Log
 
connectionCloser - Variable in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations.FlowableConnection
 
connectionFactory - Variable in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
 
connectionFactory - Variable in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
 
connectionFactory() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfiguration
 
connectionFactory(C) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
Use the specified ConnectionFactoryConfigurationBuilder to configure connections to the database
connectionFactory(C) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationChildBuilder
 
connectionFactory(C) - Method in interface org.infinispan.persistence.jdbc.common.configuration.JdbcStoreConfigurationChildBuilder
Use the specified ConnectionFactoryConfigurationBuilder to configure connections to the database
connectionFactory(Class<C>) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
Use the specified ConnectionFactory to handle connection to the database
connectionFactory(Class<C>) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationChildBuilder
 
connectionFactory(Class<C>) - Method in interface org.infinispan.persistence.jdbc.common.configuration.JdbcStoreConfigurationChildBuilder
Use the specified ConnectionFactory to handle connection to the database
ConnectionFactory - Class in org.infinispan.persistence.jdbc.common.connectionfactory
Defines the functionality a connection factory should implement.
ConnectionFactory() - Constructor for class org.infinispan.persistence.jdbc.common.connectionfactory.ConnectionFactory
 
connectionFactoryClass() - Method in interface org.infinispan.persistence.jdbc.common.configuration.ConnectionFactoryConfiguration
 
connectionFactoryClass() - Method in class org.infinispan.persistence.jdbc.common.configuration.ManagedConnectionFactoryConfiguration
 
connectionFactoryClass() - Method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfiguration
 
connectionFactoryClass() - Method in class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfiguration
 
ConnectionFactoryConfiguration - Interface in org.infinispan.persistence.jdbc.common.configuration
ConnectionFactoryConfiguration.
ConnectionFactoryConfigurationBuilder<T> - Interface in org.infinispan.persistence.jdbc.common.configuration
 
connectionInJndiNotFound(String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
 
connectionInterval() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
 
connectionInterval(int) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
connectionPool() - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
connectionPool() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
connectionPool() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
connectionPool() - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Configures the connection pool
connectionPool() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
 
connectionPool() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationChildBuilder
 
connectionPool() - Method in interface org.infinispan.persistence.jdbc.common.configuration.JdbcStoreConfigurationChildBuilder
Configures a connection pool to be used by this JDBC Cache Store to handle connections to the database
connectionPool() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder.StringTableManipulationConfigurationBuilder
 
connectionPool() - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
connectionPool() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
connectionPool() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
connectionPool() - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
Configures the connection pool
ConnectionPoolConfiguration - Class in org.infinispan.client.hotrod.configuration
ConnectionPoolConfiguration.
ConnectionPoolConfiguration - Class in org.infinispan.persistence.remote.configuration
 
ConnectionPoolConfigurationBuilder - Class in org.infinispan.client.hotrod.configuration
ConnectionPoolConfigurationBuilder.
ConnectionPoolConfigurationBuilder - Class in org.infinispan.persistence.remote.configuration
ConnectionPoolConfigurationBuilder.
connectionTimeout() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
connectionTimeout() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
connectionTimeout(int) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
connectionTimeout(int) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
connectionTimeout(int) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
This property defines the maximum socket connect timeout in milliseconds before giving up connecting to the server.
connectionTimeout(long) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
connectionTimeout(long) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
connectionTimeout(long) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
This property defines the maximum socket connect timeout before giving up connecting to the server.
connectionUrl() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractUnmanagedConnectionFactoryConfiguration
 
connectionUrl(String) - Method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfigurationBuilder
 
connectionUrl(String) - Method in class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfigurationBuilder
 
connectorMatchesRequest(String) - Method in class org.infinispan.rest.logging.Messages_$bundle
 
connectorMatchesRequest(String) - Method in interface org.infinispan.rest.logging.Messages
 
connectorMatchesRequest$str() - Method in class org.infinispan.rest.logging.Messages_$bundle
 
connectorStart(String) - Method in interface org.infinispan.server.core.ServerStateManager
 
connectorStatus(String) - Method in interface org.infinispan.server.core.ServerStateManager
 
connectorStop(String) - Method in interface org.infinispan.server.core.ServerStateManager
 
connectSource(String, StoreConfiguration) - Method in class org.infinispan.upgrade.RollingUpgradeManager
 
connectSource(Cache<Object, Object>, StoreConfiguration) - Method in class org.infinispan.persistence.remote.upgrade.HotRodTargetMigrator
 
connectSource(Cache<Object, Object>, StoreConfiguration) - Method in interface org.infinispan.upgrade.TargetMigrator
Connects the target cluster to the source cluster through a Remote Store.
CONSISTENT - Enum constant in enum org.infinispan.counter.configuration.Reliability
If the cluster splits in multiple partitions, the majority partition is allowed to read/update the counter if the counter is available on that partition.
CONSISTENT - Enum constant in enum org.infinispan.lock.configuration.Reliability
 
CONSISTENT_HASH_FACTORY - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
CONSISTENT_HASH_FACTORY - Static variable in class org.infinispan.configuration.cache.HashConfiguration
 
ConsistentHash - Interface in org.infinispan.distribution.ch
A consistent hash algorithm implementation.
consistentHashFactory() - Method in class org.infinispan.configuration.cache.HashConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
Since 11.0. Will be removed in 14.0, the segment allocation will no longer be customizable.
consistentHashFactory(ConsistentHashFactory<? extends ConsistentHash>) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 11.0. Will be removed in 14.0, the segment allocation will no longer be customizable.
ConsistentHashFactory<CH> - Interface in org.infinispan.distribution.ch
Deprecated, for removal: This API element is subject to removal in a future version.
Since 11.0. Will be removed in 14.0, the segment allocation will no longer be customizable.
consistentHashImpl() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
consistentHashImpl(int) - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
consistentHashImpl(int, Class<? extends ConsistentHash>) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
consistentHashImpl(int, Class<? extends ConsistentHash>) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
consistentHashImpl(int, Class<? extends ConsistentHash>) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Defines the ConsistentHash implementation to use for the specified version.
consistentHashImpl(int, String) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
consistentHashImpl(int, String) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
consistentHashImpl(int, String) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Defines the ConsistentHash implementation to use for the specified version.
ConsistentHashPersistenceConstants - Class in org.infinispan.distribution.ch.impl
Constants used as keys within a persisted consistent hash
ConsistentHashPersistenceConstants() - Constructor for class org.infinispan.distribution.ch.impl.ConsistentHashPersistenceConstants
 
ConstantLambdaExternalizer() - Constructor for class org.infinispan.marshall.core.MarshallableFunctionExternalizers.ConstantLambdaExternalizer
 
Constants - Class in org.infinispan.server.hotrod
Constant values
Constants - Interface in org.infinispan.metrics
Various public constant names, used by Infinispan's metrics support.
construct(Class<T>) - Method in class org.infinispan.factories.AnyScopeComponentFactory
Deprecated, for removal: This API element is subject to removal in a future version.
Since 9.4, please override ComponentFactory.construct(String) instead.
construct(Class<T>, String) - Method in class org.infinispan.factories.NamedComponentFactory
Deprecated.
Constructs a component.
construct(String) - Method in class org.infinispan.distribution.ch.impl.KeyPartitionerFactory
 
construct(String) - Method in class org.infinispan.distribution.group.impl.GroupManagerFactory
 
construct(String) - Method in class org.infinispan.factories.AnyScopeComponentFactory
 
construct(String) - Method in class org.infinispan.factories.AuthorizationManagerFactory
 
construct(String) - Method in class org.infinispan.factories.ClusteringDependentLogicFactory
 
construct(String) - Method in interface org.infinispan.factories.ComponentFactory
 
construct(String) - Method in class org.infinispan.factories.DataContainerFactory
 
construct(String) - Method in class org.infinispan.factories.DistributionManagerFactory
 
construct(String) - Method in class org.infinispan.factories.EmptyConstructorFactory
 
construct(String) - Method in class org.infinispan.factories.EmptyConstructorNamedCacheFactory
 
construct(String) - Method in class org.infinispan.factories.EncoderRegistryFactory
 
construct(String) - Method in class org.infinispan.factories.EntryMetaFactory
 
construct(String) - Method in class org.infinispan.factories.ExpirationManagerFactory
 
construct(String) - Method in class org.infinispan.factories.InboundInvocationHandlerFactory
 
construct(String) - Method in class org.infinispan.factories.InterceptorChainFactory
 
construct(String) - Method in class org.infinispan.factories.LockContainerFactory
 
construct(String) - Method in class org.infinispan.factories.LockManagerFactory
 
construct(String) - Method in class org.infinispan.factories.MarshallerFactory
 
construct(String) - Method in class org.infinispan.factories.NamedComponentFactory
Deprecated.
 
construct(String) - Method in class org.infinispan.factories.NamedExecutorsFactory
 
construct(String) - Method in class org.infinispan.factories.PartitionHandlingManagerFactory
 
construct(String) - Method in class org.infinispan.factories.PublisherManagerFactory
 
construct(String) - Method in class org.infinispan.factories.RecoveryManagerFactory
 
construct(String) - Method in class org.infinispan.factories.ResponseGeneratorFactory
 
construct(String) - Method in class org.infinispan.factories.RpcManagerFactory
 
construct(String) - Method in class org.infinispan.factories.SizeCalculatorFactory
 
construct(String) - Method in class org.infinispan.factories.StateTransferComponentFactory
 
construct(String) - Method in class org.infinispan.factories.TransactionManagerFactory
 
construct(String) - Method in class org.infinispan.factories.TransactionSynchronizationRegistryFactory
 
construct(String) - Method in class org.infinispan.factories.TransactionTableFactory
 
construct(String) - Method in class org.infinispan.factories.TransportFactory
 
construct(String) - Method in class org.infinispan.factories.VersionGeneratorFactory
 
construct(String) - Method in class org.infinispan.factories.XSiteEntryMergePolicyFactory
 
construct(String) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEventManagerFactory
 
construct(String) - Method in class org.infinispan.security.impl.GlobalSecurityManagerFactory
 
construct(String) - Method in class org.infinispan.server.core.factories.NettyEventLoopFactory
 
construct(String) - Method in class org.infinispan.server.core.factories.NettyIOFactory
 
construct(String) - Method in class org.infinispan.server.core.telemetry.TelemetryServiceFactory
 
construct(String) - Method in class org.infinispan.stats.impl.StatsCollector.Factory
 
construct(String) - Method in class org.infinispan.topology.ClusterTopologyManagerFactory
 
construct(String) - Method in class org.infinispan.topology.LocalTopologyManagerFactory
 
Constructing a Cache - Search tag in interface org.infinispan.Cache
Section
Constructing and Modifying JSON Structures - Search tag in class org.infinispan.commons.dataconversion.internal.Json
Section
consumer - Variable in class org.infinispan.commons.util.RemovableIterator
 
CONTAINER - Static variable in interface org.infinispan.counter.logging.Log
 
CONTAINER - Static variable in interface org.infinispan.query.logging.Log
 
ContainerEmbeddedCacheManagerFactoryBean - Class in org.infinispan.spring.embedded.provider
FactoryBean for creating a CacheManager for a pre-defined CacheContainer.
ContainerEmbeddedCacheManagerFactoryBean(EmbeddedCacheManager) - Constructor for class org.infinispan.spring.embedded.provider.ContainerEmbeddedCacheManagerFactoryBean
 
ContainerMixedSiteStatus - Class in org.infinispan.xsite.status
A mixed SiteStatus.
ContainerMixedSiteStatus(Collection<String>, Collection<String>, Collection<String>) - Constructor for class org.infinispan.xsite.status.ContainerMixedSiteStatus
 
ContainerRemoteCacheManagerFactoryBean - Class in org.infinispan.spring.remote.provider
FactoryBean for creating a CacheManager for a pre-defined CacheContainer.
ContainerRemoteCacheManagerFactoryBean(RemoteCacheManager) - Constructor for class org.infinispan.spring.remote.provider.ContainerRemoteCacheManagerFactoryBean
 
ContainerResource - Class in org.infinispan.rest.resources
REST resource to manage the cache container.
ContainerResource - Interface in org.infinispan.server.core.backup
An interface that defines how a container resource is backed up and restored by the BackupManager.
ContainerResource(InvocationHelper) - Constructor for class org.infinispan.rest.resources.ContainerResource
 
ContainerResource.ConfigurationListener - Class in org.infinispan.rest.resources
 
ContainerResourceFactory - Class in org.infinispan.server.core.backup.resources
Factory for creating the ContainerResources required for a backup/restore operation.
ContainerResourceFactory() - Constructor for class org.infinispan.server.core.backup.resources.ContainerResourceFactory
 
ContainerSiteStatusBuilder - Class in org.infinispan.xsite.status
A per-container SiteStatus builder.
ContainerSiteStatusBuilder() - Constructor for class org.infinispan.xsite.status.ContainerSiteStatusBuilder
 
ContainerStats - Interface in org.infinispan.stats
 
containerStop() - Method in interface org.infinispan.server.core.ServerManagement
 
containRemoteTx(GlobalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
 
contains(int) - Method in class org.infinispan.commons.util.ImmutableIntSet
Deprecated.
 
contains(int) - Method in interface org.infinispan.commons.util.IntSet
Whether this set contains the given int
contains(int) - Method in class org.infinispan.commons.util.RangeSet
Deprecated.
 
contains(int) - Method in class org.infinispan.commons.util.SmallIntSet
Deprecated.
Check if the set contains an integer without boxing the parameter.
contains(int, Object) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
Deprecated.
Returns true if the storage contains an entry associated with the given key in the given segment
contains(int, Object) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
contains(Integer) - Method in class org.infinispan.commons.util.SmallIntSet
Deprecated.
 
contains(Object) - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
 
contains(Object) - Method in class org.infinispan.cache.impl.CacheBackedEntrySet
 
contains(Object) - Method in class org.infinispan.cache.impl.CacheBackedKeySet
 
contains(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySetBase
 
contains(Object) - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
 
contains(Object) - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
 
contains(Object) - Method in class org.infinispan.commons.util.FastCopyHashMap.EntrySet
 
contains(Object) - Method in class org.infinispan.commons.util.FastCopyHashMap.KeySet
 
contains(Object) - Method in class org.infinispan.commons.util.FastCopyHashMap.Values
 
contains(Object) - Method in class org.infinispan.commons.util.ForwardingList
 
contains(Object) - Method in class org.infinispan.commons.util.ImmutableHopscotchHashSet
 
contains(Object) - Method in class org.infinispan.commons.util.ImmutableIntSet
Deprecated.
 
contains(Object) - Method in class org.infinispan.commons.util.ImmutableListCopy
 
contains(Object) - Method in class org.infinispan.commons.util.RangeSet
Deprecated.
 
contains(Object) - Method in class org.infinispan.commons.util.SmallIntSet
Deprecated.
 
contains(Object) - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
 
contains(Object) - Method in class org.infinispan.InternalCacheSet
 
contains(Object) - Method in class org.infinispan.persistence.cluster.ClusterLoader
Deprecated.
 
contains(Object) - Method in interface org.infinispan.persistence.spi.CacheLoader
Deprecated.
Returns true if the storage contains an entry associated with the given key.
contains(Object) - Method in class org.infinispan.persistence.support.AbstractSegmentedAdvancedLoadWriteStore
 
contains(Object) - Method in class org.infinispan.persistence.support.DelegatingCacheLoader
 
contains(Object) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Deprecated.
Checks that the left argument (which is expected to be an array or a Collection) contains the given element.
contains(Object) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
 
contains(String) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
Returns whether this attribute set contains the specified named attribute
contains(String) - Static method in enum org.infinispan.rest.framework.Method
 
contains(AttributeDefinition<T>) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
Returns whether this set contains the specified attribute definition
contains(IracTombstoneInfo) - Method in class org.infinispan.container.versioning.irac.DefaultIracTombstoneManager
 
contains(V) - Method in class org.infinispan.multimap.impl.Bucket
 
CONTAINS_ENTRY_MULTIMAP - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
CONTAINS_ENTRY_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
CONTAINS_KEY - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
CONTAINS_KEY_MULTIMAP - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
CONTAINS_KEY_MULTIMAP_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
CONTAINS_KEY_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
CONTAINS_KEY_VALUE_FUNCTION - Static variable in interface org.infinispan.multimap.impl.ExternalizerIds
 
CONTAINS_VALUE_MULTIMAP - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
CONTAINS_VALUE_MULTIMAP_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
containsAll(long, long) - Static method in class org.infinispan.commons.util.EnumUtil
 
containsAll(Object...) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Deprecated.
Checks that the left argument (which is expected to be an array or a Collection) contains all of the the given elements, in any order.
containsAll(Collection) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Deprecated.
Checks that the left argument (which is expected to be an array or a Collection) contains all the elements of the given collection, in any order.
containsAll(Collection<?>) - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
 
containsAll(Collection<?>) - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
 
containsAll(Collection<?>) - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
 
containsAll(Collection<?>) - Method in class org.infinispan.commons.util.ForwardingList
 
containsAll(Collection<?>) - Method in class org.infinispan.commons.util.ImmutableHopscotchHashSet
 
containsAll(Collection<?>) - Method in class org.infinispan.commons.util.ImmutableIntSet
Deprecated.
 
containsAll(Collection<?>) - Method in class org.infinispan.commons.util.RangeSet
Deprecated.
 
containsAll(Collection<?>) - Method in class org.infinispan.commons.util.SmallIntSet
Deprecated.
 
containsAll(Collection<?>) - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
 
containsAll(Collection<?>) - Method in class org.infinispan.InternalCacheSet
 
containsAll(Collection<?>) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
 
containsAll(IntSet) - Method in class org.infinispan.commons.util.ImmutableIntSet
Deprecated.
 
containsAll(IntSet) - Method in interface org.infinispan.commons.util.IntSet
Whether this set contains all ints in the given IntSet
containsAll(IntSet) - Method in class org.infinispan.commons.util.RangeSet
Deprecated.
 
containsAll(IntSet) - Method in class org.infinispan.commons.util.SmallIntSet
Deprecated.
 
containsAll(Param<?>...) - Method in class org.infinispan.functional.impl.Params
Checks whether all the parameters passed in are already present in the current parameters.
containsAny(long, long) - Static method in class org.infinispan.commons.util.EnumUtil
 
containsAny(Object...) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Deprecated.
Checks that the left argument (which is expected to be an array or a Collection) contains any of the the given elements.
containsAny(Collection) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Deprecated.
Checks that the left argument (which is expected to be an array or a Collection) contains any of the elements of the given collection.
containsAny(Collection<T>, Collection<T>) - Static method in class org.infinispan.commons.util.InfinispanCollections
 
containsEntry(K, V) - Method in interface org.infinispan.multimap.api.BasicMultimapCache
Returns Boolean.TRUE if this multimap cache contains the key-value pair.
containsEntry(K, V) - Method in class org.infinispan.multimap.impl.EmbeddedMultimapCache
 
containsInstance(AsyncInterceptor) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Checks whether the chain contains the supplied interceptor instance.
containsInstance(AsyncInterceptor) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
containsInterceptorType(Class<? extends AsyncInterceptor>) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Checks whether the chain contains an interceptor with the given class.
containsInterceptorType(Class<? extends AsyncInterceptor>) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
containsInterceptorType(Class<? extends AsyncInterceptor>, boolean) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Checks whether the chain contains an interceptor with the given class, or a subclass.
containsInterceptorType(Class<? extends AsyncInterceptor>, boolean) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
containsKey(int, Object) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
containsKey(int, Object) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
containsKey(int, Object) - Method in interface org.infinispan.container.impl.InternalDataContainer
Same as DataContainer.containsKey(Object) except that the segment of the key can provided to lookup if the entry exists without calculating the segment for the given key.
containsKey(int, Object) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
containsKey(int, Object) - Method in class org.infinispan.persistence.file.SingleFileStore
The base class implementation calls SingleFileStore.load(int, Object) for this, we can do better because we keep all keys in memory.
containsKey(int, Object) - Method in class org.infinispan.persistence.remote.RemoteStore
 
containsKey(int, Object) - Method in class org.infinispan.persistence.rocksdb.RocksDBStore
 
containsKey(int, Object) - Method in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
 
containsKey(int, Object) - Method in interface org.infinispan.persistence.spi.NonBlockingStore
Returns a stage that will contain whether the value can be found in the store.
containsKey(int, Object) - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
 
containsKey(int, Object) - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
 
containsKey(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
containsKey(Object) - Method in class org.infinispan.cache.impl.CacheImpl
 
containsKey(Object) - Method in class org.infinispan.cache.impl.DecoratedCache
 
containsKey(Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
containsKey(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
containsKey(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
containsKey(Object) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
 
containsKey(Object) - Method in class org.infinispan.commons.util.ArrayMap
 
containsKey(Object) - Method in class org.infinispan.commons.util.FastCopyHashMap
 
containsKey(Object) - Method in class org.infinispan.commons.util.WeakValueHashMap
 
containsKey(Object) - Method in interface org.infinispan.container.DataContainer
Tests whether an entry exists in the container
containsKey(Object) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
containsKey(Object) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
containsKey(Object) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
containsKey(Object) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
containsKey(Object) - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
 
containsKey(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
containsKey(Object) - Method in class org.infinispan.xsite.irac.DefaultIracManager
 
containsKey(Object) - Method in interface org.infinispan.xsite.irac.IracManager
Checks if the key is present.
containsKey(Object) - Method in enum org.infinispan.xsite.irac.NoOpIracManager
 
containsKey(K) - Method in interface org.infinispan.multimap.api.BasicMultimapCache
Returns Boolean.TRUE if this multimap cache contains the key.
containsKey(K) - Method in class org.infinispan.multimap.impl.EmbeddedMultimapCache
 
containsKeyAsync(K) - Method in class org.infinispan.cache.impl.EncoderCache
 
containsKeyAsync(K) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
containsKeyAsync(K) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
containsKeyAsync(K) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
containsKeyAsync(K) - Method in interface org.infinispan.commons.api.AsyncCache
Asynchronous version of Map.containsKey(Object)
containsLocalTx(GlobalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
 
containsLockOwner(Object) - Method in class org.infinispan.util.concurrent.locks.impl.InfinispanLock
It tests if the lock has the lock owner.
containsProperty(String) - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
 
containsProperty(String) - Method in interface org.infinispan.globalstate.ScopedPersistentState
Returns whether the state contains a property
containsRole(String) - Method in class org.infinispan.security.impl.SubjectACL
 
containsValue(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
containsValue(Object) - Method in class org.infinispan.cache.impl.CacheImpl
 
containsValue(Object) - Method in class org.infinispan.cache.impl.DecoratedCache
 
containsValue(Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
containsValue(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
containsValue(Object) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
containsValue(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
containsValue(Object) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
 
containsValue(Object) - Method in class org.infinispan.commons.util.ArrayMap
 
containsValue(Object) - Method in class org.infinispan.commons.util.FastCopyHashMap
 
containsValue(Object) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
containsValue(Object) - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
 
containsValue(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
containsValue(V) - Method in interface org.infinispan.multimap.api.BasicMultimapCache
Asynchronous method that returns Boolean.TRUE if this multimap cache contains the value at any key.
containsValue(V) - Method in class org.infinispan.multimap.impl.EmbeddedMultimapCache
 
content() - Method in class org.infinispan.rest.ServerSentEvent
 
CONTENT_ENCODING_HEADER - Enum constant in enum org.infinispan.rest.RequestHeader
 
CONTENT_LENGTH_HEADER - Enum constant in enum org.infinispan.rest.ResponseHeader
 
CONTENT_TYPE_HEADER - Enum constant in enum org.infinispan.rest.RequestHeader
 
CONTENT_TYPE_HEADER - Enum constant in enum org.infinispan.rest.ResponseHeader
 
contentLength(long) - Method in interface org.infinispan.rest.framework.impl.RestResponseBuilder
 
contentLength(long) - Method in class org.infinispan.rest.framework.impl.SimpleRestResponse.Builder
 
contentLength(long) - Method in class org.infinispan.rest.NettyRestResponse.Builder
 
contents() - Method in interface org.infinispan.rest.framework.RestRequest
 
contents() - Method in class org.infinispan.rest.NettyRestRequest
 
ContentSource - Interface in org.infinispan.rest.framework
 
contentType() - Method in interface org.infinispan.rest.framework.RestRequest
 
contentType() - Method in class org.infinispan.rest.NettyRestRequest
 
contentType(String) - Method in interface org.infinispan.rest.framework.impl.RestResponseBuilder
 
contentType(String) - Method in class org.infinispan.rest.framework.impl.SimpleRestResponse.Builder
 
contentType(String) - Method in class org.infinispan.rest.NettyRestResponse.Builder
 
contentType(MediaType) - Method in interface org.infinispan.rest.framework.impl.RestResponseBuilder
 
contentType(MediaType) - Method in class org.infinispan.rest.framework.impl.SimpleRestResponse.Builder
 
contentType(MediaType) - Method in class org.infinispan.rest.NettyRestResponse.Builder
 
ContentTypeConfiguration - Class in org.infinispan.configuration.cache
 
ContentTypeConfigurationBuilder - Class in org.infinispan.configuration.cache
 
ContentTypeConfigurationBuilder(Enum<?>, EncodingConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
 
CONTEXT_INITIALIZER - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
CONTEXT_INITIALIZERS - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
CONTEXT_INITIALIZERS - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
CONTEXT_PATH - Static variable in class org.infinispan.rest.configuration.RestServerConfiguration
 
ContextBuilder - Interface in org.infinispan.cache.impl
An interface to build InvocationContext.
contextInitializers() - Method in class org.infinispan.configuration.global.SerializationConfiguration
 
contextPath() - Method in class org.infinispan.rest.configuration.RestServerConfiguration
 
contextPath(String) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
 
continueOnNonBlockingThread(CompletionStage<V>, Object) - Method in interface org.infinispan.util.concurrent.BlockingManager
When the provided stage is complete, continue the completion chain of the returned CompletionStage on the supplied executor.
continueOnNonBlockingThread(CompletionStage<V>, Object) - Method in class org.infinispan.util.concurrent.BlockingManagerImpl
 
continueTaskInBackground() - Method in class org.infinispan.executors.SemaphoreCompletionService
Called from a task to remove the permit that would otherwise be freed when the task finishes running When the asynchronous part of the task finishes, it must call SemaphoreCompletionService.backgroundTaskFinished(Callable) to make the permit available again.
CONTINUOUS_QUERY_FILTER_FACTORY_NAME - Static variable in class org.infinispan.client.hotrod.filter.Filters
 
ContinuousQuery<K,V> - Interface in org.infinispan.query.api.continuous
A container of continuous query listeners for a cache.
ContinuousQueryImpl<K,V> - Class in org.infinispan.client.hotrod.event.impl
A container of continuous query listeners for a remote cache.
ContinuousQueryImpl(RemoteCache<K, V>) - Constructor for class org.infinispan.client.hotrod.event.impl.ContinuousQueryImpl
 
ContinuousQueryListener<K,V> - Interface in org.infinispan.query.api.continuous
Listener for continuous query events.
ControlByte - Enum in org.infinispan.server.hotrod.tx
A control byte used by each write operation to flag if the key was read or not, or if the write operation is a remove operation
convert(long, MemoryUnit) - Method in enum org.infinispan.commons.util.MemoryUnit
Deprecated.
 
convert(Object) - Method in interface org.infinispan.search.mapper.mapping.EntityConverter
Perform the conversion.
convert(Object, MediaType, MediaType) - Method in class org.infinispan.encoding.DataConversion
Deprecated, for removal: This API element is subject to removal in a future version.
Since 11.0, with no replacement.
convert(Object, MediaType, MediaType) - Method in interface org.infinispan.marshall.core.EncoderRegistry
Performs a data conversion.
convert(Object, MediaType, MediaType) - Method in class org.infinispan.marshall.core.EncoderRegistryImpl
 
convert(String) - Method in enum org.infinispan.commons.configuration.io.NamingStrategy
 
convert(K, V, Metadata) - Method in class org.infinispan.filter.AbstractKeyValueFilterConverter
 
convert(K, V, Metadata) - Method in interface org.infinispan.filter.Converter
 
convert(K, V, Metadata) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventConverterAsConverter
 
convert(K, V, Metadata, V, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.AbstractCacheEventFilterConverter
 
convert(K, V, Metadata, V, Metadata, EventType) - Method in interface org.infinispan.notifications.cachelistener.filter.CacheEventConverter
Converts the given newValue into something different possibly.
convert(K, V, Metadata, V, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter
 
convert(K, V, Metadata, V, Metadata, EventType) - Method in class org.infinispan.server.hotrod.event.KeyValueWithPreviousEventConverter
 
convert(MarshallableEntry<K, V>, InternalEntryFactory) - Static method in class org.infinispan.persistence.internal.PersistenceUtil
 
convert(MarshallableEntry<K, V>, InternalEntryFactory) - Static method in class org.infinispan.persistence.PersistenceUtil
 
convertCharset(Object, Charset, Charset) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
Convert text content.
convertedTypeIdentifier() - Method in interface org.infinispan.search.mapper.mapping.EntityConverter
 
converter - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
Converter<K,V,C> - Interface in org.infinispan.filter
Converter that can be used to transform a given entry to a different value.
converterFactoryName() - Element in annotation type org.infinispan.client.hotrod.annotation.ClientListener
Defines the converter factory for this client listener.
converterToFunction(KeyValueFilterConverter<? super K, ? super V, C>) - Static method in class org.infinispan.filter.CacheFilters
Creates a new Function using the provided filter convert.
Converting to String - Search tag in class org.infinispan.commons.dataconversion.internal.Json
Section
convertJavaToOctetStream(Object, MediaType, Marshaller) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
Deprecated, for removal: This API element is subject to removal in a future version.
Since 13.0, with no replacement.
convertJavaToProtoStream(Object, MediaType, ImmutableSerializationContext) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
Converts a java object to a sequence of bytes using a ProtoStream ImmutableSerializationContext.
convertJavaToText(Object, MediaType, MediaType) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
Deprecated, for removal: This API element is subject to removal in a future version.
Since 13.0 without replacement.
convertNanosToMicro(double) - Static method in class org.infinispan.extendedstats.CacheStatisticCollector
 
convertNanosToSeconds(double) - Static method in class org.infinispan.extendedstats.CacheStatisticCollector
 
convertOctetStreamToJava(byte[], MediaType, Marshaller) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
Deprecated, for removal: This API element is subject to removal in a future version.
Since 13.0, without replacement.
convertOctetStreamToText(byte[], MediaType) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
Deprecated, for removal: This API element is subject to removal in a future version.
Since 13.0, without replacment.
convertOctetStreamToUrlEncoded(Object, MediaType) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
Deprecated, for removal: This API element is subject to removal in a future version.
Since 13.0 without replacement.
convertParameters(TaskContext) - Method in class org.infinispan.scripting.utils.ScriptConversions
 
convertSynchronization(Synchronization) - Method in class org.infinispan.cache.impl.InvocationHelper
 
convertSynchronization(Synchronization) - Method in enum org.infinispan.commons.tx.DefaultResourceConverter
 
convertSynchronization(Synchronization) - Method in interface org.infinispan.commons.tx.TransactionResourceConverter
 
convertTextToObject(Object, MediaType) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
Converts text content to the Java representation (String).
convertTextToOctetStream(Object, MediaType) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
Deprecated, for removal: This API element is subject to removal in a future version.
Since 13.0, without replacement.
convertTextToText(Object, MediaType, MediaType) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
Convert text content to a different encoding.
convertTextToUrlEncoded(Object, MediaType) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
Deprecated, for removal: This API element is subject to removal in a future version.
Since 13.0, without replacement.
convertToOctetStream(Object, MediaType, MediaType) - Method in class org.infinispan.commons.dataconversion.DefaultTranscoder
 
convertToRequestFormat(Object, MediaType) - Method in class org.infinispan.encoding.DataConversion
Deprecated, for removal: This API element is subject to removal in a future version.
Since 11.0, with no replacement.
convertToRequestType(Object, MediaType, MediaType) - Method in class org.infinispan.scripting.utils.ScriptConversions
 
convertUrlEncodedToObject(Object) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
Deprecated, for removal: This API element is subject to removal in a future version.
since 13.0 without replacement.
convertUrlEncodedToOctetStream(Object) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
Deprecated, for removal: This API element is subject to removal in a future version.
Since 13.0 without replacement.
convertUrlEncodedToText(Object, MediaType) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
Deprecated, for removal: This API element is subject to removal in a future version.
Since 13.0 without replacement.
ConvertUtil - Class in org.infinispan.counter.configuration
convertValue(CacheEventConverter<? super K, ? super V, ?>, CacheEntryEvent<K, V>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
convertXaResource(XAResource) - Method in class org.infinispan.cache.impl.InvocationHelper
 
convertXaResource(XAResource) - Method in enum org.infinispan.commons.tx.DefaultResourceConverter
 
convertXaResource(XAResource) - Method in interface org.infinispan.commons.tx.TransactionResourceConverter
 
COORDINATOR - Enum constant in enum org.infinispan.topology.ClusterTopologyManager.ClusterManagerStatus
 
copier() - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
 
copier(AttributeCopier<T>) - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition.Builder
 
copy() - Method in interface org.infinispan.commons.io.ByteBuffer
Returns a new byte[] instance of size ByteBuffer.getLength() that contains all the bytes owned by this buffer.
copy() - Method in class org.infinispan.commons.io.ByteBufferImpl
 
copy() - Method in class org.infinispan.functional.impl.MetaParams
 
copy() - Method in class org.infinispan.rest.ServerSentEvent
 
copy(InputStream, OutputStream) - Static method in class org.infinispan.util.stream.Streams
Deprecated.
Copy all of the bytes from the input stream to the output stream.
copy(InputStream, OutputStream, byte[]) - Static method in class org.infinispan.util.stream.Streams
Deprecated.
Copy all of the bytes from the input stream to the output stream.
copy(InputStream, OutputStream, int) - Static method in class org.infinispan.util.stream.Streams
Deprecated.
Copy all of the bytes from the input stream to the output stream.
copy(Xid) - Static method in class org.infinispan.commons.tx.XidImpl
 
copy(ReadWriteManyCommand<K, V, R>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
copy(ReadWriteManyEntriesCommand<K, V, T, R>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
copy(WriteOnlyManyCommand<K, V>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
copy(WriteOnlyManyEntriesCommand<K, V, T>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
copy(PutMapCommand, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
copy(CacheEntry) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
 
copy(CacheEntry<K, V>) - Method in interface org.infinispan.container.impl.InternalEntryFactory
Creates a copy of this cache entry and synchronizes serializes the copy process with the InternalEntryFactory.update(org.infinispan.container.entries.InternalCacheEntry, org.infinispan.metadata.Metadata).
copyAttribute(TypedProperties) - Method in class org.infinispan.commons.configuration.attributes.TypedPropertiesAttributeCopier
 
copyAttribute(T) - Method in interface org.infinispan.commons.configuration.attributes.AttributeCopier
 
copyAttribute(T) - Method in class org.infinispan.commons.configuration.attributes.CollectionAttributeCopier
 
copyAttribute(T) - Method in class org.infinispan.commons.configuration.attributes.CopyConstructorAttributeCopier
 
copyAttribute(T) - Method in class org.infinispan.commons.configuration.attributes.IdentityAttributeCopier
 
copyAttribute(T) - Method in class org.infinispan.commons.configuration.attributes.SimpleInstanceAttributeCopier
 
copyb(InputStream, OutputStream) - Static method in class org.infinispan.util.stream.Streams
Deprecated.
Copy all of the bytes from the input stream to the output stream wrapping streams in buffers as needed.
CopyConstructorAttributeCopier<T> - Class in org.infinispan.commons.configuration.attributes
CopyConstructorAttributeCopier.
copySome(InputStream, OutputStream, byte[], long) - Static method in class org.infinispan.util.stream.Streams
Deprecated.
Copy a limited number of bytes from the input stream to the output stream.
copySome(InputStream, OutputStream, int, long) - Static method in class org.infinispan.util.stream.Streams
Deprecated.
Copy a limited number of bytes from the input stream to the output stream.
copySome(InputStream, OutputStream, long) - Static method in class org.infinispan.util.stream.Streams
Deprecated.
Copy a limited number of bytes from the input stream to the output stream.
copyValue(ExtendedStatistic, ExtendedStatistic) - Method in class org.infinispan.extendedstats.TransactionStatistics
Copies a statistic value and adds it to another statistic.
copyWithoutRemotableFlags(long) - Static method in class org.infinispan.context.impl.FlagBitSets
Creates a copy of a Flag BitSet removing instances of FAIL_SILENTLY.
CORE_LOWER_BOUND - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
CORE_THREADS - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
CoreBlockHoundIntegration - Class in org.infinispan.util
 
CoreBlockHoundIntegration() - Constructor for class org.infinispan.util.CoreBlockHoundIntegration
 
CoreConfigurationSerializer - Class in org.infinispan.configuration.serializing
Serializes an Infinispan configuration to an ConfigurationWriter
CoreConfigurationSerializer() - Constructor for class org.infinispan.configuration.serializing.CoreConfigurationSerializer
 
CoreExecutorFactory - Class in org.infinispan.factories.threads
Static factory class for producing executor factories in the core module
CoreImmutables - Class in org.infinispan.util
Factory for generating immutable type wrappers for core types.
CoreImmutables() - Constructor for class org.infinispan.util.CoreImmutables
 
coreThreads - Variable in class org.infinispan.factories.threads.AbstractThreadPoolExecutorFactory
 
coreThreads() - Method in class org.infinispan.commons.executors.BlockingThreadPoolExecutorFactory
Deprecated.
 
coreThreads() - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
 
coreThreads() - Method in class org.infinispan.factories.threads.AbstractThreadPoolExecutorFactory
 
coreThreads(Integer) - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
 
cors() - Method in class org.infinispan.rest.configuration.RestServerConfiguration
 
cors() - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
 
CorsConfiguration - Class in org.infinispan.rest.configuration
 
CorsConfigurationBuilder - Class in org.infinispan.rest.configuration
 
CorsConfigurationBuilder() - Constructor for class org.infinispan.rest.configuration.CorsConfigurationBuilder
 
CorsHandler - Class in org.infinispan.rest
Handles Cross Origin Resource Sharing (CORS) requests.
CorsHandler(CorsConfig) - Constructor for class org.infinispan.rest.CorsHandler
Creates a new instance with a single CorsConfig.
CorsHandler(List<CorsConfig>, boolean) - Constructor for class org.infinispan.rest.CorsHandler
Creates a new instance with the specified config list.
CorsRuleConfiguration - Class in org.infinispan.rest.configuration
 
CorsRuleConfigurationBuilder - Class in org.infinispan.rest.configuration
 
corsRules() - Method in class org.infinispan.rest.configuration.CorsConfiguration
 
couldNotFindPropertiesFile(String) - Method in interface org.infinispan.client.hotrod.logging.Log
 
couldNotInstantiateTransformerClass(Class<?>, Exception) - Method in interface org.infinispan.query.logging.Log
 
couldNotMigrateData(String) - Method in interface org.infinispan.persistence.remote.logging.Log
 
count() - Method in class org.infinispan.commons.stat.DefaultSimpleStat
 
count() - Method in interface org.infinispan.commons.stat.SimpleStat
 
count() - Method in interface org.infinispan.commons.stat.TimerTracker
 
count() - Method in interface org.infinispan.functional.Traversable
A terminal operation that returns the number of elements in the traversable.
count() - Static method in class org.infinispan.reactive.publisher.PublisherReducers
 
count() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
count() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
count() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
count() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
count() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
count() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
count() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
count() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
count() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
count(String) - Static method in interface org.infinispan.query.dsl.Expression
Deprecated.
 
count(AdvancedCacheLoader<K, V>, Predicate<? super K>) - Static method in class org.infinispan.persistence.PersistenceUtil
 
count(SegmentedAdvancedLoadWriteStore<?, ?>, IntSet) - Static method in class org.infinispan.persistence.PersistenceUtil
Counts how many entries are present in the segmented store.
COUNT - Enum constant in enum org.infinispan.eviction.EvictionType
Deprecated.
 
CountDownRunnable - Class in org.infinispan.util.concurrent
A concurrency structure that invokes a Runnable when its count reaches zero.
CountDownRunnable(Runnable) - Constructor for class org.infinispan.util.concurrent.CountDownRunnable
 
counter - Static variable in class org.infinispan.client.hotrod.event.impl.ClientListenerNotifier
 
COUNTER - Enum constant in enum org.infinispan.security.AuditContext
 
COUNTER_ADD_AND_GET - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
COUNTER_ADD_AND_GET_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
COUNTER_ADD_LISTENER - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
COUNTER_ADD_LISTENER_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
COUNTER_BACKUP_ENTRY - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
COUNTER_CACHE_NAME - Static variable in class org.infinispan.client.hotrod.counter.impl.CounterOperationFactory
 
COUNTER_CACHE_NAME - Static variable in class org.infinispan.counter.impl.CounterModuleLifecycle
 
COUNTER_CAS - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
COUNTER_CAS_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
COUNTER_CONFIGURATION - Static variable in interface org.infinispan.commons.marshall.Ids
 
COUNTER_CONFIGURATION - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
COUNTER_CREATE - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
COUNTER_CREATE_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
COUNTER_EVENT - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
COUNTER_GET - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
COUNTER_GET_CONFIGURATION - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
COUNTER_GET_CONFIGURATION_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
COUNTER_GET_NAMES - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
COUNTER_GET_NAMES_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
COUNTER_GET_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
COUNTER_IS_DEFINED - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
COUNTER_IS_DEFINED_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
COUNTER_NOT_FOUND - Enum constant in enum org.infinispan.server.hotrod.counter.listener.ListenerOperationStatus
The counter wasn't found.
COUNTER_REMOVE - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
COUNTER_REMOVE_LISTENER - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
COUNTER_REMOVE_LISTENER_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
COUNTER_REMOVE_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
COUNTER_RESET - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
COUNTER_RESET_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
COUNTER_STATE - Static variable in interface org.infinispan.commons.marshall.Ids
 
COUNTER_STATE - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
COUNTER_STORAGE - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
COUNTER_TYPE - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
COUNTER_VALUE - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
CounterBackupEntry() - Constructor for class org.infinispan.server.core.backup.resources.CounterResource.CounterBackupEntry
 
CounterBackupEntry$___Marshaller_2af248d5cc134577501d751e859e0021aca6b7f47edf43acc378580b56297af6 - Class in org.infinispan.server.core.backup.resources
WARNING: Generated code! Do not edit!
CounterBackupEntry$___Marshaller_2af248d5cc134577501d751e859e0021aca6b7f47edf43acc378580b56297af6() - Constructor for class org.infinispan.server.core.backup.resources.CounterBackupEntry$___Marshaller_2af248d5cc134577501d751e859e0021aca6b7f47edf43acc378580b56297af6
 
counterConfiguration() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
 
CounterConfiguration - Class in org.infinispan.counter.api
A counter configuration used to define counters cluster wide via CounterManager.defineCounter(String, CounterConfiguration).
CounterConfiguration.Builder - Class in org.infinispan.counter.api
The builder of CounterConfiguration.
CounterConfiguration$___Marshaller_200ccbe7f9bd55cd3d0f90bae5ea29adc0a29590c936038020329c50ede7e29f - Class in org.infinispan.counter.api
WARNING: Generated code! Do not edit!
CounterConfiguration$___Marshaller_200ccbe7f9bd55cd3d0f90bae5ea29adc0a29590c936038020329c50ede7e29f() - Constructor for class org.infinispan.counter.api.CounterConfiguration$___Marshaller_200ccbe7f9bd55cd3d0f90bae5ea29adc0a29590c936038020329c50ede7e29f
 
CounterConfigurationBuilder<T,S> - Interface in org.infinispan.counter.configuration
Base counter configuration builder.
CounterConfigurationException - Exception Class in org.infinispan.counter.exception
Signals a missing configuration or an invalid configuration.
CounterConfigurationException() - Constructor for exception class org.infinispan.counter.exception.CounterConfigurationException
 
CounterConfigurationException(String) - Constructor for exception class org.infinispan.counter.exception.CounterConfigurationException
 
CounterConfigurationException(String, Throwable) - Constructor for exception class org.infinispan.counter.exception.CounterConfigurationException
 
CounterConfigurationException(Throwable) - Constructor for exception class org.infinispan.counter.exception.CounterConfigurationException
 
CounterConfigurationMetaParam - Class in org.infinispan.functional.impl
CounterConfigurationMetaParam(CounterConfiguration) - Constructor for class org.infinispan.functional.impl.CounterConfigurationMetaParam
 
CounterConfigurationParser - Class in org.infinispan.counter.configuration
Counters configuration parser
CounterConfigurationParser() - Constructor for class org.infinispan.counter.configuration.CounterConfigurationParser
 
counterConfigurationResponse(HotRodHeader, HotRodServer, Channel, CounterConfiguration) - Method in class org.infinispan.server.hotrod.Encoder4x
 
counterConfigurationResponse(HotRodHeader, HotRodServer, Channel, CounterConfiguration) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
 
CounterConfigurationSerializer - Class in org.infinispan.counter.configuration
Counters configuration serializer.
CounterConfigurationSerializer() - Constructor for class org.infinispan.counter.configuration.CounterConfigurationSerializer
 
CounterEvent - Interface in org.infinispan.counter.api
The event used by CounterListener.
CounterEventDispatcher - Class in org.infinispan.client.hotrod.event.impl
 
CounterEventDispatcher(byte[], ConcurrentMap<String, List<Consumer<HotRodCounterEvent>>>, SocketAddress, Supplier<CompletableFuture<Void>>, Runnable) - Constructor for class org.infinispan.client.hotrod.event.impl.CounterEventDispatcher
 
CounterException - Exception Class in org.infinispan.counter.exception
A RuntimeException related to counters.
CounterException() - Constructor for exception class org.infinispan.counter.exception.CounterException
 
CounterException(String) - Constructor for exception class org.infinispan.counter.exception.CounterException
 
CounterException(String, Throwable) - Constructor for exception class org.infinispan.counter.exception.CounterException
 
CounterException(String, Throwable, boolean, boolean) - Constructor for exception class org.infinispan.counter.exception.CounterException
 
CounterException(Throwable) - Constructor for exception class org.infinispan.counter.exception.CounterException
 
CounterListener - Interface in org.infinispan.counter.api
A listener interface to listen to StrongCounter changes.
CounterManager - Interface in org.infinispan.counter.api
The CounterManager creates, defines and returns counters.
CounterManagerConfiguration - Class in org.infinispan.counter.configuration
The CounterManager configuration.
CounterManagerConfigurationBuilder - Class in org.infinispan.counter.configuration
The CounterManager configuration builder.
CounterManagerConfigurationBuilder(GlobalConfigurationBuilder) - Constructor for class org.infinispan.counter.configuration.CounterManagerConfigurationBuilder
 
counterManagerNotStarted() - Method in interface org.infinispan.counter.logging.Log
 
CounterMetricInfo<T> - Class in org.infinispan.commons.stat
Represents a counter.
CounterMetricInfo(String, String, Map<String, String>, BiConsumer<T, CounterTracker>) - Constructor for class org.infinispan.commons.stat.CounterMetricInfo
 
CounterModuleLifecycle - Class in org.infinispan.counter.impl
It registers a EmbeddedCounterManager to each EmbeddedCacheManager started and starts the cache on it.
CounterModuleLifecycle() - Constructor for class org.infinispan.counter.impl.CounterModuleLifecycle
 
counterNamesResponse(HotRodHeader, HotRodServer, Channel, Collection<String>) - Method in class org.infinispan.server.hotrod.Encoder4x
 
counterNamesResponse(HotRodHeader, HotRodServer, Channel, Collection<String>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
 
CounterNotFoundException - Exception Class in org.infinispan.counter.exception
Signal that an attempt to access a counter has failed.
CounterNotFoundException() - Constructor for exception class org.infinispan.counter.exception.CounterNotFoundException
 
CounterNotFoundException(String) - Constructor for exception class org.infinispan.counter.exception.CounterNotFoundException
 
CounterNotFoundException(String, Throwable) - Constructor for exception class org.infinispan.counter.exception.CounterNotFoundException
 
CounterNotFoundException(String, Throwable, boolean, boolean) - Constructor for exception class org.infinispan.counter.exception.CounterNotFoundException
 
CounterNotFoundException(Throwable) - Constructor for exception class org.infinispan.counter.exception.CounterNotFoundException
 
CounterOperationFactory - Class in org.infinispan.client.hotrod.counter.impl
A operation factory that builds counter operations.
CounterOutOfBoundsException - Exception Class in org.infinispan.counter.exception
A CounterException signalling that the StrongCounter has reached its bounds.
CounterOutOfBoundsException(String) - Constructor for exception class org.infinispan.counter.exception.CounterOutOfBoundsException
 
CounterParser - Class in org.infinispan.counter.configuration
Counters configuration parser
CounterParser() - Constructor for class org.infinispan.counter.configuration.CounterParser
 
counterProcessor - Variable in class org.infinispan.server.hotrod.HotRodDecoder
 
CounterResource - Class in org.infinispan.rest.resources
Handler for the counter resource.
CounterResource - Class in org.infinispan.server.core.backup.resources
CounterResource(InvocationHelper) - Constructor for class org.infinispan.rest.resources.CounterResource
 
CounterResource.CounterBackupEntry - Class in org.infinispan.server.core.backup.resources
ProtoStream entity used to represent counter instances.
counters() - Method in class org.infinispan.counter.configuration.CounterManagerConfiguration
 
counters() - Method in class org.infinispan.counter.configuration.CounterManagerConfigurationBuilder
 
COUNTERS - Enum constant in enum org.infinispan.counter.configuration.Element
 
COUNTERS - Enum constant in enum org.infinispan.server.core.BackupManager.Resources.Type
 
COUNTERS_LOWER_BOUND - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
CounterState - Enum in org.infinispan.counter.api
The possible states for a counter value.
CounterState$___Marshaller_93aa5d27c0d57954ec79247b055254b02d5c87a64e0764e392772b387eb7542d - Class in org.infinispan.counter.api
 
CounterState$___Marshaller_93aa5d27c0d57954ec79247b055254b02d5c87a64e0764e392772b387eb7542d() - Constructor for class org.infinispan.counter.api.CounterState$___Marshaller_93aa5d27c0d57954ec79247b055254b02d5c87a64e0764e392772b387eb7542d
 
CounterTracker - Interface in org.infinispan.commons.stat
Tracks a monotonically increasing values.
CounterType - Enum in org.infinispan.counter.api
The counter types.
CounterType$___Marshaller_4dd4ef0972bf79fd96da56b8ce9348d84b1c42596acd7df3abf86c5e467887f5 - Class in org.infinispan.counter.api
 
CounterType$___Marshaller_4dd4ef0972bf79fd96da56b8ce9348d84b1c42596acd7df3abf86c5e467887f5() - Constructor for class org.infinispan.counter.api.CounterType$___Marshaller_4dd4ef0972bf79fd96da56b8ce9348d84b1c42596acd7df3abf86c5e467887f5
 
countRequestsReceived() - Method in class org.infinispan.xsite.metrics.DefaultXSiteMetricsCollector
 
countRequestsReceived() - Method in class org.infinispan.xsite.metrics.NoOpXSiteMetricsCollector
 
countRequestsReceived() - Method in interface org.infinispan.xsite.metrics.XSiteMetricsCollector
 
countRequestsReceived(String) - Method in class org.infinispan.xsite.metrics.DefaultXSiteMetricsCollector
 
countRequestsReceived(String) - Method in class org.infinispan.xsite.metrics.NoOpXSiteMetricsCollector
 
countRequestsReceived(String) - Method in interface org.infinispan.xsite.metrics.XSiteMetricsCollector
 
countRequestsSent() - Method in class org.infinispan.xsite.metrics.DefaultXSiteMetricsCollector
 
countRequestsSent() - Method in class org.infinispan.xsite.metrics.NoOpXSiteMetricsCollector
 
countRequestsSent() - Method in interface org.infinispan.xsite.metrics.XSiteMetricsCollector
 
countRequestsSent(String) - Method in class org.infinispan.xsite.metrics.DefaultXSiteMetricsCollector
 
countRequestsSent(String) - Method in class org.infinispan.xsite.metrics.NoOpXSiteMetricsCollector
 
countRequestsSent(String) - Method in interface org.infinispan.xsite.metrics.XSiteMetricsCollector
 
cpm - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
cpuCount - Variable in class org.infinispan.reactive.publisher.impl.LocalPublisherManagerImpl
 
CR - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
 
create() - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
 
create() - Method in class org.infinispan.client.hotrod.configuration.ClusterConfigurationBuilder
 
create() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
create() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
 
create() - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfigurationBuilder
 
create() - Method in class org.infinispan.client.hotrod.configuration.NearCacheConfigurationBuilder
 
create() - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfigurationBuilder
 
create() - Method in class org.infinispan.client.hotrod.configuration.SecurityConfigurationBuilder
 
create() - Method in class org.infinispan.client.hotrod.configuration.ServerConfigurationBuilder
 
create() - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
 
create() - Method in class org.infinispan.client.hotrod.configuration.StatisticsConfigurationBuilder
 
create() - Method in class org.infinispan.client.hotrod.configuration.TransactionConfigurationBuilder
Deprecated.
 
create() - Method in interface org.infinispan.commons.configuration.Builder
Create the configuration bean
create() - Static method in enum org.infinispan.commons.executors.CachedThreadPoolExecutorFactory
 
create() - Static method in enum org.infinispan.commons.executors.ScheduledThreadPoolExecutorFactory
 
create() - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
create() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
Deprecated.
 
create() - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
Deprecated.
 
create() - Method in class org.infinispan.configuration.cache.CustomStoreConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.IndexReaderConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
Deprecated.
 
create() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.MemoryStorageConfigurationBuilder
Deprecated.
 
create() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.QueryConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.SecurityConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.StatisticsConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.AllowListConfiguration
 
create() - Method in class org.infinispan.configuration.global.AllowListConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.CachedThreadPoolConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.GlobalJmxConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.GlobalMetricsConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.GlobalStatePathConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.GlobalStorageConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.JGroupsConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.PrincipalRoleMapperConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.RolePermissionMapperConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.ScheduledThreadPoolConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
Deprecated.
 
create() - Method in class org.infinispan.configuration.global.StackConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.StackFileConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.TemporaryGlobalStatePathConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.ThreadFactoryConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
create() - Method in class org.infinispan.configuration.global.WhiteListConfiguration
Deprecated.
 
create() - Method in class org.infinispan.configuration.global.WhiteListConfigurationBuilder
Deprecated.
 
create() - Method in class org.infinispan.configuration.parsing.SFSToSIFSConfigurationBuilder
 
create() - Method in class org.infinispan.counter.configuration.CounterManagerConfigurationBuilder
 
create() - Method in class org.infinispan.counter.configuration.StrongCounterConfigurationBuilder
 
create() - Method in class org.infinispan.counter.configuration.WeakCounterConfigurationBuilder
 
create() - Static method in class org.infinispan.functional.impl.Params
 
create() - Method in class org.infinispan.lock.configuration.ClusteredLockConfigurationBuilder
 
create() - Method in class org.infinispan.lock.configuration.ClusteredLockManagerConfigurationBuilder
 
create() - Method in class org.infinispan.metrics.config.MicrometerMeterRegisterConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.jdbc.common.configuration.ManagedConnectionFactoryConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.jdbc.configuration.DataColumnConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.jdbc.configuration.IdColumnConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.jdbc.configuration.SegmentColumnConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.jdbc.configuration.TimestampColumnConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.remote.configuration.MechanismConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.remote.configuration.TrustStoreConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBExpirationConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.sifs.configuration.DataConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.sifs.configuration.IndexConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfigurationBuilder
 
create() - Method in class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfigurationBuilder
 
create() - Method in class org.infinispan.rest.configuration.AuthenticationConfigurationBuilder
 
create() - Method in class org.infinispan.rest.configuration.CorsConfigurationBuilder
 
create() - Method in class org.infinispan.rest.configuration.CorsRuleConfigurationBuilder
 
create() - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
 
create() - Method in class org.infinispan.rest.framework.impl.InvocationImpl.Builder
 
create() - Method in class org.infinispan.rest.framework.impl.Invocations.Builder
 
create() - Method in class org.infinispan.security.impl.CreatePermissionConfigurationBuilder
 
create() - Method in class org.infinispan.server.core.configuration.EncryptionConfigurationBuilder
 
create() - Method in class org.infinispan.server.core.configuration.IpFilterConfigurationBuilder
 
create() - Method in class org.infinispan.server.core.configuration.SniConfigurationBuilder
 
create() - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
 
create() - Method in class org.infinispan.server.core.configuration.SslEngineConfigurationBuilder
 
create() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
 
create() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
 
create() - Method in class org.infinispan.server.hotrod.configuration.SaslConfigurationBuilder
 
create() - Method in class org.infinispan.server.hotrod.configuration.TopologyCacheConfigurationBuilder
 
create() - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
 
create(byte) - Static method in class org.infinispan.commons.io.ByteBufferImpl
 
create(byte[]) - Static method in class org.infinispan.commons.io.ByteBufferImpl
 
create(byte[], int, int) - Static method in class org.infinispan.commons.io.ByteBufferImpl
 
create(int) - Method in interface org.infinispan.cache.impl.ContextBuilder
Creates a new InvocationContext.
create(int, byte[], byte[]) - Static method in class org.infinispan.commons.tx.XidImpl
 
create(int, int) - Static method in class org.infinispan.factories.threads.EnhancedQueueExecutorFactory
 
create(int, int) - Static method in class org.infinispan.factories.threads.NonBlockingThreadPoolExecutorFactory
 
create(int, int, boolean) - Static method in class org.infinispan.commons.executors.BlockingThreadPoolExecutorFactory
Deprecated.
 
create(int, int, List<Address>, Map<Address, Float>) - Method in interface org.infinispan.distribution.ch.ConsistentHashFactory
Deprecated.
Create a new consistent hash instance.
create(int, int, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
 
create(int, int, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory
 
create(int, int, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory
 
create(int, int, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory
 
create(int, int, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory
 
create(int, long) - Static method in class org.infinispan.container.versioning.irac.TopologyIracVersion
 
create(long, Collection<Address>, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
Creates a collector for a single key write operation.
create(Object) - Method in interface org.infinispan.persistence.spi.MarshallableEntryFactory
value defaults to null
create(Object) - Static method in class org.infinispan.remoting.responses.UnsuccessfulResponse
 
create(Object, Object) - Method in interface org.infinispan.persistence.spi.MarshallableEntryFactory
metadata defaults to null created defaults to -1 lastUsed defaults to -1
create(Object, Object, InternalCacheEntry) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
 
create(Object, Object, EntryVersion, long, long, long, long) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
 
create(Object, Object, Metadata) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
 
create(Object, Object, Metadata, long, long) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
 
create(Object, Object, Metadata, long, long, long, long) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
 
create(Object, Object, Metadata, PrivateMetadata, long, long) - Method in interface org.infinispan.persistence.spi.MarshallableEntryFactory
Creates a MarshallableEntry using non-marshalled POJOs as arguments
create(Object, ByteBuffer, ByteBuffer, ByteBuffer, long, long) - Method in interface org.infinispan.persistence.spi.MarshallableEntryFactory
Creates a MarshallableEntry using a object key and already marshalled value/metadata as arguments
create(Object, InternalCacheValue<V>) - Method in interface org.infinispan.persistence.spi.MarshallableEntryFactory
Creates a MarshallableEntry instance from a key and an InternalCacheValue.
create(Object, MarshalledValue) - Method in interface org.infinispan.persistence.spi.MarshallableEntryFactory
Creates a MarshallableEntry using a Key MarshalledValue.
create(String) - Static method in class org.infinispan.client.hotrod.impl.HotRodURI
 
create(String) - Method in interface org.infinispan.query.dsl.QueryFactory
Creates a Query based on an Ickle query string.
create(String, Path) - Method in class org.infinispan.server.core.backup.BackupManagerImpl
 
create(String, Path) - Method in interface org.infinispan.server.core.BackupManager
Create a backup of all containers configured on the server, including all available resources.
create(String, Path, Map<String, BackupManager.Resources>) - Method in class org.infinispan.server.core.backup.BackupManagerImpl
 
create(String, Path, Map<String, BackupManager.Resources>) - Method in interface org.infinispan.server.core.BackupManager
Create a backup of the specified containers, including the resources defined in the provided BackupManager.Resources object.
create(URI) - Static method in class org.infinispan.client.hotrod.impl.HotRodURI
 
create(ByteBuffer) - Static method in class org.infinispan.commons.io.ByteBufferImpl
 
create(UUID) - Static method in class org.infinispan.client.hotrod.transaction.manager.RemoteXid
 
create(K, V, InternalCacheEntry<?, ?>) - Method in interface org.infinispan.container.impl.InternalEntryFactory
Creates a new InternalCacheEntry instance based on the version and timestamp/lifespan information reflected in the CacheEntry instance passed in.
create(K, V, EntryVersion, long, long, long, long) - Method in interface org.infinispan.container.impl.InternalEntryFactory
Creates a new InternalCacheEntry instance
create(K, V, Metadata) - Method in interface org.infinispan.container.impl.InternalEntryFactory
Creates a new InternalCacheEntry instance
create(K, V, Metadata, long, long) - Method in interface org.infinispan.container.impl.InternalEntryFactory
Creates a new InternalCacheEntry instance
create(K, V, Metadata, long, long, long, long) - Method in interface org.infinispan.container.impl.InternalEntryFactory
Creates a new InternalCacheEntry instance
create(AttributeFactory) - Method in class org.infinispan.search.mapper.mapping.impl.DefaultAnalysisConfigurer.ConfigurableBufferSizeKeywordTokenizerFactory
 
create(AdvancedCache<K, V>) - Static method in class org.infinispan.functional.impl.FunctionalMapImpl
 
create(NearCacheConfiguration, ClientListenerNotifier) - Static method in class org.infinispan.client.hotrod.near.NearCacheService
 
create(ClientListenerOperation, SocketAddress, Runnable, InternalRemoteCache<?, ?>) - Static method in class org.infinispan.client.hotrod.event.impl.ClientEventDispatcher
 
create(Hash, int, int, List<Address>, Map<Address, Float>) - Method in interface org.infinispan.distribution.ch.ConsistentHashFactory
Deprecated, for removal: This API element is subject to removal in a future version.
since 11.0. hashFunction is ignored, use ConsistentHashFactory.create(int, int, List, Map) instead.
create(ByteBuffer, ByteBuffer) - Method in interface org.infinispan.persistence.spi.MarshallableEntryFactory
metadataBytes defaults to null created defaults to -1 lastUsed defaults to -1
create(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, long, long) - Method in interface org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore.EntryCreator
 
create(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, long, long) - Method in interface org.infinispan.persistence.spi.MarshallableEntryFactory
Creates a MarshallableEntry using already marshalled objects as arguments
create(WrappedBytes, int, InternalCacheEntry<WrappedBytes, WrappedBytes>) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
Creates an off-heap entry using the provided key value and metadata
create(WrappedBytes, int, InternalCacheEntry<WrappedBytes, WrappedBytes>) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
 
create(BackupConfiguration) - Static method in class org.infinispan.xsite.statetransfer.AsyncProviderState
 
create(BackupConfiguration) - Static method in class org.infinispan.xsite.statetransfer.SyncProviderState
 
create(Configuration, AsyncInterceptorChain) - Static method in class org.infinispan.stats.impl.StatsImpl
Use this factory to create Stats object from configuration and the interceptor chain.
create(CacheEntry) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
 
create(CacheEntry<K, V>) - Method in interface org.infinispan.container.impl.InternalEntryFactory
Creates a new InternalCacheEntry instance based on the key, value, version and timestamp/lifespan information reflected in the CacheEntry instance passed in.
create(InternalCacheEntry<K, V>) - Method in interface org.infinispan.persistence.spi.MarshallableEntryFactory
Creates a MarshallableEntry instance from an InternalCacheEntry.
create(FunctionalMapImpl<K, V>) - Static method in class org.infinispan.functional.impl.ReadOnlyMapImpl
 
create(FunctionalMapImpl<K, V>) - Static method in class org.infinispan.functional.impl.ReadWriteMapImpl
 
create(FunctionalMapImpl<K, V>) - Static method in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
create(Params, AdvancedCache<K, V>) - Static method in class org.infinispan.functional.impl.FunctionalMapImpl
 
create(StatsCollector) - Static method in class org.infinispan.stats.impl.StatsImpl
Use this factory to create Stats object from StatsCollector.
create(R, boolean) - Static method in class org.infinispan.functional.impl.StatsEnvelope
 
create(T) - Static method in class org.infinispan.commons.util.ByRef
 
create(T) - Static method in class org.infinispan.remoting.responses.SuccessfulResponse
 
create(T, CacheEntry<?, ?>, boolean, boolean) - Static method in class org.infinispan.functional.impl.StatsEnvelope
 
CREATE - Enum constant in enum org.infinispan.notifications.cachemanagerlistener.event.ConfigurationChangedEvent.EventType
 
CREATE - Enum constant in enum org.infinispan.security.AuthorizationPermission
Allows creation of resources (caches, counters, schemas, tasks)
CREATE - Static variable in class org.infinispan.functional.impl.StatsEnvelope
 
CREATE_NEW - Enum constant in enum org.infinispan.client.hotrod.configuration.ExhaustedAction
 
CREATE_NEW - Enum constant in enum org.infinispan.persistence.remote.configuration.ExhaustedAction
 
CREATE_ON_START - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
 
CREATE_ON_START - Static variable in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
CREATE_STATE_FUNCTION - Static variable in class org.infinispan.server.core.ExternalizerIds
 
createBackingEmbeddedCacheManager() - Method in class org.infinispan.spring.embedded.AbstractEmbeddedCacheManagerFactory
 
createBiased(long, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
 
createBlockingExecutorService() - Static method in class org.infinispan.commons.jdkspecific.ThreadCreator
 
createBuilder(int, int, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory
 
createCache(String, A) - Method in interface org.infinispan.commons.api.CacheContainerAdmin
Creates a cache on the container using the specified template.
createCache(String, String) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
 
createCache(String, String) - Method in interface org.infinispan.client.hotrod.RemoteCacheManagerAdmin
Creates a cache on the remote server cluster using the specified template name.
createCache(String, String) - Method in interface org.infinispan.commons.api.CacheContainerAdmin
Creates a cache on the container using the specified template.
createCache(String, String) - Method in class org.infinispan.manager.DefaultCacheManagerAdmin
 
createCache(String, String) - Method in interface org.infinispan.manager.EmbeddedCacheManagerAdmin
Creates a cache on the container using the specified template.
createCache(String, String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.GlobalConfigurationManager
Defines a cluster-wide cache configuration using the supplied template
createCache(String, String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.GlobalConfigurationManagerImpl
 
createCache(String, String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.ImmutableLocalConfigurationStorage
 
createCache(String, String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.OverlayLocalConfigurationStorage
 
createCache(String, String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
 
createCache(String, String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.LocalConfigurationStorage
Creates the cache using the supplied template, configuration and flags.
createCache(String, DefaultTemplate) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
 
createCache(String, DefaultTemplate) - Method in interface org.infinispan.client.hotrod.RemoteCacheManagerAdmin
Creates a cache on the remote server cluster using the specified default configuration template present in the server.
createCache(String, BasicConfiguration) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
 
createCache(String, BasicConfiguration) - Method in interface org.infinispan.client.hotrod.RemoteCacheManagerAdmin
Creates a cache on the remote server cluster using the specified configuration
createCache(String, Configuration) - Method in class org.infinispan.manager.DefaultCacheManager
 
createCache(String, Configuration) - Method in class org.infinispan.manager.DefaultCacheManagerAdmin
 
createCache(String, Configuration) - Method in interface org.infinispan.manager.EmbeddedCacheManager
Creates a cache on the local node using the supplied configuration.
createCache(String, Configuration) - Method in interface org.infinispan.manager.EmbeddedCacheManagerAdmin
Creates a cache across the cluster.
createCache(String, Configuration) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
createCache(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.GlobalConfigurationManager
Defines a cluster-wide cache configuration
createCache(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.GlobalConfigurationManagerImpl
 
createCache(Configuration, GlobalComponentRegistry, String) - Method in class org.infinispan.factories.InternalCacheFactory
This implementation clones the configuration passed in before using it.
createChannel(String) - Method in class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator
 
createChannel(String) - Method in class org.infinispan.remoting.transport.jgroups.FileJGroupsChannelConfigurator
 
createChannel(String) - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelConfigurator
 
createChannelFactory() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
createClearNonTxInvocationContext() - Method in class org.infinispan.context.impl.AbstractInvocationContextFactory
 
createClearNonTxInvocationContext() - Method in interface org.infinispan.context.InvocationContextFactory
createConcurrentFilter(int) - Static method in class org.infinispan.commons.util.MurmurHash3BloomFilter
 
createConcurrentFilter(int, int) - Static method in class org.infinispan.commons.util.MurmurHash3BloomFilter
 
createConcurrentFilter(int, Iterable<ToIntFunction<? super E>>) - Static method in class org.infinispan.commons.util.BloomFilter
Same as BloomFilter.createFilter(int, Iterable) except the returned {code BloomFilter} instance may be used concurrently without additional synchronization.
createConnectEvent(ByteString) - Static method in class org.infinispan.xsite.events.XSiteEvent
 
createConsistentHash(int, short, SocketAddress[][]) - Method in class org.infinispan.client.hotrod.impl.TopologyInfo
 
createContainedTypeExtendedMappingCollector(PojoRawTypeModel<E>, String) - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapperDelegate
 
createContext(ComponentRegistry) - Method in interface org.infinispan.util.concurrent.locks.TransactionalRemoteLockCommand
It creates the transaction context.
created - Variable in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
created - Variable in class org.infinispan.container.entries.MortalCacheEntry
 
created - Variable in class org.infinispan.container.entries.MortalCacheValue
 
created - Variable in class org.infinispan.container.entries.ReadCommittedEntry
 
created - Variable in class org.infinispan.container.entries.TransientMortalCacheEntry
 
created() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
 
created() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
Deprecated.
 
created() - Method in interface org.infinispan.metadata.InternalMetadata
Deprecated.
 
created() - Method in interface org.infinispan.persistence.spi.MarshallableEntry
 
created(long) - Method in class org.infinispan.rest.NettyRestResponse.Builder
 
CREATED - Enum constant in enum org.infinispan.container.entries.ReadCommittedEntry.Flags
 
CREATED_HEADER - Enum constant in enum org.infinispan.rest.RequestHeader
 
CREATED_HEADER - Enum constant in enum org.infinispan.rest.ResponseHeader
 
createDatagramSocket(String) - Method in class org.infinispan.remoting.transport.jgroups.NamedSocketFactory
 
createDatagramSocket(String, int) - Method in class org.infinispan.remoting.transport.jgroups.NamedSocketFactory
 
createDatagramSocket(String, int, InetAddress) - Method in class org.infinispan.remoting.transport.jgroups.NamedSocketFactory
 
createDatagramSocket(String, SocketAddress) - Method in class org.infinispan.remoting.transport.jgroups.NamedSocketFactory
 
CreatedEventImpl<K> - Class in org.infinispan.client.hotrod.event.impl
 
CreatedEventImpl(byte[], K, long, boolean) - Constructor for class org.infinispan.client.hotrod.event.impl.CreatedEventImpl
 
createdNettyEventLoop(String, String) - Method in interface org.infinispan.server.core.logging.Log
 
createdSocketChannel(String, String) - Method in interface org.infinispan.server.core.logging.Log
 
createEntityReference(String, Object) - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
 
createEvent(Cache<K, V>, Event.Type) - Static method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
createEventLoopGroup(int, ExecutorService) - Method in interface org.infinispan.client.hotrod.TransportFactory
Creates an event loop group
createEventLoopGroup(int, ThreadFactory) - Static method in class org.infinispan.server.core.transport.IOURingNativeTransport
 
createEventLoopGroup(int, ThreadFactory) - Static method in class org.infinispan.server.core.transport.NativeTransport
 
createExecutor(ThreadFactory) - Method in class org.infinispan.commons.executors.BlockingThreadPoolExecutorFactory
Deprecated.
 
createExecutor(ThreadFactory) - Method in enum org.infinispan.commons.executors.CachedThreadPoolExecutorFactory
 
createExecutor(ThreadFactory) - Method in enum org.infinispan.commons.executors.ScheduledThreadPoolExecutorFactory
 
createExecutor(ThreadFactory) - Method in interface org.infinispan.commons.executors.ThreadPoolExecutorFactory
 
createExecutor(ThreadFactory) - Method in class org.infinispan.factories.threads.EnhancedQueueExecutorFactory
 
createExecutor(ThreadFactory) - Method in class org.infinispan.factories.threads.NonBlockingThreadPoolExecutorFactory
 
createExecutor(BlockingManager) - Method in class org.infinispan.xsite.events.XSiteEventsManagerImpl
 
createExternal(Class<?>, ObjectInput) - Method in class org.infinispan.jboss.marshalling.commons.JBossExternalizerAdapter
 
createFilter(int) - Static method in class org.infinispan.commons.util.MurmurHash3BloomFilter
 
createFilter(int, int) - Static method in class org.infinispan.commons.util.MurmurHash3BloomFilter
 
createFilter(int, Iterable<ToIntFunction<? super E>>) - Static method in class org.infinispan.commons.util.BloomFilter
 
createIndexedTypeExtendedMappingCollector(PojoRawTypeModel<E>, String) - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapperDelegate
 
createIndexer() - Method in class org.infinispan.search.mapper.session.impl.InfinispanSearchSession
 
createIndexer() - Method in interface org.infinispan.search.mapper.session.SearchSession
 
createInitialCacheTopology() - Method in class org.infinispan.topology.ClusterCacheStatus
 
createInitialStateRequest(ByteString, ByteString) - Static method in class org.infinispan.xsite.events.XSiteEvent
 
createInstance(PartitionHandlingConfiguration) - Method in interface org.infinispan.conflict.EntryMergePolicyFactory
 
createInstance(PartitionHandlingConfiguration) - Method in class org.infinispan.conflict.EntryMergePolicyFactoryRegistry
 
createInvocationContext(boolean, int) - Method in class org.infinispan.context.impl.NonTransactionalInvocationContextFactory
 
createInvocationContext(boolean, int) - Method in class org.infinispan.context.impl.TransactionalInvocationContextFactory
 
createInvocationContext(boolean, int) - Method in interface org.infinispan.context.InvocationContextFactory
If we are in a tx scope this will return an TxInvocationContext.
createInvocationContext(Transaction, boolean) - Method in class org.infinispan.context.impl.NonTransactionalInvocationContextFactory
 
createInvocationContext(Transaction, boolean) - Method in class org.infinispan.context.impl.TransactionalInvocationContextFactory
 
createInvocationContext(Transaction, boolean) - Method in interface org.infinispan.context.InvocationContextFactory
Creates an invocation context
createInvocationContextWithImplicitTransaction(int, boolean) - Method in class org.infinispan.cache.impl.InvocationHelper
Creates an invocation context with an implicit transaction if it is required.
createJdkSslContext(SslEngineConfiguration) - Static method in class org.infinispan.server.core.utils.SslUtils
 
createJsonArray(Collection<T>) - Static method in class org.infinispan.commons.dataconversion.internal.JsonUtils
 
createJsonArray(Collection<T>, Function<T, Json>) - Static method in class org.infinispan.commons.dataconversion.internal.JsonUtils
 
createJsonArray(Stream<T>) - Static method in class org.infinispan.commons.dataconversion.internal.JsonUtils
 
createJsonArray(Stream<T>, Function<T, Json>) - Static method in class org.infinispan.commons.dataconversion.internal.JsonUtils
 
createL1(K, V, Metadata) - Method in interface org.infinispan.container.impl.InternalEntryFactory
Creates a L1 entry.
createL1(K, V, Metadata) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
 
createLocalizedCacheTopology(CacheTopology) - Method in interface org.infinispan.distribution.DistributionManager
 
createLocalizedCacheTopology(CacheTopology) - Method in class org.infinispan.distribution.impl.DistributionManagerImpl
 
createLocalTx(XidImpl, EmbeddedTransaction) - Method in class org.infinispan.server.hotrod.tx.table.PerCacheTxTable
Adds the EmbeddedTransaction in the local transaction table.
createMap() - Method in class org.infinispan.commons.util.WeakValueHashMap
Create map.
createMapperDelegate() - Method in class org.infinispan.search.mapper.impl.InfinispanMappingInitiator
 
createMarshaller(MarshallingConfiguration) - Method in class org.infinispan.jboss.marshalling.commons.JBossMarshallerFactory
 
createMassIndexerAgent(PojoMassIndexerAgentCreateContext) - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
 
createMixedStatus(List<E>, List<E>) - Method in class org.infinispan.xsite.status.AbstractSiteStatusBuilder
 
createMixedStatus(List<String>, List<String>) - Method in class org.infinispan.xsite.status.ContainerSiteStatusBuilder
 
createMixedStatus(List<Address>, List<Address>) - Method in class org.infinispan.xsite.status.CacheSiteStatusBuilder
 
createMulticastSocket(String) - Method in class org.infinispan.remoting.transport.jgroups.NamedSocketFactory
 
createMulticastSocket(String, int) - Method in class org.infinispan.remoting.transport.jgroups.NamedSocketFactory
 
createMulticastSocket(String, SocketAddress) - Method in class org.infinispan.remoting.transport.jgroups.NamedSocketFactory
 
createMultiTargetCollector(long, int, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
 
createNearCache(NearCacheConfiguration, BiConsumer<K, MetadataValue<V>>) - Method in class org.infinispan.client.hotrod.near.DefaultNearCacheFactory
 
createNearCache(NearCacheConfiguration, BiConsumer<K, MetadataValue<V>>) - Method in interface org.infinispan.client.hotrod.near.NearCacheFactory
 
createNearCache(NearCacheConfiguration, BiConsumer<K, MetadataValue<V>>) - Method in class org.infinispan.client.hotrod.near.NearCacheService
 
createNearCacheService(String, NearCacheConfiguration) - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
createNettySslContext(SslConfiguration, SslEngineConfiguration, ApplicationProtocolConfig) - Static method in class org.infinispan.server.core.utils.SslUtils
 
createNewFile() - Method in class org.infinispan.io.GridFile
Deprecated.
 
createNonTxInvocationContext() - Method in class org.infinispan.context.impl.NonTransactionalInvocationContextFactory
 
createNonTxInvocationContext() - Method in class org.infinispan.context.impl.TransactionalInvocationContextFactory
 
createNonTxInvocationContext() - Method in interface org.infinispan.context.InvocationContextFactory
createOnStart() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
createOnStart(boolean) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
Determines whether database tables should be created by the store on startup
CreatePermissionConfiguration - Class in org.infinispan.security.impl
 
CreatePermissionConfigurationBuilder - Class in org.infinispan.security.impl
 
CreatePermissionConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.security.impl.CreatePermissionConfigurationBuilder
 
createPropertySource(ConfigurationPropertyChecker) - Method in class org.infinispan.search.mapper.mapping.impl.IndexProperties
 
createPushTask(Address, XSiteStateProvider) - Method in class org.infinispan.xsite.statetransfer.BaseXSiteStateProviderState
 
createPushTask(Address, XSiteStateProvider) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateProviderState
Creates a new XSiteStatePushTask to do state transfer to remove site.
createReader(InputStream) - Method in class org.infinispan.server.core.dataconversion.xml.MXParserDriver
 
createReader(Reader) - Method in class org.infinispan.server.core.dataconversion.xml.MXParserDriver
 
createReference(KeyTransformationHandler) - Static method in class org.infinispan.query.impl.KeyTransformationHandlerIdentifierBridge
 
createRemoteInvocationContext(Address) - Method in class org.infinispan.context.impl.NonTransactionalInvocationContextFactory
 
createRemoteInvocationContext(Address) - Method in class org.infinispan.context.impl.TransactionalInvocationContextFactory
 
createRemoteInvocationContext(Address) - Method in interface org.infinispan.context.InvocationContextFactory
createRemoteInvocationContextForCommand(VisitableCommand, Address) - Method in class org.infinispan.context.impl.AbstractInvocationContextFactory
 
createRemoteInvocationContextForCommand(VisitableCommand, Address) - Method in interface org.infinispan.context.InvocationContextFactory
As InvocationContextFactory.createRemoteInvocationContext(org.infinispan.remoting.transport.Address), but returning the flags to the context from the Command if any Flag was set.
createRemoteTxInvocationContext(RemoteTransaction, Address) - Method in class org.infinispan.context.impl.NonTransactionalInvocationContextFactory
 
createRemoteTxInvocationContext(RemoteTransaction, Address) - Method in class org.infinispan.context.impl.TransactionalInvocationContextFactory
 
createRemoteTxInvocationContext(RemoteTransaction, Address) - Method in interface org.infinispan.context.InvocationContextFactory
createRequestState(ByteString, ByteString) - Static method in class org.infinispan.xsite.events.XSiteEvent
 
createSaslServer(String, String, String, Map<String, ?>, CallbackHandler) - Method in class org.infinispan.server.core.security.external.ExternalSaslServerFactory
 
createSaslServer(String, List<Principal>, String, String, Map<String, String>) - Method in interface org.infinispan.server.core.security.ServerAuthenticationProvider
Create a SaslServer, to be used for a single authentication session, for the specified mechanismName.
createScope(Class<E>, Collection<String>) - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
 
createScope(Class<E>, Collection<String>) - Method in interface org.infinispan.search.mapper.session.impl.InfinispanSearchSessionMappingContext
 
createScope(Collection<? extends Class<? extends E>>) - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
 
createScope(Collection<? extends Class<? extends E>>) - Method in interface org.infinispan.search.mapper.session.impl.InfinispanSearchSessionMappingContext
 
createSegmentBasedCollector(long, Map<Address, Collection<Integer>>, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
Creates a collector for PutMapCommand.
createServerSocket(String) - Method in class org.infinispan.remoting.transport.jgroups.NamedSocketFactory
 
createServerSocket(String, int) - Method in class org.infinispan.remoting.transport.jgroups.NamedSocketFactory
 
createServerSocket(String, int, int) - Method in class org.infinispan.remoting.transport.jgroups.NamedSocketFactory
 
createServerSocket(String, int, int, InetAddress) - Method in class org.infinispan.remoting.transport.jgroups.NamedSocketFactory
 
createSession() - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository
 
createSingleKeyNonTxInvocationContext() - Method in class org.infinispan.context.impl.NonTransactionalInvocationContextFactory
 
createSingleKeyNonTxInvocationContext() - Method in class org.infinispan.context.impl.TransactionalInvocationContextFactory
 
createSingleKeyNonTxInvocationContext() - Method in interface org.infinispan.context.InvocationContextFactory
createsNonBlockingThreads() - Method in class org.infinispan.commons.executors.BlockingThreadPoolExecutorFactory
Deprecated.
 
createsNonBlockingThreads() - Method in interface org.infinispan.commons.executors.ThreadPoolExecutorFactory
 
createsNonBlockingThreads() - Method in class org.infinispan.factories.threads.NonBlockingThreadPoolExecutorFactory
 
createSocket(String) - Method in class org.infinispan.remoting.transport.jgroups.NamedSocketFactory
 
createSocket(String, String, int) - Method in class org.infinispan.remoting.transport.jgroups.NamedSocketFactory
 
createSocket(String, String, int, InetAddress, int) - Method in class org.infinispan.remoting.transport.jgroups.NamedSocketFactory
 
createSocket(String, InetAddress, int) - Method in class org.infinispan.remoting.transport.jgroups.NamedSocketFactory
 
createSocket(String, InetAddress, int, InetAddress, int) - Method in class org.infinispan.remoting.transport.jgroups.NamedSocketFactory
 
CreateStateFunction - Class in org.infinispan.server.hotrod.tx.table.functions
It creates a new TxState.
CreateStateFunction(GlobalTransaction, boolean, long) - Constructor for class org.infinispan.server.hotrod.tx.table.functions.CreateStateFunction
 
createStoreInstance(StoreConfiguration) - Static method in class org.infinispan.persistence.internal.PersistenceUtil
Deprecated.
This method is only public for use with prior Store classes, use PersistenceUtil.storeFromConfiguration(StoreConfiguration) when dealing with NonBlockingStore instances
createTableOperations(InitializationContext, C) - Method in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
Extension point to allow for initializing and creating a table operations object.
createTableOperations(InitializationContext, C) - Method in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore
 
createTableOperations(InitializationContext, JdbcStringBasedStoreConfiguration) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
createTemplate(String, A) - Method in interface org.infinispan.commons.api.CacheContainerAdmin
Creates a template on the container using the provided configuration.
createTemplate(String, BasicConfiguration) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
 
createTemplate(String, Configuration) - Method in class org.infinispan.manager.DefaultCacheManagerAdmin
 
createTemplate(String, Configuration) - Method in interface org.infinispan.manager.EmbeddedCacheManagerAdmin
Creates a template that is replicated across the cluster using the specified configuration.
createTemplate(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.GlobalConfigurationManager
Defines a cluster-wide configuration template
createTemplate(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.GlobalConfigurationManagerImpl
 
createTemplate(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.ImmutableLocalConfigurationStorage
 
createTemplate(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.OverlayLocalConfigurationStorage
 
createTemplate(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
 
createTemplate(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.LocalConfigurationStorage
Creates the template using the supplied configuration and flags.
createThread(ThreadGroup, Runnable, boolean) - Static method in class org.infinispan.commons.jdkspecific.ThreadCreator
 
createTopologyCacheConfig(long) - Method in class org.infinispan.server.hotrod.HotRodServer
 
createTransaction() - Method in class org.infinispan.client.hotrod.transaction.manager.RemoteTransactionManager
 
createTransaction() - Method in class org.infinispan.commons.tx.TransactionManagerImpl
 
createTransaction() - Method in class org.infinispan.transaction.tm.EmbeddedBaseTransactionManager
 
createTxInvocationContext(LocalTransaction) - Method in class org.infinispan.context.impl.NonTransactionalInvocationContextFactory
 
createTxInvocationContext(LocalTransaction) - Method in class org.infinispan.context.impl.TransactionalInvocationContextFactory
 
createTxInvocationContext(LocalTransaction) - Method in interface org.infinispan.context.InvocationContextFactory
createUnmarshaller(MarshallingConfiguration) - Method in class org.infinispan.jboss.marshalling.commons.JBossMarshallerFactory
 
createURLStreamHandler(String) - Method in class org.infinispan.commons.jdkspecific.ClasspathURLStreamHandlerProvider
 
createURLStreamHandler(String) - Method in class org.infinispan.commons.util.ClasspathURLStreamHandler
 
createValue(CacheEntry) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
 
createValue(CacheEntry<?, V>) - Method in interface org.infinispan.container.impl.InternalEntryFactory
Creates an InternalCacheValue based on the InternalCacheEntry passed in.
createWrappedEntry(Object, CacheEntry<?, ?>) - Method in class org.infinispan.container.impl.EntryFactoryImpl
 
createWriter(OutputStream) - Method in class org.infinispan.server.core.dataconversion.xml.MXParserDriver
 
createWriter(Writer) - Method in class org.infinispan.server.core.dataconversion.xml.MXParserDriver
 
createXid(UUID) - Static method in class org.infinispan.transaction.tm.EmbeddedTransaction
 
CRLF - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
 
CRLFBytes - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
 
CrossSiteIllegalLifecycleStateException - Exception Class in org.infinispan.commons
This exception is thrown when the cache or cache manager does not have the right lifecycle state for cross-site operations to be called on it.
CrossSiteIllegalLifecycleStateException() - Constructor for exception class org.infinispan.commons.CrossSiteIllegalLifecycleStateException
 
CrossSiteIllegalLifecycleStateException(String) - Constructor for exception class org.infinispan.commons.CrossSiteIllegalLifecycleStateException
 
CrossSiteIllegalLifecycleStateException(String, Throwable) - Constructor for exception class org.infinispan.commons.CrossSiteIllegalLifecycleStateException
 
CrossSiteIllegalLifecycleStateException(Throwable) - Constructor for exception class org.infinispan.commons.CrossSiteIllegalLifecycleStateException
 
ctx - Variable in class org.infinispan.persistence.file.SingleFileStore
 
ctx - Variable in class org.infinispan.persistence.remote.RemoteStore
 
ctx - Variable in class org.infinispan.persistence.support.DelegatingCacheLoader
 
ctx - Variable in class org.infinispan.persistence.support.DelegatingCacheWriter
 
CURRENT_NR_OF_ENTRIES - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
Deprecated, for removal: This API element is subject to removal in a future version.
currentIndent - Variable in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
 
currentJoiners(String) - Method in interface org.infinispan.topology.ClusterTopologyManager
Returns the list of nodes that joined the cache with the given cacheName if the current node is the coordinator.
currentJoiners(String) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
currentMillisFromNanotime() - Static method in class org.infinispan.commons.util.Util
System.nanoTime() is less expensive than System.currentTimeMillis() and better suited to measure time intervals.
currentSize - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
currentValue - Variable in class org.infinispan.commons.util.RemovableIterator
 
CUSTOM - Enum constant in enum org.infinispan.configuration.cache.BackupFailurePolicy
 
CUSTOM - Enum constant in enum org.infinispan.conflict.MergePolicy
 
CUSTOM - Enum constant in enum org.infinispan.globalstate.ConfigurationStorage
Lets you provide a configuration storage provider.
CUSTOM_CONFIGURATION_STORAGE - Enum constant in enum org.infinispan.configuration.parsing.Element
 
CUSTOM_INTERCEPTORS - Enum constant in enum org.infinispan.configuration.parsing.Element
 
CUSTOM_PERMISSION_MAPPER - Enum constant in enum org.infinispan.configuration.parsing.Element
 
CUSTOM_ROLE_MAPPER - Enum constant in enum org.infinispan.configuration.parsing.Element
 
CUSTOM_STORE_CLASS - Static variable in class org.infinispan.configuration.cache.CustomStoreConfiguration
 
customDecodeKey(ChannelHandlerContext, ByteBuf) - Method in class org.infinispan.server.memcached.MemcachedDecoder
 
customDecodeValue(ChannelHandlerContext, ByteBuf) - Method in class org.infinispan.server.memcached.MemcachedDecoder
 
CustomEventImpl<T> - Class in org.infinispan.client.hotrod.event.impl
 
CustomEventImpl(byte[], T, boolean, ClientEvent.Type) - Constructor for class org.infinispan.client.hotrod.event.impl.CustomEventImpl
 
CustomFailurePolicy<K,V> - Interface in org.infinispan.configuration.cache
Used for implementing custom policies in case of communication failures with a remote site.
customInterceptors() - Method in class org.infinispan.configuration.cache.AbstractCustomInterceptorsConfigurationChildBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationChildBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.AbstractPersistenceConfigurationChildBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.remote.configuration.AbstractSecurityConfigurationChildBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.AbstractTransportConfigurationChildBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.BackupForBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.security.impl.CreatePermissionConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.CustomStoreConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.IndexReaderConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder.StringTableManipulationConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.jdbc.common.configuration.ManagedConnectionFactoryConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.remote.configuration.MechanismConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.MemoryStorageConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.QueryConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.SecurityConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.parsing.SFSToSIFSConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.StatisticsConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.persistence.remote.configuration.TrustStoreConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.Configuration
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customInterceptors() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
CustomInterceptorsConfiguration - Class in org.infinispan.configuration.cache
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
CustomInterceptorsConfigurationBuilder - Class in org.infinispan.configuration.cache
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
customStoreClass() - Method in class org.infinispan.configuration.cache.CustomStoreConfiguration
 
customStoreClass(Class<?>) - Method in class org.infinispan.configuration.cache.CustomStoreConfigurationBuilder
 
CustomStoreConfiguration - Class in org.infinispan.configuration.cache
 
CustomStoreConfiguration(AttributeSet, AsyncStoreConfiguration) - Constructor for class org.infinispan.configuration.cache.CustomStoreConfiguration
 
CustomStoreConfigurationBuilder - Class in org.infinispan.configuration.cache
StoreConfigurationBuilder used for stores/loaders that don't have a configuration builder
CustomStoreConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.CustomStoreConfigurationBuilder
 
CyclicDependencyException - Exception Class in org.infinispan.util
Thrown when a cyclic dependency exist
CyclicDependencyException(String) - Constructor for exception class org.infinispan.util.CyclicDependencyException
 
CyclicDependencyException(String, Throwable) - Constructor for exception class org.infinispan.util.CyclicDependencyException
 

D

data - Variable in class org.infinispan.io.GridFilesystem
Deprecated.
 
data - Variable in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
 
data() - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfiguration
 
DATA - Enum constant in enum org.infinispan.configuration.parsing.Element
 
DATA_COLUMN - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
 
DATA_COLUMN_NAME - Static variable in class org.infinispan.persistence.jdbc.configuration.DataColumnConfiguration
 
DATA_COLUMN_TYPE - Static variable in class org.infinispan.persistence.jdbc.configuration.DataColumnConfiguration
 
DATA_CONTAINER - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
DATA_CONTAINER - Enum constant in enum org.infinispan.configuration.parsing.Element
 
DATA_CONVERSION - Static variable in interface org.infinispan.commons.marshall.Ids
 
DATA_DISTRIBUTION_LOWER_BOUND - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
DATA_LOCATION - Static variable in class org.infinispan.persistence.sifs.configuration.DataConfiguration
 
DATA_REHASHED - Enum constant in enum org.infinispan.notifications.cachelistener.event.Event.Type
 
DATA_SOURCE - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
 
DatabaseType - Enum in org.infinispan.persistence.jdbc.common
Supported database dialects for the JDBC cache stores
dataColumnConfiguration() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
DataColumnConfiguration - Class in org.infinispan.persistence.jdbc.configuration
 
DataColumnConfiguration(AttributeSet) - Constructor for class org.infinispan.persistence.jdbc.configuration.DataColumnConfiguration
 
DataColumnConfigurationBuilder - Class in org.infinispan.persistence.jdbc.configuration
 
dataColumnName() - Method in class org.infinispan.persistence.jdbc.configuration.DataColumnConfiguration
 
dataColumnName() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
dataColumnName() - Method in class org.infinispan.persistence.jdbc.configuration.TimestampColumnConfiguration
 
dataColumnName(String) - Method in class org.infinispan.persistence.jdbc.configuration.DataColumnConfigurationBuilder
 
dataColumnName(String) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
The name of the database column used to store the entries
dataColumnName(String) - Method in class org.infinispan.persistence.jdbc.configuration.TimestampColumnConfigurationBuilder
 
dataColumnType() - Method in class org.infinispan.persistence.jdbc.configuration.DataColumnConfiguration
 
dataColumnType() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
dataColumnType() - Method in class org.infinispan.persistence.jdbc.configuration.TimestampColumnConfiguration
 
dataColumnType(String) - Method in class org.infinispan.persistence.jdbc.configuration.DataColumnConfigurationBuilder
 
dataColumnType(String) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
The type of the database column used to store the entries
dataColumnType(String) - Method in class org.infinispan.persistence.jdbc.configuration.TimestampColumnConfigurationBuilder
 
DataCommand - Interface in org.infinispan.commands
Commands of this type manipulate data in the cache.
DataConfiguration - Class in org.infinispan.persistence.sifs.configuration
 
DataConfigurationBuilder - Class in org.infinispan.persistence.sifs.configuration
 
DataConfigurationBuilder() - Constructor for class org.infinispan.persistence.sifs.configuration.DataConfigurationBuilder
 
dataContainer - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
dataContainer - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
DataContainer<K,V> - Interface in org.infinispan.container
The main internal data structure which stores entries.
DataContainer.ComputeAction<K,V> - Interface in org.infinispan.container
 
DataContainerFactory - Class in org.infinispan.factories
Constructs the data container
DataContainerFactory() - Constructor for class org.infinispan.factories.DataContainerFactory
 
DataContainerRemoveIterator<K,V> - Class in org.infinispan.util
This is an iterator that will iterate upon the data container.
DataContainerRemoveIterator(Cache<K, V>) - Constructor for class org.infinispan.util.DataContainerRemoveIterator
 
DataContainerRemoveIterator(Cache<K, V>, DataContainer<K, V>) - Constructor for class org.infinispan.util.DataContainerRemoveIterator
 
DataConversion - Class in org.infinispan.encoding
Handle conversions for Keys or values.
DataConversion.Externalizer - Class in org.infinispan.encoding
 
DataConversionAwareListenable<K,V> - Interface in org.infinispan.notifications
 
dataDbOptions() - Method in class org.infinispan.persistence.rocksdb.RocksDBStore
 
DataDistributionContextInitializer - Interface in org.infinispan.rest.distribution
 
DataDistributionContextInitializerImpl - Class in org.infinispan.rest.distribution
WARNING: Generated code! Do not edit!
DataDistributionContextInitializerImpl() - Constructor for class org.infinispan.rest.distribution.DataDistributionContextInitializerImpl
 
DataFormat - Class in org.infinispan.client.hotrod
Defines data format for keys and values during Hot Rod client requests.
DataFormat.Builder - Class in org.infinispan.client.hotrod
 
datagramChannelClass() - Method in interface org.infinispan.client.hotrod.TransportFactory
Returns the Netty DatagramChannel class to use for DNS resolution.
DataLocality - Enum in org.infinispan.distribution
Deprecated.
Since 11.0. Will be removed in 14.0, no longer used.
dataLocation() - Method in class org.infinispan.persistence.sifs.configuration.DataConfiguration
 
dataLocation() - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfiguration
 
dataLocation(String) - Method in class org.infinispan.persistence.sifs.configuration.DataConfigurationBuilder
 
dataLocation(String) - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
The path where the Soft-Index store will keep its data files.
DataOperationOrderer - Class in org.infinispan.util.concurrent
Ordering construct allowing concurrent operations that wish to do operations upon the same key to wait until the most recently registered operation is complete in a non blocking way.
DataOperationOrderer() - Constructor for class org.infinispan.util.concurrent.DataOperationOrderer
 
DataOperationOrderer.Operation - Enum in org.infinispan.util.concurrent
 
dataRead(boolean, long, int) - Method in class org.infinispan.client.hotrod.impl.ClientStatistics
 
DataRehashed - Annotation Type in org.infinispan.notifications.cachelistener.annotation
This annotation should be used on methods that need to be notified when a rehash starts or ends.
DataRehashedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
An event passed in to methods annotated with DataRehashed.
dataRemove(long, int) - Method in class org.infinispan.client.hotrod.impl.ClientStatistics
 
dataSource() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
 
dataSource() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationChildBuilder
 
dataSource() - Method in interface org.infinispan.persistence.jdbc.common.configuration.JdbcStoreConfigurationChildBuilder
Configures a DataSource to be used by this JDBC Cache Store to handle connections to the database
dataSource() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder.StringTableManipulationConfigurationBuilder
 
dataSourceTestFail(String) - Method in class org.infinispan.rest.logging.Messages_$bundle
 
dataSourceTestFail(String) - Method in interface org.infinispan.rest.logging.Messages
 
dataSourceTestFail$str() - Method in class org.infinispan.rest.logging.Messages_$bundle
 
dataSourceTestOk(String) - Method in class org.infinispan.rest.logging.Messages_$bundle
 
dataSourceTestOk(String) - Method in interface org.infinispan.rest.logging.Messages
 
dataSourceTestOk$str() - Method in class org.infinispan.rest.logging.Messages_$bundle
 
dataStore(long, int) - Method in class org.infinispan.client.hotrod.impl.ClientStatistics
 
DATE - Enum constant in enum org.infinispan.persistence.sql.AbstractSchemaJdbcStore.ProtostreamFieldType
 
DATE_HEADER - Enum constant in enum org.infinispan.rest.ResponseHeader
 
DateUtils - Class in org.infinispan.rest
 
DAYS - Enum constant in enum org.infinispan.server.hotrod.TimeUnitValue
 
DB_MAJOR_VERSION - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
 
DB_MINOR_VERSION - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
 
DB2 - Enum constant in enum org.infinispan.persistence.jdbc.common.DatabaseType
 
DB2_390 - Enum constant in enum org.infinispan.persistence.jdbc.common.DatabaseType
 
dbMajorVersion() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfiguration
Deprecated.
since 14.0, always returns null
dbMajorVersion(Integer) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
since 14.0 is ignored
dbMinorVersion() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
since 14.0, always returns null
dbMinorVersion(Integer) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
since 14.0 is ignored
DDAsyncInterceptor - Class in org.infinispan.interceptors
Interface for async interceptors using double-dispatch.
DDAsyncInterceptor() - Constructor for class org.infinispan.interceptors.DDAsyncInterceptor
 
DEADLOCK_DETECTING_GLOBAL_TRANSACTION - Static variable in interface org.infinispan.commons.marshall.Ids
 
deadlockCheck(DeadlockChecker) - Method in class org.infinispan.util.concurrent.locks.impl.InfinispanLock
It forces a deadlock checking.
deadlockCheck(DeadlockChecker) - Method in interface org.infinispan.util.concurrent.locks.impl.LockContainer
It forces a deadlock checks in all existing locks.
deadlockCheck(DeadlockChecker) - Method in class org.infinispan.util.concurrent.locks.impl.PerKeyLockContainer
 
deadlockCheck(DeadlockChecker) - Method in class org.infinispan.util.concurrent.locks.impl.StripedLockContainer
 
DeadlockChecker - Interface in org.infinispan.util.concurrent.locks
An interface to implement the deadlock algorithm.
deadlockDetected(Object, Object) - Method in interface org.infinispan.util.concurrent.locks.DeadlockChecker
It checks for deadlock.
DeadlockDetectedException - Exception Class in org.infinispan.util.concurrent.locks
Exception signaling detected deadlocks.
DeadlockDetectedException(String) - Constructor for exception class org.infinispan.util.concurrent.locks.DeadlockDetectedException
 
DEADLOCKED - Enum constant in enum org.infinispan.util.concurrent.locks.LockState
The deadlock occurred with another possible lock owner and it should abort.
deallocate() - Method in class org.infinispan.container.offheap.MemoryAddressHash
 
deallocate(long, long) - Method in interface org.infinispan.container.offheap.OffHeapMemoryAllocator
Deallocates the memory at the given address assuming a given size.
deallocate(long, long) - Method in class org.infinispan.container.offheap.UnpooledOffHeapMemoryAllocator
 
DebuggingExceptionListener() - Constructor for class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller.DebuggingExceptionListener
 
dec() - Method in class org.infinispan.commons.util.ByRef.Integer
 
dec() - Method in class org.infinispan.commons.util.ByRef.Long
 
DECISION_FUNCTION - Static variable in class org.infinispan.server.core.ExternalizerIds
 
decode(byte) - Static method in enum org.infinispan.server.hotrod.TimeUnitValue
 
decode(int) - Static method in class org.infinispan.commons.io.SignedNumeric
 
decode(int) - Method in class org.infinispan.counter.api.CounterState$___Marshaller_93aa5d27c0d57954ec79247b055254b02d5c87a64e0764e392772b387eb7542d
 
decode(int) - Method in class org.infinispan.counter.api.CounterType$___Marshaller_4dd4ef0972bf79fd96da56b8ce9348d84b1c42596acd7df3abf86c5e467887f5
 
decode(int) - Method in class org.infinispan.counter.api.Storage$___Marshaller_ed04a8616efd062a7c88e9e578efa97c99224ac3211dd20ca76376455f84a9ae
 
decode(int) - Method in class org.infinispan.security.AuthorizationPermission$___Marshaller_e4a67ef18a1f2ebc30b0d1e396f24e2098535911da768fa734361c9903b14240
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.infinispan.server.core.transport.SaslQopHandler
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.infinispan.server.hotrod.HotRodDecoder
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.infinispan.server.memcached.MemcachedDecoder
 
decode(String) - Static method in class org.infinispan.commons.dataconversion.Base16Codec
 
DECODE_HEADER - Enum constant in enum org.infinispan.server.hotrod.HotRodDecoderState
 
DECODE_HEADER - Enum constant in enum org.infinispan.server.memcached.MemcachedDecoderState
 
DECODE_HEADER_CUSTOM - Enum constant in enum org.infinispan.server.hotrod.HotRodDecoderState
 
DECODE_KEY - Enum constant in enum org.infinispan.server.hotrod.HotRodDecoderState
 
DECODE_KEY - Enum constant in enum org.infinispan.server.memcached.MemcachedDecoderState
 
DECODE_KEY_CUSTOM - Enum constant in enum org.infinispan.server.hotrod.HotRodDecoderState
 
DECODE_PARAMETERS - Enum constant in enum org.infinispan.server.hotrod.HotRodDecoderState
 
DECODE_PARAMETERS - Enum constant in enum org.infinispan.server.memcached.MemcachedDecoderState
 
DECODE_VALUE - Enum constant in enum org.infinispan.server.hotrod.HotRodDecoderState
 
DECODE_VALUE - Enum constant in enum org.infinispan.server.memcached.MemcachedDecoderState
 
DECODE_VALUE_CUSTOM - Enum constant in enum org.infinispan.server.hotrod.HotRodDecoderState
 
decodeConfiguration(Supplier<Byte>, LongSupplier, IntSupplier) - Static method in class org.infinispan.counter.util.EncodeUtil
decodeContent(Object, MediaType) - Method in class org.infinispan.commons.dataconversion.AbstractTranscoder
Decodes content before doing the transcoding.
decodeNewState(byte) - Static method in class org.infinispan.server.hotrod.counter.listener.ClientCounterEvent
 
decodeObjectContent(Object, MediaType) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
Deprecated, for removal: This API element is subject to removal in a future version.
Since 13.0, without replacement.
decodeOctetStream(Object, MediaType) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
Deprecated, for removal: This API element is subject to removal in a future version.
Since 13.0, without replacement.
decodeOldState(byte) - Static method in class org.infinispan.server.hotrod.counter.listener.ClientCounterEvent
 
decodePair(byte) - Static method in enum org.infinispan.server.hotrod.TimeUnitValue
 
decoder - Variable in class org.infinispan.server.core.transport.NettyChannelInitializer
 
decoderResult() - Method in class org.infinispan.rest.ServerSentEvent
 
decodeStorage(byte) - Static method in class org.infinispan.counter.util.EncodeUtil
Decodes the CounterType.
decodeType(byte) - Static method in class org.infinispan.counter.util.EncodeUtil
Decodes the Storage.
decodeVersion(short) - Static method in class org.infinispan.commons.util.Version
 
decodeVersion(short) - Static method in class org.infinispan.Version
Deprecated.
 
decodeVersionForSerialization(short) - Static method in class org.infinispan.commons.util.Version
Serialization only looks at major and minor, not micro or below.
decodeVersionForSerialization(short) - Static method in class org.infinispan.Version
Deprecated.
Serialization only looks at major and minor, not micro or below.
decorateCache(AdvancedCache<K, V>) - Method in class org.infinispan.server.hotrod.tx.PrepareCoordinator
Decorates the cache with the transaction created.
DecoratedCache<K,V> - Class in org.infinispan.cache.impl
A decorator to a cache, which can be built with a specific set of Flags.
DecoratedCache(CacheImpl<K, V>, long) - Constructor for class org.infinispan.cache.impl.DecoratedCache
 
DecoratedCache(CacheImpl<K, V>, Object, long) - Constructor for class org.infinispan.cache.impl.DecoratedCache
 
decoratedWriteContextBuilder() - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
 
decOwned(int) - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
 
decOwned(Address) - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
 
decPrimaryOwned(int) - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
 
decPrimaryOwned(Address) - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
 
decrement() - Method in interface org.infinispan.counter.api.SyncWeakCounter
 
decrement() - Method in interface org.infinispan.counter.api.WeakCounter
Decrements the counter.
decrement() - Method in class org.infinispan.util.concurrent.CountDownRunnable
 
decrementAndGet() - Method in interface org.infinispan.counter.api.StrongCounter
Atomically decrements the counter and returns the new value
decrementAndGet() - Method in interface org.infinispan.counter.api.SyncStrongCounter
 
DecrementRequest - Enum constant in enum org.infinispan.server.memcached.MemcachedOperation
 
DEF_CLASS_COUNT - Static variable in class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller
 
DEF_INSTANCE_COUNT - Static variable in class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller
 
DEFAULT - Enum constant in enum org.infinispan.configuration.global.ShutdownHookBehavior
By default a shutdown hook is registered if no MBean server (apart from the JDK default) is detected.
DEFAULT - Enum constant in enum org.infinispan.configuration.parsing.Element
 
DEFAULT - Enum constant in enum org.infinispan.server.hotrod.TimeUnitValue
 
DEFAULT - Enum constant in enum org.infinispan.xsite.spi.XSiteMergePolicy
The default implementation chooses the entry with the lower lexicographically site name (SiteEntry.getSiteName()).
DEFAULT - Static variable in interface org.infinispan.client.hotrod.TransportFactory
 
DEFAULT - Static variable in interface org.infinispan.commons.configuration.attributes.AttributeParser
 
DEFAULT - Static variable in interface org.infinispan.commons.configuration.attributes.AttributeSerializer
 
DEFAULT - Static variable in class org.infinispan.commons.configuration.Combine
 
DEFAULT - Static variable in interface org.infinispan.commons.configuration.io.ConfigurationResourceResolver
Deprecated, for removal: This API element is subject to removal in a future version.
DEFAULT - Static variable in class org.infinispan.commons.configuration.io.ConfigurationResourceResolvers
 
DEFAULT - Static variable in interface org.infinispan.commons.configuration.io.PropertyReplacer
 
DEFAULT_BATCH_SIZE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DEFAULT_BUFFER_SIZE - Static variable in class org.infinispan.util.stream.Streams
Deprecated.
The default buffer size that will be used for buffered operations.
DEFAULT_CACHE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
DEFAULT_CACHE_NAME - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
 
DEFAULT_CACHE_NAME - Static variable in annotation type org.infinispan.spring.embedded.session.configuration.EnableInfinispanEmbeddedHttpSession
 
DEFAULT_CACHE_NAME - Static variable in annotation type org.infinispan.spring.remote.session.configuration.EnableInfinispanRemoteHttpSession
 
DEFAULT_CHUNK_SIZE - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
DEFAULT_CONNECT_TIMEOUT - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DEFAULT_CONSISTENT_HASH - Static variable in interface org.infinispan.commons.marshall.Ids
 
DEFAULT_CONSISTENT_HASH_FACTORY - Static variable in interface org.infinispan.commons.marshall.Ids
 
DEFAULT_CONSISTENT_HASH_VERSION - Static variable in class org.infinispan.server.hotrod.Constants
 
DEFAULT_CONSISTENT_HASH_VERSION_1x - Static variable in class org.infinispan.server.hotrod.Constants
 
DEFAULT_DOUBLING_SIZE - Static variable in class org.infinispan.commons.io.ExposedByteArrayOutputStream
Deprecated.
Default buffer size after which if more buffer capacity is needed the buffer will grow by 25% rather than 100%
DEFAULT_DOUBLING_SIZE - Static variable in class org.infinispan.commons.io.LazyByteArrayOutputStream
Default buffer size after which if more buffer capacity is needed the buffer will grow by 25% rather than 100%
DEFAULT_DOUBLING_SIZE - Static variable in class org.infinispan.io.ExpandableMarshalledValueByteStream
Deprecated.
Default buffer size after which if more buffer capacity is needed the buffer will grow by 25% rather than 100%
DEFAULT_EXECUTOR_FACTORY_POOL_SIZE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DEFAULT_EXECUTOR_FACTORY_THREADNAME_PREFIX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DEFAULT_EXECUTOR_FACTORY_THREADNAME_SUFFIX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DEFAULT_HOTROD_PORT - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DEFAULT_HOTROD_PORT - Static variable in class org.infinispan.server.hotrod.HotRodServer
 
DEFAULT_JGROUPS_CONFIGURATION_FILE - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
DEFAULT_KEEP_ALIVE_MILLIS - Static variable in class org.infinispan.commons.executors.BlockingThreadPoolExecutorFactory
Deprecated.
 
DEFAULT_KEEP_ALIVE_MILLIS - Static variable in class org.infinispan.factories.threads.NonBlockingThreadPoolExecutorFactory
 
DEFAULT_KEY - Static variable in class org.infinispan.encoding.DataConversion
Deprecated, for removal: This API element is subject to removal in a future version.
Since 11.0. To be removed in 14.0, with no replacement.
DEFAULT_KEY_SIZE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
Deprecated, for removal: This API element is subject to removal in a future version.
Since 12.0, does nothing and will be removed in 15.0
DEFAULT_LIFESPAN - Enum constant in enum org.infinispan.client.hotrod.Flag
This flag can either be used as a request flag during a put operation to mean that the default server lifespan should be applied or as a response flag meaning that the return entry has a default lifespan value
DEFAULT_MARSHALL_VERSION - Static variable in class org.infinispan.configuration.global.GlobalConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
Since 9.4, use Version.getVersionShort() instead.
DEFAULT_MAX_ACTIVE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DEFAULT_MAX_PENDING_REQUESTS - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DEFAULT_MAX_RESULTS - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
DEFAULT_MAX_RESULTS - Static variable in class org.infinispan.configuration.cache.QueryConfiguration
 
DEFAULT_MAX_RETRIES - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DEFAULT_MAX_RETRIES - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
DEFAULT_MAX_WAIT - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DEFAULT_MAXIDLE - Enum constant in enum org.infinispan.client.hotrod.Flag
This flag can either be used as a request flag during a put operation to mean that the default server maxIdle should be applied or as a response flag meaning that the return entry has a default maxIdle value
DEFAULT_MECHANISM - Static variable in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
 
DEFAULT_MEMCACHED_CACHE - Static variable in class org.infinispan.server.memcached.configuration.MemcachedServerConfiguration
 
DEFAULT_MEMCACHED_PORT - Static variable in class org.infinispan.server.memcached.configuration.MemcachedServerConfiguration
 
DEFAULT_MIN_EVICTABLE_IDLE_TIME - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DEFAULT_MIN_IDLE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DEFAULT_PATTERN - Static variable in class org.infinispan.factories.threads.DefaultThreadFactory
 
DEFAULT_PROTOCOL_VERSION - Static variable in enum org.infinispan.client.hotrod.ProtocolVersion
 
DEFAULT_REALM - Static variable in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
 
DEFAULT_RECOVERY_INFO_CACHE - Static variable in class org.infinispan.configuration.cache.RecoveryConfiguration
 
DEFAULT_RESOURCE - Static variable in class org.infinispan.rest.resources.StaticContentResource
 
DEFAULT_ROLES - Static variable in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
DEFAULT_SERVER_NAME - Static variable in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
 
DEFAULT_SIZE - Static variable in class org.infinispan.commons.io.LazyByteArrayOutputStream
 
DEFAULT_SNI_DOMAIN - Static variable in class org.infinispan.server.core.configuration.SslConfiguration
 
DEFAULT_SO_TIMEOUT - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DEFAULT_STACK - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
DEFAULT_STALE_STATS_THRESHOLD - Static variable in class org.infinispan.stats.impl.AbstractClusterStats
 
DEFAULT_STALE_STATS_THRESHOLD - Static variable in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
DEFAULT_STALE_STATS_THRESHOLD - Static variable in class org.infinispan.stats.impl.ClusterContainerStatsImpl
 
DEFAULT_STALE_STATS_THRESHOLD - Static variable in class org.infinispan.stats.impl.LocalContainerStatsImpl
 
DEFAULT_TIMEOUT - Static variable in class org.infinispan.client.hotrod.configuration.TransactionConfigurationBuilder
Deprecated.
 
DEFAULT_TIMEOUT - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
DEFAULT_TOP_KEY - Static variable in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
 
DEFAULT_TOPOLOGY_ID - Static variable in class org.infinispan.server.hotrod.Constants
 
DEFAULT_TRACING_PROPAGATION_ENABLED - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DEFAULT_TRANSPORT - Static variable in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
DEFAULT_VALUE - Static variable in class org.infinispan.encoding.DataConversion
Deprecated, for removal: This API element is subject to removal in a future version.
Since 11.0. To be removed in 14.0, with no replacement.
DEFAULT_VALUE_SIZE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
Deprecated, for removal: This API element is subject to removal in a future version.
Since 12.0, does nothing and will be removed in 15.0
DEFAULT_WAIT_TIME - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
 
DefaultAnalysisConfigurer - Class in org.infinispan.search.mapper.mapping.impl
 
DefaultAnalysisConfigurer() - Constructor for class org.infinispan.search.mapper.mapping.impl.DefaultAnalysisConfigurer
 
DefaultAnalysisConfigurer.ConfigurableBufferSizeKeywordTokenizerFactory - Class in org.infinispan.search.mapper.mapping.impl
Similar to KeywordTokenizerFactory but with a configurable buffer size.
DefaultBuilder() - Constructor for class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl.DefaultBuilder
 
defaultCache(String) - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
 
DefaultCacheManager - Class in org.infinispan.manager
A CacheManager is the primary mechanism for retrieving a Cache instance, and is often used as a starting point to using the Cache.
DefaultCacheManager() - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs and starts a default instance of the CacheManager, using configuration defaults.
DefaultCacheManager(boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs a default instance of the CacheManager, using configuration defaults.
DefaultCacheManager(InputStream) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs and starts a new instance of the CacheManager, using the input stream passed in to read configuration file contents.
DefaultCacheManager(InputStream, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs a new instance of the CacheManager, using the input stream passed in to read configuration file contents.
DefaultCacheManager(String) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs and starts a new instance of the CacheManager, using the configuration file name passed in.
DefaultCacheManager(String, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs a new instance of the CacheManager, using the configuration file name passed in.
DefaultCacheManager(URL, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs a new instance of the CacheManager, using the input stream passed in to read configuration file contents.
DefaultCacheManager(Configuration) - Constructor for class org.infinispan.manager.DefaultCacheManager
Deprecated, for removal: This API element is subject to removal in a future version.
DefaultCacheManager(Configuration, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Deprecated, for removal: This API element is subject to removal in a future version.
DefaultCacheManager(GlobalConfiguration) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs and starts a new instance of the CacheManager, using the global configuration passed in, and system defaults for the default named cache configuration.
DefaultCacheManager(GlobalConfiguration, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs a new instance of the CacheManager, using the global configuration passed in, and system defaults for the default named cache configuration.
DefaultCacheManager(GlobalConfiguration, Configuration) - Constructor for class org.infinispan.manager.DefaultCacheManager
Deprecated, for removal: This API element is subject to removal in a future version.
DefaultCacheManager(GlobalConfiguration, Configuration, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Deprecated, for removal: This API element is subject to removal in a future version.
DefaultCacheManager(ConfigurationBuilderHolder, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
Constructs a new instance of the CacheManager, using the holder passed in to read configuration settings.
DefaultCacheManagerAdmin - Class in org.infinispan.manager
The default implementation of EmbeddedCacheManagerAdmin
defaultCacheName() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
 
defaultCacheName() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
defaultCacheName() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
defaultCacheName() - Method in class org.infinispan.server.core.AbstractProtocolServer
 
defaultCacheName() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.CachedThreadPoolConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.GlobalJmxConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.GlobalMetricsConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.GlobalStatePathConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.GlobalStorageConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.JGroupsConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.PrincipalRoleMapperConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.RolePermissionMapperConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.ScheduledThreadPoolConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.StackConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.StackFileConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.TemporaryGlobalStatePathConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.ThreadFactoryConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
defaultCacheName(String) - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
Sets the name of the cache that acts as the default cache and is returned by EmbeddedCacheManager.getCache().
defaultCacheName(String) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
 
defaultCacheName(String) - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
 
defaultCacheName(String) - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
 
defaultCacheName(String) - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
Specifies the cache to use as a default cache for the protocol
defaultChunkSize - Variable in class org.infinispan.io.GridFilesystem
Deprecated.
 
defaultClusteredBuilder() - Static method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
 
defaultClusteredBuilder() - Static method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
defaultConfiguration() - Static method in class org.infinispan.counter.configuration.CounterManagerConfigurationBuilder
 
defaultConfiguration() - Static method in class org.infinispan.lock.configuration.ClusteredLockManagerConfigurationBuilder
 
DefaultConsistentHash - Class in org.infinispan.distribution.ch.impl
Default ConsistentHash implementation.
DefaultConsistentHash(int, int, List<Address>, Map<Address, Float>, List<Address>[]) - Constructor for class org.infinispan.distribution.ch.impl.DefaultConsistentHash
 
DefaultConsistentHash.Externalizer - Class in org.infinispan.distribution.ch.impl
 
DefaultConsistentHashFactory - Class in org.infinispan.distribution.ch.impl
Default implementation of ConsistentHashFactory.
DefaultConsistentHashFactory() - Constructor for class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
 
DefaultConsistentHashFactory.Builder - Class in org.infinispan.distribution.ch.impl
 
DefaultConsistentHashFactory.Externalizer - Class in org.infinispan.distribution.ch.impl
 
defaultContextBuilderForWrite() - Method in class org.infinispan.cache.impl.CacheImpl
 
DefaultContextClassResolver - Class in org.infinispan.jboss.marshalling.commons
This class refines ContextClassLoader to add a default class loader.
DefaultContextClassResolver(ClassLoader) - Constructor for class org.infinispan.jboss.marshalling.commons.DefaultContextClassResolver
 
DefaultDataContainer<K,V> - Class in org.infinispan.container.impl
DefaultDataContainer is both eviction and non-eviction based data container.
DefaultDataContainer(int) - Constructor for class org.infinispan.container.impl.DefaultDataContainer
 
DefaultDataContainer(int, long, EntrySizeCalculator<? super K, ? super V>) - Constructor for class org.infinispan.container.impl.DefaultDataContainer
Method invoked when memory policy is used.
DefaultDataContainer(int, long, EvictionType) - Constructor for class org.infinispan.container.impl.DefaultDataContainer
 
DefaultDataContainer(long, EntrySizeCalculator<? super K, ? super InternalCacheEntry<K, V>>) - Constructor for class org.infinispan.container.impl.DefaultDataContainer
Constructor that allows user to provide a size calculator that also handles the cache entry and metadata.
DefaultExecutorFactory - Class in org.infinispan.executors
Default executor factory that creates executors using the JDK Executors service.
DefaultExecutorFactory() - Constructor for class org.infinispan.executors.DefaultExecutorFactory
 
defaultExpiration(int, int, ProtocolFlag) - Method in class org.infinispan.server.hotrod.HotRodDecoder
 
defaultFactory - Static variable in class org.infinispan.commons.dataconversion.internal.Json
 
DefaultFactory() - Constructor for class org.infinispan.commons.dataconversion.internal.Json.DefaultFactory
 
DefaultFactoryFor - Annotation Type in org.infinispan.factories.annotations
An annotation that is used internally, for defining a DEFAULT factory to be used when constructing components.
DefaultFileLookup() - Constructor for class org.infinispan.commons.util.FileLookupFactory.DefaultFileLookup
 
DefaultIracManager - Class in org.infinispan.xsite.irac
Default implementation of IracManager.
DefaultIracManager(Configuration) - Constructor for class org.infinispan.xsite.irac.DefaultIracManager
 
DefaultIracTombstoneManager - Class in org.infinispan.container.versioning.irac
A default implementation for IracTombstoneManager.
DefaultIracTombstoneManager(Configuration) - Constructor for class org.infinispan.container.versioning.irac.DefaultIracTombstoneManager
 
DefaultIracVersionGenerator - Class in org.infinispan.container.versioning.irac
Default implementation of IracVersionGenerator.
DefaultIracVersionGenerator(int) - Constructor for class org.infinispan.container.versioning.irac.DefaultIracVersionGenerator
 
DefaultIterationManager - Class in org.infinispan.server.hotrod.iteration
 
DefaultIterationManager(TimeService) - Constructor for class org.infinispan.server.hotrod.iteration.DefaultIterationManager
 
defaultLifespan - Variable in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
DefaultLifespan - Enum constant in enum org.infinispan.server.hotrod.ProtocolFlag
 
defaultLoadingContext() - Method in class org.infinispan.search.mapper.session.impl.InfinispanSearchSession
 
DefaultLockManager - Class in org.infinispan.util.concurrent.locks.impl
The default LockManager implementation for transactional and non-transactional caches.
DefaultLockManager() - Constructor for class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
 
DefaultMaxIdle - Enum constant in enum org.infinispan.server.hotrod.ProtocolFlag
 
defaultMaxIdleTime - Variable in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
defaultMaxInactiveInterval - Variable in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository
 
defaultMaxResults() - Method in class org.infinispan.configuration.cache.QueryConfiguration
Limits the number of results returned by a query.
defaultMaxResults() - Method in class org.infinispan.configuration.cache.QueryConfigurationBuilder
 
defaultMaxResults(int) - Method in class org.infinispan.configuration.cache.QueryConfigurationBuilder
Limits the number of results returned by a query.
defaultMetadata - Variable in class org.infinispan.cache.impl.CacheImpl
 
DefaultNearCacheFactory - Class in org.infinispan.client.hotrod.near
 
DefaultNearCacheFactory() - Constructor for class org.infinispan.client.hotrod.near.DefaultNearCacheFactory
 
DefaultPendingLockManager - Class in org.infinispan.util.concurrent.locks.impl
The default implementation for PendingLockManager.
DefaultPendingLockManager() - Constructor for class org.infinispan.util.concurrent.locks.impl.DefaultPendingLockManager
 
DefaultReadyAction - Class in org.infinispan.remoting.inboundhandler.action
A list of Action to be executed to check when it is ready.
DefaultReadyAction(ActionState, Action...) - Constructor for class org.infinispan.remoting.inboundhandler.action.DefaultReadyAction
 
defaultRemoteCache() - Method in class org.infinispan.configuration.cache.BackupForBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Use a named cache with BackupForBuilder.remoteCache(String) instead.
DefaultResourceConverter - Enum in org.infinispan.commons.tx
A default blocking implementation of TransactionResourceConverter.
DefaultResponseGenerator - Class in org.infinispan.remoting.responses
The default response generator for most cache modes
DefaultResponseGenerator() - Constructor for class org.infinispan.remoting.responses.DefaultResponseGenerator
 
DefaultScheduledExecutorFactory - Class in org.infinispan.executors
Creates scheduled executors using the JDK Executors service
DefaultScheduledExecutorFactory() - Constructor for class org.infinispan.executors.DefaultScheduledExecutorFactory
 
DefaultSegmentedDataContainer<K,V> - Class in org.infinispan.container.impl
DataContainer implementation that internally stores entries in an array of maps.
DefaultSegmentedDataContainer(Supplier<PeekableTouchableMap<K, V>>, int) - Constructor for class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
DefaultSimpleStat - Class in org.infinispan.commons.stat
A default SimpleStat implementation.
DefaultSimpleStat() - Constructor for class org.infinispan.commons.stat.DefaultSimpleStat
 
DefaultTakeOfflineManager - Class in org.infinispan.xsite.status
The default implementation of TakeOfflineManager.
DefaultTakeOfflineManager(String) - Constructor for class org.infinispan.xsite.status.DefaultTakeOfflineManager
 
DefaultTemplate - Enum in org.infinispan.client.hotrod
This enum lists the cache configuration templates names that are available in the server by default.
DefaultThreadFactory - Class in org.infinispan.factories.threads
Thread factory based on JBoss Thread's JBossThreadFactory.
DefaultThreadFactory(String, ThreadGroup, int, String, String, String) - Constructor for class org.infinispan.factories.threads.DefaultThreadFactory
Construct a new instance.
DefaultThreadFactory(ThreadGroup, int, String, String, String) - Constructor for class org.infinispan.factories.threads.DefaultThreadFactory
Construct a new instance.
DefaultTimeService - Class in org.infinispan.commons.time
The default implementation of TimeService.
DefaultTimeService() - Constructor for class org.infinispan.commons.time.DefaultTimeService
 
defaultTransactionManagerLookup() - Static method in class org.infinispan.client.hotrod.configuration.TransactionConfigurationBuilder
Deprecated.
 
DefaultTranscoder - Class in org.infinispan.commons.dataconversion
Handle conversions between text/plain, url-encoded, java objects, and octet-stream contents.
DefaultTranscoder(Marshaller) - Constructor for class org.infinispan.commons.dataconversion.DefaultTranscoder
 
DefaultTransformer - Class in org.infinispan.query.impl
WARNING, slow as a senile dog, uses Java Serialization and base64 encoding to get a String representation of an Object.
DefaultTransformer() - Constructor for class org.infinispan.query.impl.DefaultTransformer
 
defaultTransport() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
DefaultTwoWayKey2StringMapper - Class in org.infinispan.persistence.keymappers
Default implementation for TwoWayKey2StringMapper that knows how to handle all primitive wrapper keys and Strings.
DefaultTwoWayKey2StringMapper() - Constructor for class org.infinispan.persistence.keymappers.DefaultTwoWayKey2StringMapper
 
defaultValue() - Static method in class org.infinispan.functional.MetaParam.MetaLifespan
 
defaultValue() - Static method in class org.infinispan.functional.MetaParam.MetaMaxIdle
 
defaultValue() - Static method in enum org.infinispan.functional.Param.ExecutionMode
 
defaultValue() - Static method in enum org.infinispan.functional.Param.LockingMode
 
defaultValue() - Static method in enum org.infinispan.functional.Param.PersistenceMode
Provides default persistence mode.
defaultValue() - Static method in enum org.infinispan.functional.Param.ReplicationMode
 
defaultValue() - Static method in enum org.infinispan.functional.Param.StatisticsMode
 
DefaultXSiteEntryMergePolicy<K,V> - Class in org.infinispan.xsite.spi
The default XSiteEntryMergePolicy implementation.
DefaultXSiteMetricsCollector - Class in org.infinispan.xsite.metrics
Implementation of XSiteMetricsCollector to use when asynchronous backups (cross-site replication) are configured.
DefaultXSiteMetricsCollector(Configuration) - Constructor for class org.infinispan.xsite.metrics.DefaultXSiteMetricsCollector
 
defineConfiguration(String, String, Configuration) - Method in class org.infinispan.manager.DefaultCacheManager
 
defineConfiguration(String, String, Configuration) - Method in interface org.infinispan.manager.EmbeddedCacheManager
Defines a cache configuration by first reading the template configuration and then applying the override.
defineConfiguration(String, String, Configuration) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
defineConfiguration(String, Configuration) - Method in class org.infinispan.manager.DefaultCacheManager
 
defineConfiguration(String, Configuration) - Method in interface org.infinispan.manager.EmbeddedCacheManager
Register a cache configuration in the cache manager.
defineConfiguration(String, Configuration) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
defineConfiguration(String, Configuration) - Method in interface org.infinispan.multimap.api.embedded.MultimapCacheManager
Defines a named multimap cache's configuration by using the provided configuration If this cache was already configured either declaritively or programmatically this method will throw a CacheConfigurationException.
defineConfiguration(String, Configuration) - Method in class org.infinispan.multimap.impl.EmbeddedMultimapCacheManager
 
DefineConfigurationAction - Class in org.infinispan.security.actions
DefineConfigurationAction.
DefineConfigurationAction(EmbeddedCacheManager, String, Configuration) - Constructor for class org.infinispan.security.actions.DefineConfigurationAction
 
defineCounter(String, CounterConfiguration) - Method in class org.infinispan.client.hotrod.counter.impl.RemoteCounterManager
 
defineCounter(String, CounterConfiguration) - Method in interface org.infinispan.counter.api.CounterManager
Defines a counter with the specific name and CounterConfiguration.
DefineCounterOperation - Class in org.infinispan.client.hotrod.counter.operation
DefineCounterOperation(ChannelFactory, AtomicReference<ClientTopology>, Configuration, String, CounterConfiguration) - Constructor for class org.infinispan.client.hotrod.counter.operation.DefineCounterOperation
 
defineEntityReplacementText(String, String) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
defineEntityReplacementText(String, String) - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Set new value for entity replacement text as defined in XML 1.0 Section 4.5 Construction of Internal Entity Replacement Text.
defineLock(String) - Method in interface org.infinispan.lock.api.ClusteredLockManager
Defines a lock with the specific name and the default ClusteredLockConfiguration.
defineLock(String, ClusteredLockConfiguration) - Method in interface org.infinispan.lock.api.ClusteredLockManager
Defines a lock with the specific name and ClusteredLockConfiguration.
DEGRADED - Enum constant in enum org.infinispan.health.HealthStatus
Given entity is unhealthy.
DEGRADED_MODE - Enum constant in enum org.infinispan.partitionhandling.AvailabilityMode
Data can not be safely accessed because of a network split or successive nodes leaving.
delAt(int) - Method in class org.infinispan.commons.dataconversion.internal.Json
Remove the element at the specified index from a Json array.
delAt(String) - Method in class org.infinispan.commons.dataconversion.internal.Json
Delete the specified property from a Json object.
delayedNull(CompletionStage<Void>) - Static method in class org.infinispan.interceptors.BaseAsyncInterceptor
The same as BaseAsyncInterceptor.delayedValue(CompletionStage, Object), except that it is optimizes cases where the return value is null.
delayedValue(CompletionStage<?>, Object) - Static method in class org.infinispan.interceptors.BaseAsyncInterceptor
Returns an InvocationStage if the provided CompletionStage is null, not completed or completed via exception.
delayedValue(CompletionStage<?>, Object, Throwable) - Static method in class org.infinispan.interceptors.BaseAsyncInterceptor
This method should be used instead of BaseAsyncInterceptor.delayedValue(CompletionStage, Object) when a InvocationFinallyFunction is used to properly handle the exception if any is present.
delayStart() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
delayStart() - Method in class org.infinispan.factories.ComponentRegistry
The ComponentRegistry may delay the start after a cluster shutdown.
delayStart() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
delegate - Variable in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
delegate - Variable in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
 
delegate - Variable in class org.infinispan.search.mapper.work.impl.IndexingOperation
 
delegate - Variable in class org.infinispan.server.core.security.SubjectSaslServer
 
delegate() - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
 
delegate() - Method in class org.infinispan.commons.util.AbstractDelegatingConcurrentMap
 
delegate() - Method in class org.infinispan.commons.util.AbstractDelegatingMap
 
delegate() - Method in class org.infinispan.commons.util.AbstractDelegatingSet
 
delegate() - Method in class org.infinispan.commons.util.EnumerationList
 
delegate() - Method in class org.infinispan.commons.util.ForwardingList
 
delegate() - Method in class org.infinispan.configuration.parsing.SFSToSIFSStore
 
delegate() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
delegate() - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
delegate() - Method in class org.infinispan.container.impl.PeekableTouchableCaffeineMap
 
delegate() - Method in class org.infinispan.container.impl.PeekableTouchableContainerMap
 
delegate() - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
delegate() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
 
delegate() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
 
delegate() - Method in class org.infinispan.persistence.async.AsyncNonBlockingStore
 
delegate() - Method in class org.infinispan.persistence.support.DelegatingInitializationContext
 
delegate() - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
 
delegate() - Method in class org.infinispan.server.core.transport.NonRecursiveEventLoopGroup
 
delegate() - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
 
delegate() - Method in class org.infinispan.util.EntryWrapper
 
DelegatingCacheEntryListenerInvocation<K,V> - Class in org.infinispan.notifications.cachelistener.filter
A wrapper around a CacheEntryListenerInvocation that keeps a reference to the FilterIndexingServiceProvider instance that handles this invocation.
DelegatingCacheEntryListenerInvocation(CacheEntryListenerInvocation<K, V>) - Constructor for class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
DelegatingCacheLoader<K,V> - Class in org.infinispan.persistence.support
 
DelegatingCacheLoader(CacheLoader) - Constructor for class org.infinispan.persistence.support.DelegatingCacheLoader
 
DelegatingCacheWriter<K,V> - Class in org.infinispan.persistence.support
 
DelegatingCacheWriter(CacheWriter<K, V>) - Constructor for class org.infinispan.persistence.support.DelegatingCacheWriter
 
DelegatingEventLoopGroup - Class in org.infinispan.server.core.utils
 
DelegatingEventLoopGroup() - Constructor for class org.infinispan.server.core.utils.DelegatingEventLoopGroup
 
DelegatingInitializationContext - Class in org.infinispan.persistence.support
 
DelegatingInitializationContext() - Constructor for class org.infinispan.persistence.support.DelegatingInitializationContext
 
delegatingNearCache(RemoteCacheImpl<K, V>, NearCacheService<K, V>) - Static method in class org.infinispan.client.hotrod.impl.InvalidatedNearRemoteCache
 
DelegatingNonBlockingStore<K,V> - Class in org.infinispan.persistence.support
 
DelegatingNonBlockingStore() - Constructor for class org.infinispan.persistence.support.DelegatingNonBlockingStore
 
DelegatingObjectInput - Class in org.infinispan.commons.marshall
Class that extends InputStream and implements ObjectInput.
DelegatingObjectInput(ObjectInput) - Constructor for class org.infinispan.commons.marshall.DelegatingObjectInput
 
DelegatingObjectOutput - Class in org.infinispan.commons.marshall
Class that extends OutputStream and implements ObjectOutput.
DelegatingObjectOutput(ObjectOutput) - Constructor for class org.infinispan.commons.marshall.DelegatingObjectOutput
 
DelegatingPersistenceManager - Class in org.infinispan.persistence.support
 
DelegatingPersistenceManager(PersistenceManager) - Constructor for class org.infinispan.persistence.support.DelegatingPersistenceManager
 
DelegatingRemoteCache<K,V> - Class in org.infinispan.client.hotrod.impl
Delegates all invocations to the provided underlying InternalRemoteCache but provides extensibility to intercept when a method is invoked.
DelegatingRemoteCache(InternalRemoteCache<K, V>) - Constructor for class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
delete() - Method in class org.infinispan.io.GridFile
Deprecated.
 
delete() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfiguration
 
delete(int, Object) - Method in class org.infinispan.persistence.async.AsyncNonBlockingStore
 
delete(int, Object) - Method in class org.infinispan.persistence.file.SingleFileStore
 
delete(int, Object) - Method in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
 
delete(int, Object) - Method in class org.infinispan.persistence.remote.RemoteStore
 
delete(int, Object) - Method in class org.infinispan.persistence.rocksdb.RocksDBStore
 
delete(int, Object) - Method in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
 
delete(int, Object) - Method in interface org.infinispan.persistence.spi.NonBlockingStore
Removes the entry for given key and segment from the store and optionally report if the entry was actually removed or not.
delete(int, Object) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
Deprecated.
Removes the entry for the provided key which is in the given segment.
delete(int, Object) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
delete(int, Object) - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
 
delete(int, Object) - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
 
delete(Object) - Method in interface org.infinispan.persistence.spi.CacheWriter
Deprecated.
 
delete(Object) - Method in class org.infinispan.persistence.support.AbstractSegmentedAdvancedLoadWriteStore
 
delete(Object) - Method in class org.infinispan.persistence.support.DelegatingCacheWriter
 
delete(Object, String, Object) - Method in class org.infinispan.search.mapper.work.impl.SearchIndexerImpl
 
delete(Object, String, Object) - Method in interface org.infinispan.search.mapper.work.SearchIndexer
 
delete(String) - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfigurationBuilder
Configures the delete statement to be used when removing entries from the database.
DELETE - Enum constant in enum org.infinispan.rest.framework.Method
 
DELETE - Static variable in class org.infinispan.functional.impl.StatsEnvelope
 
DELETE - Static variable in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfiguration
 
DELETE_ALL - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
 
DELETE_ALL - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
 
DELETE_ALL - Static variable in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfiguration
 
DELETE_SINGLE - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
 
DELETE_SINGLE - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
 
deleteAll() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfiguration
 
deleteAll(String) - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfigurationBuilder
Configures the delete all statement to be used when clearing the store.
deleteAllCannotHaveParameters(String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
 
deleteAllRows(Connection) - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
 
deleteAllRows(Connection) - Method in interface org.infinispan.persistence.jdbc.common.TableOperations
 
deleteAndSelectQueryMismatchArguments(String, String, String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
 
deleteAndSelectQueryMismatchArguments(List<String>, List<String>) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
 
deleteBatch(Iterable<Object>) - Method in interface org.infinispan.persistence.spi.CacheWriter
Deprecated.
Remove all provided keys from the store in a single batch operation.
deleteBatch(Iterable<Object>) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
deleteById(String) - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository
 
DELETED - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
 
deleteEntry(Connection, int, Object) - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
 
deleteEntry(Connection, int, Object) - Method in interface org.infinispan.persistence.jdbc.common.TableOperations
 
deleteFile(int) - Method in class org.infinispan.persistence.sifs.FileProvider
 
deleteFromAllStores(Object, int, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
 
DeleteIndexingOperation - Class in org.infinispan.search.mapper.work.impl
 
deleteOnExit() - Method in class org.infinispan.io.GridFile
Deprecated.
 
deleteRequest(int, Object, ByteBuffer) - Method in class org.infinispan.persistence.sifs.LogAppender
 
deleteScopedState(String) - Method in interface org.infinispan.globalstate.GlobalStateManager
Delete the persistent state for the given scope
deleteScopedState(String) - Method in class org.infinispan.globalstate.impl.GlobalStateManagerImpl
 
delistResource(XAResource, int) - Method in class org.infinispan.commons.tx.TransactionImpl
De-list an XA resource from this transaction.
deliverOrder() - Method in class org.infinispan.remoting.rpc.RpcOptions
 
DeliveryGuarantee - Enum in org.infinispan.reactive.publisher.impl
Enumeration defining the possible delivery guarantees for entries.
Delivery Semantics - Search tag in annotation type org.infinispan.notifications.Listener
Section
DELTA_COMPOSITE_KEY - Static variable in interface org.infinispan.commons.marshall.Ids
 
deny(String, String) - Method in class org.infinispan.security.mappers.ClusterRoleMapper
 
deny(String, String) - Method in interface org.infinispan.security.MutablePrincipalRoleMapper
 
DENY - Enum constant in enum org.infinispan.security.AuditResponse
 
DENY_READ_WRITES - Enum constant in enum org.infinispan.partitionhandling.PartitionHandling
If the partition does not have all owners for a given segment, both reads and writes are denied for all keys in that segment.
DependencyGraph<T> - Class in org.infinispan.util
Graph to track dependencies between objects
DependencyGraph() - Constructor for class org.infinispan.util.DependencyGraph
 
dependsOn(CompletionStage<?>) - Method in interface org.infinispan.util.concurrent.AggregateCompletionStage
Adds another CompletionStage for this stage to be reliant upon.
dependsOn(IracXSiteBackup, CompletionStage<? extends IntSet>) - Method in class org.infinispan.xsite.irac.IracResponseCollector
 
dependsOn(IracXSiteBackup, CompletionStage<Void>) - Method in class org.infinispan.xsite.irac.IracClearResponseCollector
 
deprecated() - Method in class org.infinispan.rest.framework.impl.InvocationImpl.Builder
 
deprecated() - Method in class org.infinispan.rest.framework.impl.InvocationImpl
 
deprecated() - Method in interface org.infinispan.rest.framework.Invocation
 
deprecatedConfigurationProperty(String) - Method in interface org.infinispan.client.hotrod.logging.Log
 
deprecatedSince(int, int) - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition.Builder
 
depth - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
DERBY - Enum constant in enum org.infinispan.persistence.jdbc.common.DatabaseType
 
deregister(ChannelHandlerContext, ChannelPromise) - Method in class org.infinispan.server.core.transport.SaslQopHandler
 
DESC - Enum constant in enum org.infinispan.query.dsl.SortOrder
Deprecated.
 
destination() - Method in interface org.infinispan.remoting.transport.jgroups.RequestTracker
 
destroy() - Method in interface org.infinispan.persistence.spi.ExternalStore
Deprecated.
Method to be used to destroy and clean up any resources associated with this store.
destroy() - Method in interface org.infinispan.persistence.spi.NonBlockingStore
This method is to be invoked when the store should clean up all underlying data and storage of said data.
destroy() - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
destroy() - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
 
destroy() - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository
 
destroy() - Method in class org.infinispan.spring.embedded.InfinispanDefaultCacheFactoryBean
Shuts down the org.infinispan.Cache created by this FactoryBean.
destroy() - Method in class org.infinispan.spring.embedded.provider.SpringEmbeddedCacheManagerFactoryBean
Shuts down the SpringEmbeddedCacheManager instance created by this FactoryBean.
destroy() - Method in class org.infinispan.spring.embedded.support.InfinispanEmbeddedCacheManagerFactoryBean
Shuts down the EmbeddedCacheManager instance created by this FactoryBean.
destroy() - Method in class org.infinispan.spring.embedded.support.InfinispanNamedEmbeddedCacheFactoryBean
Shuts down the org.infinispan.Cache created by this FactoryBean.
destroy() - Method in class org.infinispan.spring.remote.provider.SpringRemoteCacheManagerFactoryBean
stop the RemoteCacheManager created by this factory.
destroy() - Method in class org.infinispan.spring.remote.support.InfinispanRemoteCacheManagerFactoryBean
stop the RemoteCacheManager created by this factory.
destroy() - Static method in class org.infinispan.transaction.tm.BatchModeTransactionManager
 
destroy() - Static method in class org.infinispan.transaction.tm.EmbeddedTransactionManager
 
destroyTxConnection(Transaction) - Method in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
 
detachFactory() - Static method in class org.infinispan.commons.dataconversion.internal.Json
Clear the thread-local factory previously attached to this thread via the Json.attachFactory(Factory) method.
detail - Variable in exception class org.infinispan.commons.configuration.io.xml.XmlPullParserException
 
detectEntityType(T) - Method in class org.infinispan.search.mapper.model.impl.InfinispanRuntimeIntrospector
 
determinePrimaryParameters(C, AbstractSchemaJdbcStore.Parameter[]) - Method in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore
 
determinePrimaryParameters(QueriesJdbcStoreConfiguration, AbstractSchemaJdbcStore.Parameter[]) - Method in class org.infinispan.persistence.sql.QueriesJdbcStore
 
dialect() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfiguration
 
dialect(DatabaseType) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
 
DIALECT - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
 
diffBitSets(long, long) - Static method in class org.infinispan.commons.util.EnumUtil
 
difference(Set<? extends E>, Set<? extends E>) - Static method in class org.infinispan.commons.util.InfinispanCollections
Returns the elements that are present in s1 but which are not present in s2, without changing the contents of neither s1, nor s2.
DIFFERENT_MACHINE - Enum constant in enum org.infinispan.manager.ClusterExecutionPolicy
The command will be executed only on a different machine.
DIFFERENT_RACK - Enum constant in enum org.infinispan.manager.ClusterExecutionPolicy
The command will be executed on machine on a different rack.
DIFFERENT_SITE - Enum constant in enum org.infinispan.manager.ClusterExecutionPolicy
The command will be executed on a different site.
DIR - Static variable in class org.infinispan.io.GridFile.Metadata
Deprecated.
 
disable() - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
Disables authentication
disable() - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
Disables the SSL support
disable() - Method in class org.infinispan.client.hotrod.configuration.StatisticsConfigurationBuilder
Disables client-side statistics collection
disable() - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
 
disable() - Method in class org.infinispan.configuration.cache.IndexReaderConfigurationBuilder
 
disable() - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
 
disable() - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
disable() - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
Disables authorization for this cache
disable() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
disable() - Method in interface org.infinispan.configuration.cache.IndexingConfigurationChildBuilder
 
disable() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
 
disable() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
Deprecated.
Disable statistics gathering and reporting
disable() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
disable() - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
Disable recovery for this cache
disable() - Method in class org.infinispan.configuration.cache.StatisticsConfigurationBuilder
Disable statistics gathering.
disable() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
 
disable() - Method in class org.infinispan.configuration.global.GlobalJmxConfigurationBuilder
Disables JMX in the cache manager.
disable() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
Deprecated.
Disables JMX in the cache manager.
disable() - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
 
disable() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
Disables authentication
disable() - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
Disables the SSL support
disable() - Method in class org.infinispan.rest.configuration.AuthenticationConfigurationBuilder
 
disable() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
 
disable() - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
Disables the SSL support
disable() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
 
disableBackOff() - Method in class org.infinispan.xsite.irac.IracExecutor
 
disableBackups() - Method in class org.infinispan.configuration.cache.SitesConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
since 14.0. To be removed without replacement.
disableBackups(boolean) - 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.
disabled() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
Disable grouping support so that Group annotations are not used and any configured groupers will not be be invoked
DISABLED - Enum constant in enum org.infinispan.client.hotrod.configuration.NearCacheMode
Near caching is disabled.
disableReaper() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
Disable the background reaper to test entries for expiration.
disableRehashAware() - Method in interface org.infinispan.BaseCacheStream
Disables tracking of rehash events that could occur to the underlying cache.
disableRehashAware() - Method in interface org.infinispan.CacheStream
Disables tracking of rehash events that could occur to the underlying cache.
disableRehashAware() - Method in interface org.infinispan.DoubleCacheStream
Disables tracking of rehash events that could occur to the underlying cache.
disableRehashAware() - Method in interface org.infinispan.IntCacheStream
Disables tracking of rehash events that could occur to the underlying cache.
disableRehashAware() - Method in interface org.infinispan.LockedStream
Disables tracking of rehash events that could occur to the underlying cache.
disableRehashAware() - Method in interface org.infinispan.LongCacheStream
Disables tracking of rehash events that could occur to the underlying cache.
disableRehashAware() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
disableRehashAware() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
disableRehashAware() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
disableRehashAware() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
disableRehashAware() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
disableRehashAware() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
disableRehashAware() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
disableRehashAware() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
disableRehashAware() - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
disableRehashAware() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
disableStore(String) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
 
disableTracingPropagation() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
DiscardUpdateException - Exception Class in org.infinispan.xsite.irac
For optimistic transactions, it signals the update from the remote site is not valid (old version or conflict resolution rejected it).
DiscardUpdateException(String, Throwable, boolean, boolean) - Constructor for exception class org.infinispan.xsite.irac.DiscardUpdateException
 
disconnect(ChannelHandlerContext, ChannelPromise) - Method in class org.infinispan.server.core.transport.SaslQopHandler
 
DISCONNECT_REMOTE_STORE - Static variable in interface org.infinispan.persistence.remote.ExternalizerIds
 
disconnectChannel - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
DisconnectRemoteStoreTask - Class in org.infinispan.persistence.remote.upgrade
Cluster task to remove the remote store from a set a caches
DisconnectRemoteStoreTask(String) - Constructor for class org.infinispan.persistence.remote.upgrade.DisconnectRemoteStoreTask
 
DisconnectRemoteStoreTask.Externalizer - Class in org.infinispan.persistence.remote.upgrade
 
disconnectSource(String) - Method in class org.infinispan.upgrade.RollingUpgradeManager
 
disconnectSource(Cache<Object, Object>) - Method in class org.infinispan.persistence.remote.upgrade.HotRodTargetMigrator
 
disconnectSource(Cache<Object, Object>) - Method in interface org.infinispan.upgrade.TargetMigrator
Disconnects the target from the source.
discoverSecurityProviders(ClassLoader) - Static method in class org.infinispan.commons.util.SslContextFactory
 
dispatch(RestRequest) - Method in class org.infinispan.rest.framework.impl.RestDispatcherImpl
 
dispatch(RestRequest) - Method in interface org.infinispan.rest.framework.RestDispatcher
 
dispatch(RestRequest, LookupResult) - Method in class org.infinispan.rest.framework.impl.RestDispatcherImpl
 
dispatch(RestRequest, LookupResult) - Method in interface org.infinispan.rest.framework.RestDispatcher
 
dispose() - Method in class org.infinispan.server.core.security.SubjectSaslServer
 
dispose() - Method in class org.infinispan.server.hotrod.iteration.IterationReaper
 
dissociateTransaction() - Static method in class org.infinispan.commons.tx.TransactionManagerImpl
 
DIST - Enum constant in enum org.infinispan.configuration.parsing.ParsedCacheMode
 
DIST_ASYNC - Enum constant in enum org.infinispan.client.hotrod.DefaultTemplate
 
DIST_ASYNC - Enum constant in enum org.infinispan.configuration.cache.CacheMode
Async DIST
DIST_SYNC - Enum constant in enum org.infinispan.client.hotrod.DefaultTemplate
 
DIST_SYNC - Enum constant in enum org.infinispan.configuration.cache.CacheMode
Synchronous DIST
distinct() - Method in interface org.infinispan.CacheStream
distinct() - Method in interface org.infinispan.DoubleCacheStream
distinct() - Method in interface org.infinispan.IntCacheStream
distinct() - Method in interface org.infinispan.LongCacheStream
distinct() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
distinct() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
distinct() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
distinct() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
distinct() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
distinct() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
distinct() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
distinct() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
distinct() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
distLostDataCheck(ConsistentHash, List<Address>) - Static method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
DISTRIBUTED_CACHE - Enum constant in enum org.infinispan.configuration.parsing.Element
 
DISTRIBUTED_CACHE_CONFIGURATION - Enum constant in enum org.infinispan.configuration.parsing.Element
 
DISTRIBUTED_CACHE_STATS_CALLABLE - Static variable in interface org.infinispan.commons.marshall.Ids
 
DISTRIBUTED_SERVER_TASK - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
DISTRIBUTED_SERVER_TASK_CONTEXT - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
DISTRIBUTED_SERVER_TASK_PARAMETER - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
DISTRIBUTED_SYNC_TIMEOUT - Static variable in class org.infinispan.configuration.global.TransportConfiguration
 
distributedBatchSize - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
distributedBatchSize(int) - Method in interface org.infinispan.BaseCacheStream
Controls how many keys are returned from a remote node when using a stream terminal operation with a distributed cache to back this stream.
distributedBatchSize(int) - Method in interface org.infinispan.CacheStream
Controls how many keys are returned from a remote node when using a stream terminal operation with a distributed cache to back this stream.
distributedBatchSize(int) - Method in interface org.infinispan.DoubleCacheStream
Controls how many keys are returned from a remote node when using a stream terminal operation with a distributed cache to back this stream.
distributedBatchSize(int) - Method in interface org.infinispan.IntCacheStream
Controls how many keys are returned from a remote node when using a stream terminal operation with a distributed cache to back this stream.
distributedBatchSize(int) - Method in interface org.infinispan.LockedStream
Controls how many keys are returned from a remote node when using a stream terminal operation with a distributed cache to back this stream.
distributedBatchSize(int) - Method in interface org.infinispan.LongCacheStream
Controls how many keys are returned from a remote node when using a stream terminal operation with a distributed cache to back this stream.
distributedBatchSize(int) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
distributedBatchSize(int) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
distributedBatchSize(int) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
distributedBatchSize(int) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
distributedBatchSize(int) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
distributedBatchSize(int) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
distributedBatchSize(int) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
distributedBatchSize(int) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
distributedBatchSize(int) - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
distributedBatchSize(int) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
DistributedCacheStatsCallableExternalizer() - Constructor for class org.infinispan.stats.impl.ClusterCacheStatsImpl.DistributedCacheStatsCallableExternalizer
 
DistributedCacheStream<Original,R> - Class in org.infinispan.stream.impl
Implementation of CacheStream that provides support for lazily distributing stream methods to appropriate nodes
DistributedCacheStream(Address, boolean, InvocationContext, long, int, Executor, ComponentRegistry, Function<? super Original, ?>, ClusterPublisherManager<?, ?>) - Constructor for class org.infinispan.stream.impl.DistributedCacheStream
Standard constructor requiring all pertinent information to properly utilize a distributed cache stream
DistributedCacheStream(AbstractCacheStream) - Constructor for class org.infinispan.stream.impl.DistributedCacheStream
This constructor is to be used only when a user calls a map or flat map method changing back to a regular Stream from an IntStream, DoubleStream etc.
DistributedDoubleCacheStream<Original> - Class in org.infinispan.stream.impl
Implementation of DoubleStream that utilizes a lazily evaluated distributed back end execution.
DistributedDoubleCacheStream(AbstractCacheStream) - Constructor for class org.infinispan.stream.impl.DistributedDoubleCacheStream
This constructor is to be used only when a user calls a map or flat map method changing to a DoubleStream from a CacheStream, Stream, IntStream, LongStream etc.
DistributedIntCacheStream<Original> - Class in org.infinispan.stream.impl
Implementation of IntStream that utilizes a lazily evaluated distributed back end execution.
DistributedIntCacheStream(AbstractCacheStream) - Constructor for class org.infinispan.stream.impl.DistributedIntCacheStream
This constructor is to be used only when a user calls a map or flat map method changing to an IntStream from a CacheStream, Stream, DoubleStream, LongStream etc.
DistributedLongCacheStream<Original> - Class in org.infinispan.stream.impl
Implementation of LongStream that utilizes a lazily evaluated distributed back end execution.
DistributedLongCacheStream(AbstractCacheStream) - Constructor for class org.infinispan.stream.impl.DistributedLongCacheStream
This constructor is to be used only when a user calls a map or flat map method changing to an IntStream from a CacheStream, Stream, DoubleStream, IntStream etc.
distributedSyncTimeout() - Method in class org.infinispan.configuration.global.TransportConfiguration
 
distributedSyncTimeout(long) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
Timeout for coordinating cluster formation when nodes join or leave the cluster.
distributedSyncTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
Timeout for coordinating cluster formation when nodes join or leave the cluster.
distributedTaskNeedCacheInBinding(String) - Method in interface org.infinispan.scripting.logging.Log
 
DISTRIBUTION - Enum constant in enum org.infinispan.configuration.cache.CacheType
 
DistributionInfo - Class in org.infinispan.distribution
 
DistributionInfo(int, Address, List<Address>, List<Address>, Collection<Address>, Address) - Constructor for class org.infinispan.distribution.DistributionInfo
 
distributionManager - Variable in class org.infinispan.expiration.impl.ClusterExpirationManager
 
distributionManager - Variable in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
DistributionManager - Interface in org.infinispan.distribution
A component that manages the distribution of elements across a cache cluster
DistributionManagerFactory - Class in org.infinispan.factories
 
DistributionManagerFactory() - Constructor for class org.infinispan.factories.DistributionManagerFactory
 
DistributionManagerImpl - Class in org.infinispan.distribution.impl
The default distribution manager implementation
DistributionManagerImpl() - Constructor for class org.infinispan.distribution.impl.DistributionManagerImpl
 
DistributionSummaryMetricInfo<T> - Class in org.infinispan.commons.stat
Represents a distribution summary (histogram).
DistributionSummaryMetricInfo(String, String, Map<String, String>, BiConsumer<T, DistributionSummaryTracker>) - Constructor for class org.infinispan.commons.stat.DistributionSummaryMetricInfo
 
DistributionSummaryTracker - Interface in org.infinispan.commons.stat
Track the sample distribution of events.
DNS_RESOLVER_MAX_TTL - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DNS_RESOLVER_MIN_TTL - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
DNS_RESOLVER_NEGATIVE_TTL - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
dnsResolverMaxTTL() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
dnsResolverMaxTTL(int) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
dnsResolverMaxTTL(int) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
dnsResolverMaxTTL(int) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
 
dnsResolverMinTTL() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
dnsResolverMinTTL(int) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
dnsResolverMinTTL(int) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
dnsResolverMinTTL(int) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
 
dnsResolverNegativeTTL() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
dnsResolverNegativeTTL(int) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
dnsResolverNegativeTTL(int) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
dnsResolverNegativeTTL(int) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
 
doAddBackupOwners(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
 
doAs(Subject, Runnable) - Static method in class org.infinispan.security.Security
 
doAs(Subject, PrivilegedAction<T>) - Static method in class org.infinispan.security.Security
A "lightweight" implementation of Subject.doAs(Subject, PrivilegedAction) which uses a ThreadLocal Subject instead of modifying the current AccessControlContext.
doAs(Subject, PrivilegedExceptionAction<T>) - Static method in class org.infinispan.security.Security
A "lightweight" implementation of Subject.doAs(Subject, PrivilegedExceptionAction) which uses a ThreadLocal Subject instead of modifying the current AccessControlContext.
doAs(Subject, BiFunction<T, U, R>, T, U) - Static method in class org.infinispan.security.Security
 
doAs(Subject, Function<T, R>, T) - Static method in class org.infinispan.security.Security
 
DOCDECL - Static variable in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
An XML document type declaration was just read.
doCheck(Object, boolean, long) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
doCheck(Object, boolean, long) - Method in class org.infinispan.scattered.impl.ScatteredPartitionHandlingManagerImpl
 
doHandleClusterView(int) - Method in class org.infinispan.topology.ClusterCacheStatus
 
doIf(Subject, AuthorizationPermission, Runnable) - Method in interface org.infinispan.security.AuthorizationManager
Executes the runnable only if the current user has the specified permission
doIf(Subject, AuthorizationPermission, Runnable) - Method in class org.infinispan.security.impl.AuthorizationManagerImpl
 
doIf(Subject, AuthorizationPermission, Runnable) - Method in class org.infinispan.security.impl.PermissiveAuthorizationManager
 
doJoin(Address, CacheJoinInfo) - Method in class org.infinispan.topology.ClusterCacheStatus
 
doLeave(Address) - Method in class org.infinispan.topology.ClusterCacheStatus
 
domain() - Method in class org.infinispan.configuration.global.GlobalJmxConfiguration
 
domain() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
Deprecated.
 
domain(String) - Method in class org.infinispan.configuration.global.GlobalJmxConfigurationBuilder
If JMX is enabled then all 'published' JMX objects will appear under this name.
domain(String) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
Deprecated.
If JMX is enabled then all 'published' JMX objects will appear under this name.
DOMAIN - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
DOMAIN - Static variable in class org.infinispan.configuration.global.GlobalJmxConfiguration
 
doMergePartitions(Map<Address, CacheStatusResponse>) - Method in class org.infinispan.topology.ClusterCacheStatus
 
DONT_LOAD - Enum constant in enum org.infinispan.commands.VisitableCommand.LoadType
Never load previous value.
DONT_REGISTER - Enum constant in enum org.infinispan.configuration.global.ShutdownHookBehavior
Forces the cache NOT to register a shutdown hook, even if no MBean server is detected.
doOnSegmentComplete(int) - Method in class org.infinispan.reactive.publisher.impl.InnerPublisherSubscription
Method invoked whenever a segment is completed.
doOnValue(R, int) - Method in class org.infinispan.reactive.publisher.impl.InnerPublisherSubscription
Method invoked on each value providing the value and segment.
doPrivileged(PrivilegedAction<T>) - Static method in class org.infinispan.security.Security
 
doPrivileged(PrivilegedExceptionAction<T>) - Static method in class org.infinispan.security.Security
 
doReadObject(ObjectInput) - Method in class org.infinispan.commons.marshall.InstanceReusingAdvancedExternalizer
 
doReadObject(ObjectInput) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash.Externalizer
 
doReadObject(ObjectInput) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash.Externalizer
 
doReadObject(ObjectInput) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash.Externalizer
 
doReadObject(ObjectInput) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress.Externalizer
 
doReadObject(ObjectInput) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress.Externalizer
 
doReadObject(ObjectInput) - Method in class org.infinispan.topology.CacheTopology.Externalizer
 
doReadObject(ObjectInput) - Method in class org.infinispan.topology.ManagerStatusResponse.Externalizer
 
doRealInvocation(Event<K, V>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
doRealInvocation(EventWrapper<K, V, CacheEntryEvent<K, V>>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
doRealInvocation(EventWrapper<K, V, CacheEntryEvent<K, V>>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.ClusteredListenerInvocation
 
doTranscode(Object, MediaType, MediaType) - Method in class org.infinispan.commons.dataconversion.AbstractTranscoder
 
doTranscode(Object, MediaType, MediaType) - Method in class org.infinispan.commons.dataconversion.BinaryTranscoder
Deprecated.
 
doTranscode(Object, MediaType, MediaType) - Method in class org.infinispan.commons.dataconversion.DefaultTranscoder
 
doTranscode(Object, MediaType, MediaType) - Method in class org.infinispan.commons.dataconversion.TranscoderMarshallerAdapter
 
doTranscode(Object, MediaType, MediaType) - Method in class org.infinispan.encoding.impl.TwoStepTranscoder
 
doTranscode(Object, MediaType, MediaType) - Method in class org.infinispan.encoding.ProtostreamTranscoder
 
doTranscode(Object, MediaType, MediaType) - Method in class org.infinispan.jboss.marshalling.dataconversion.JBossMarshallingTranscoder
 
doTranscode(Object, MediaType, MediaType) - Method in class org.infinispan.server.core.dataconversion.JsonTranscoder
 
doTranscode(Object, MediaType, MediaType) - Method in class org.infinispan.server.core.dataconversion.XMLTranscoder
 
DOUBLE - Enum constant in enum org.infinispan.persistence.sql.AbstractSchemaJdbcStore.ProtostreamFieldType
 
DOUBLE - Enum constant in enum org.infinispan.stream.impl.IntermediateType
 
DOUBLE_SUMMARY_STATISTICS - Static variable in interface org.infinispan.commons.marshall.Ids
 
doubleCacheStream() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
doubleCacheStream() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
doubleCacheStream() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
DoubleCacheStream - Interface in org.infinispan
A DoubleStream that has additional methods to allow for Serializable instances.
DoubleSummaryStatisticsExternalizer - Class in org.infinispan.marshall.exts
Externalizer used for DoubleSummaryStatistics.
DoubleSummaryStatisticsExternalizer() - Constructor for class org.infinispan.marshall.exts.DoubleSummaryStatisticsExternalizer
 
downloadFile(URL, Path, boolean, boolean) - Static method in class org.infinispan.commons.maven.AbstractArtifact
 
doWriteObject(ObjectOutput, DefaultConsistentHash) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash.Externalizer
 
doWriteObject(ObjectOutput, ReplicatedConsistentHash) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash.Externalizer
 
doWriteObject(ObjectOutput, ScatteredConsistentHash) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash.Externalizer
 
doWriteObject(ObjectOutput, JGroupsAddress) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress.Externalizer
 
doWriteObject(ObjectOutput, JGroupsTopologyAwareAddress) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress.Externalizer
 
doWriteObject(ObjectOutput, CacheTopology) - Method in class org.infinispan.topology.CacheTopology.Externalizer
 
doWriteObject(ObjectOutput, ManagerStatusResponse) - Method in class org.infinispan.topology.ManagerStatusResponse.Externalizer
 
doWriteObject(ObjectOutput, T) - Method in class org.infinispan.commons.marshall.InstanceReusingAdvancedExternalizer
 
drainCompletionQueue() - Method in class org.infinispan.executors.SemaphoreCompletionService
 
DRIVER_CLASS - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
 
DRIVER_CLASS - Static variable in class org.infinispan.persistence.jdbc.common.configuration.AbstractUnmanagedConnectionFactoryConfiguration
 
driverClass() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractUnmanagedConnectionFactoryConfiguration
 
driverClass(Class<? extends Driver>) - Method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfigurationBuilder
 
driverClass(Class<? extends Driver>) - Method in class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfigurationBuilder
 
driverClass(String) - Method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfigurationBuilder
 
driverClass(String) - Method in class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfigurationBuilder
 
DROP_ON_EXIT - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
 
DROP_ON_EXIT - Static variable in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
dropEvents(Object) - Method in interface org.infinispan.notifications.cachelistener.cluster.ClusterEventManager
Drops and ignores all previously added events for the given identifier.
dropEvents(Object) - Method in class org.infinispan.notifications.cachelistener.cluster.impl.BatchingClusterEventManagerImpl
 
dropEvents(Object) - Method in class org.infinispan.notifications.cachelistener.cluster.impl.ClusterEventManagerStub
 
dropOnExit() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
dropOnExit(boolean) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
Determines whether database tables should be dropped by the store on shutdown
DUMMY_INVOCATION_ID - Static variable in class org.infinispan.commands.CommandInvocationId
 
dummyClientStatistics(TimeService) - Static method in class org.infinispan.client.hotrod.impl.ClientStatistics
It returns a ClientStatistics instance to be used when the statistics aren't needed.
dumpCacheStatistics() - Method in class org.infinispan.extendedstats.CacheStatisticManager
 
dumpCacheStatisticsTo(PrintStream) - Method in class org.infinispan.extendedstats.CacheStatisticManager
Prints the cache statistics values to a PrintStream.
dumpStatistics() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
dumpStatisticsToSystemOut() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
dumpStatisticToFile(String) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
dumpTo(PrintWriter) - Method in class org.infinispan.extendedstats.CacheStatisticCollector
Prints the cache statistics values to a PrintStream.
dumpTo(PrintWriter) - Method in class org.infinispan.extendedstats.container.ConcurrentGlobalContainer
 
dumpTo(StringBuilder) - Method in class org.infinispan.extendedstats.CacheStatisticCollector
Dumps all the cache statistic values to a StringBuilder
dup() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
duplicate() - Method in class org.infinispan.rest.ServerSentEvent
 
duplicateAttribute(ConfigurationReader, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Get an exception reporting that an attribute of a given name has already been declared in this scope.
duplicateCacheConfiguration(String) - Method in interface org.infinispan.client.hotrod.logging.Log
 
duplicateClusterDefinition(String) - Method in interface org.infinispan.client.hotrod.logging.Log
 
duplicateCollection(Collection<E>) - Static method in class org.infinispan.commons.util.ObjectDuplicator
Deprecated.
 
duplicatedCounterName(String) - Method in interface org.infinispan.counter.logging.Log
 
duplicateFieldInSchema(String, String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
 
duplicateLocation(TopologyLevel, Collection<Address>, Address, boolean) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
duplicateMap(Map<K, V>) - Static method in class org.infinispan.commons.util.ObjectDuplicator
Deprecated.
 
duplicateNamedElement(ConfigurationReader, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
Get an exception reporting that an element of a given type and name has already been declared in this scope.
duplicateResource(String, Invocation, String) - Method in interface org.infinispan.rest.logging.Log
 
duplicateResourceMethod(String, Method, String) - Method in interface org.infinispan.rest.logging.Log
 
Duplicates - Search tag in class org.infinispan.multimap.impl.EmbeddedMultimapCache
Section
duplicateSet(Set<E>) - Static method in class org.infinispan.commons.util.ObjectDuplicator
Deprecated.
 
dynamicBuffer() - Static method in class org.infinispan.server.core.transport.ExtendedByteBuf
 
dynamicBuffer() - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
 
DynamicModuleMetadataProvider - Interface in org.infinispan.factories.impl
Modules implementing ModuleLifecycle might need additional control over the created components.

E

EC2(Properties) - Static method in class org.infinispan.remoting.transport.jgroups.BuiltinJGroupsChannelConfigurator
 
Either<A,B> - Class in org.infinispan.commons.util
 
Either() - Constructor for class org.infinispan.commons.util.Either
 
Either.Type - Enum in org.infinispan.commons.util
 
element - Variable in class org.infinispan.commons.configuration.attributes.ConfigurationElement
 
Element - Enum in org.infinispan.configuration.parsing
An enumeration of all the recognized XML element local names, by name.
Element - Enum in org.infinispan.counter.configuration
 
Element - Enum in org.infinispan.lock.configuration
 
Element - Enum in org.infinispan.persistence.jdbc.common.configuration
An enumeration of all the recognized XML element local names for the JDBC cache stores
Element - Enum in org.infinispan.persistence.remote.configuration
An enumeration of all the recognized XML element local names for the RemoteStore
Element - Enum in org.infinispan.persistence.rocksdb.configuration
An enumeration of all the recognized XML element local names for the RocksDB cache store
Element - Enum in org.infinispan.server.hotrod.configuration
 
elementName() - Method in class org.infinispan.commons.configuration.attributes.ConfigurationElement
 
elementRemoved(ConfigurationReader) - Static method in class org.infinispan.configuration.parsing.ParseUtils
 
elementRemoved(ConfigurationReader, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
 
elements() - Method in class org.infinispan.security.CachePermissionCollection
 
elName - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
elNamespaceCount - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
elPrefix - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
elRawName - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
elRawNameEnd - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
elRawNameLine - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
elUri - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
EMBEDDED_EXPIRABLE_METADATA - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
EMBEDDED_KEY - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
 
EMBEDDED_KEY - Static variable in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfiguration
 
EMBEDDED_LIFESPAN_METADATA - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
EMBEDDED_MAX_IDLE_METADATA - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
EMBEDDED_METADATA - Static variable in interface org.infinispan.commons.marshall.Ids
 
EMBEDDED_METADATA - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
EmbeddedApplicationPublishedBridge - Class in org.infinispan.spring.embedded.session
A bridge between Infinispan Embedded events and Spring.
EmbeddedApplicationPublishedBridge(SpringCache) - Constructor for class org.infinispan.spring.embedded.session.EmbeddedApplicationPublishedBridge
 
EmbeddedBaseTransactionManager - Class in org.infinispan.transaction.tm
A simple TransactionManager implementation.
EmbeddedBaseTransactionManager() - Constructor for class org.infinispan.transaction.tm.EmbeddedBaseTransactionManager
 
embeddedCacheManager - Variable in class org.infinispan.interceptors.BaseCustomAsyncInterceptor
 
EmbeddedCacheManager - Interface in org.infinispan.manager
EmbeddedCacheManager is an CacheManager that runs in the same JVM as the client.
EmbeddedCacheManagerAdmin - Interface in org.infinispan.manager
Cache manager operations which affect the whole cluster.
EmbeddedCacheManagerStartupException - Exception Class in org.infinispan.manager
An exception to encapsulate an error when starting up a cache manager
EmbeddedCacheManagerStartupException() - Constructor for exception class org.infinispan.manager.EmbeddedCacheManagerStartupException
 
EmbeddedCacheManagerStartupException(String) - Constructor for exception class org.infinispan.manager.EmbeddedCacheManagerStartupException
 
EmbeddedCacheManagerStartupException(String, Throwable) - Constructor for exception class org.infinispan.manager.EmbeddedCacheManagerStartupException
 
EmbeddedCacheManagerStartupException(Throwable) - Constructor for exception class org.infinispan.manager.EmbeddedCacheManagerStartupException
 
EmbeddedClusteredLockManagerFactory - Class in org.infinispan.lock
A ClusteredLockManager factory for embedded caches.
EmbeddedCounterManagerFactory - Class in org.infinispan.counter
A CounterManager factory for embedded cached.
EmbeddedExpirableMetadata$___Marshaller_57542ccf09e811f3460251c589ca05aed449dbbc1765661fa3851dddaac8dd71 - Class in org.infinispan.metadata
WARNING: Generated code! Do not edit!
EmbeddedExpirableMetadata$___Marshaller_57542ccf09e811f3460251c589ca05aed449dbbc1765661fa3851dddaac8dd71() - Constructor for class org.infinispan.metadata.EmbeddedExpirableMetadata$___Marshaller_57542ccf09e811f3460251c589ca05aed449dbbc1765661fa3851dddaac8dd71
 
EmbeddedJGroupsChannelConfigurator - Class in org.infinispan.remoting.transport.jgroups
A JGroups ProtocolStackConfigurator which
EmbeddedJGroupsChannelConfigurator(String, List<ProtocolConfiguration>, EmbeddedJGroupsChannelConfigurator.RemoteSites) - Constructor for class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator
 
EmbeddedJGroupsChannelConfigurator(String, List<ProtocolConfiguration>, EmbeddedJGroupsChannelConfigurator.RemoteSites, String) - Constructor for class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator
 
EmbeddedJGroupsChannelConfigurator.RemoteSite - Class in org.infinispan.remoting.transport.jgroups
 
EmbeddedJGroupsChannelConfigurator.RemoteSites - Class in org.infinispan.remoting.transport.jgroups
 
EmbeddedJGroupsChannelConfigurator.StackCombine - Enum in org.infinispan.remoting.transport.jgroups
 
embeddedKey() - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfiguration
 
embeddedKey(boolean) - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfigurationBuilder
Whether the key column(s) should be also written into the value object.
EmbeddedLifespanExpirableMetadata(long, EntryVersion) - Constructor for class org.infinispan.metadata.EmbeddedMetadata.EmbeddedLifespanExpirableMetadata
 
EmbeddedLifespanExpirableMetadata(long, NumericVersion, SimpleClusteredVersion) - Constructor for class org.infinispan.metadata.EmbeddedMetadata.EmbeddedLifespanExpirableMetadata
 
EmbeddedLifespanExpirableMetadata$___Marshaller_8da6d90d1f279b201c958e38c4b73ab7f2712dc1dc20b32c21334eacdfc6fd4b - Class in org.infinispan.metadata
WARNING: Generated code! Do not edit!
EmbeddedLifespanExpirableMetadata$___Marshaller_8da6d90d1f279b201c958e38c4b73ab7f2712dc1dc20b32c21334eacdfc6fd4b() - Constructor for class org.infinispan.metadata.EmbeddedLifespanExpirableMetadata$___Marshaller_8da6d90d1f279b201c958e38c4b73ab7f2712dc1dc20b32c21334eacdfc6fd4b
 
EmbeddedMaxIdleExpirableMetadata$___Marshaller_6887b83200c53e83a8233e38450ed44c3191b4968b578e16a63c12add76959ed - Class in org.infinispan.metadata
WARNING: Generated code! Do not edit!
EmbeddedMaxIdleExpirableMetadata$___Marshaller_6887b83200c53e83a8233e38450ed44c3191b4968b578e16a63c12add76959ed() - Constructor for class org.infinispan.metadata.EmbeddedMaxIdleExpirableMetadata$___Marshaller_6887b83200c53e83a8233e38450ed44c3191b4968b578e16a63c12add76959ed
 
EmbeddedMetadata - Class in org.infinispan.metadata
Metadata class for embedded caches.
EmbeddedMetadata.Builder - Class in org.infinispan.metadata
 
EmbeddedMetadata.EmbeddedExpirableMetadata - Class in org.infinispan.metadata
 
EmbeddedMetadata.EmbeddedLifespanExpirableMetadata - Class in org.infinispan.metadata
 
EmbeddedMetadata.EmbeddedMaxIdleExpirableMetadata - Class in org.infinispan.metadata
 
EmbeddedMetadata.Externalizer - Class in org.infinispan.metadata
 
EmbeddedMetadata$___Marshaller_d44c815cc3de96e45a01e06b569541e480035dc14f5499e3f3edc3fa7c6fe67 - Class in org.infinispan.metadata
WARNING: Generated code! Do not edit!
EmbeddedMetadata$___Marshaller_d44c815cc3de96e45a01e06b569541e480035dc14f5499e3f3edc3fa7c6fe67() - Constructor for class org.infinispan.metadata.EmbeddedMetadata$___Marshaller_d44c815cc3de96e45a01e06b569541e480035dc14f5499e3f3edc3fa7c6fe67
 
EmbeddedMultimapCache<K,V> - Class in org.infinispan.multimap.impl
Embedded implementation of MultimapCache
EmbeddedMultimapCache(Cache<K, Bucket<V>>, boolean) - Constructor for class org.infinispan.multimap.impl.EmbeddedMultimapCache
 
EmbeddedMultimapCacheManager<K,V> - Class in org.infinispan.multimap.impl
Embedded implementation of MultimapCacheManager
EmbeddedMultimapCacheManager(EmbeddedCacheManager) - Constructor for class org.infinispan.multimap.impl.EmbeddedMultimapCacheManager
 
EmbeddedMultimapCacheManagerFactory - Class in org.infinispan.multimap.api.embedded
A MultimapCache factory for embedded cached.
EmbeddedServerAdminOperationHandler - Class in org.infinispan.server.core.admin.embeddedserver
EmbeddedServerAdminOperationHandler is an implementation of AdminOperationsHandler which uses CacheContainerAdmin to apply changes to the cache manager configuration
EmbeddedServerAdminOperationHandler() - Constructor for class org.infinispan.server.core.admin.embeddedserver.EmbeddedServerAdminOperationHandler
 
EmbeddedTimeService - Class in org.infinispan.util
The default implementation of TimeService.
EmbeddedTimeService() - Constructor for class org.infinispan.util.EmbeddedTimeService
 
EmbeddedTransaction - Class in org.infinispan.transaction.tm
A Transaction implementation used by EmbeddedBaseTransactionManager.
EmbeddedTransaction(EmbeddedBaseTransactionManager) - Constructor for class org.infinispan.transaction.tm.EmbeddedTransaction
 
EmbeddedTransactionManager - Class in org.infinispan.transaction.tm
Simple transaction manager implementation that maintains transaction state in memory only.
EmbeddedTransactionManagerLookup - Class in org.infinispan.transaction.lookup
Returns an instance of EmbeddedTransactionManager.
EmbeddedTransactionManagerLookup() - Constructor for class org.infinispan.transaction.lookup.EmbeddedTransactionManagerLookup
 
EmbeddedUserTransaction - Class in org.infinispan.transaction.tm
A UserTransaction implementation that uses EmbeddedTransactionManager.
emitSessionCreatedEvent(Session) - Method in class org.infinispan.spring.common.session.AbstractApplicationPublisherBridge
 
emitSessionDeletedEvent(Session) - Method in class org.infinispan.spring.common.session.AbstractApplicationPublisherBridge
 
emitSessionDestroyedEvent(Session) - Method in class org.infinispan.spring.common.session.AbstractApplicationPublisherBridge
 
emitSessionExpiredEvent(Session) - Method in class org.infinispan.spring.common.session.AbstractApplicationPublisherBridge
 
empty() - Static method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
 
empty() - Static method in class org.infinispan.metadata.impl.PrivateMetadata
 
empty() - Static method in class org.infinispan.topology.CacheStatusResponse
 
EMPTY - Enum constant in enum org.infinispan.rest.ResponseWriter
 
EMPTY - Static variable in class org.infinispan.commons.configuration.attributes.AttributeSet
 
EMPTY - Static variable in interface org.infinispan.commons.stat.SimpleStat
 
EMPTY - Static variable in class org.infinispan.metadata.EmbeddedMetadata
 
EMPTY - Static variable in class org.infinispan.remoting.responses.UnsuccessfulResponse
 
EMPTY_ARRAY - Static variable in class org.infinispan.commons.util.concurrent.CompletableFutures
 
EMPTY_ARRAY - Static variable in class org.infinispan.commons.util.ImmutableListCopy
 
EMPTY_ARRAY - Static variable in interface org.infinispan.remoting.transport.Address
 
EMPTY_BIT_SET - Static variable in class org.infinispan.commons.util.EnumUtil
 
EMPTY_BYTE_ARRAY - Static variable in class org.infinispan.commons.util.Util
 
EMPTY_BYTE_ARRAY_ARRAY - Static variable in class org.infinispan.commons.util.Util
 
EMPTY_BYTES - Static variable in class org.infinispan.commons.marshall.WrappedByteArray
 
EMPTY_CLASS_ARRAY - Static variable in class org.infinispan.commons.util.ReflectionUtil
 
EMPTY_INSTANCE - Static variable in class org.infinispan.commons.io.ByteBufferImpl
 
EMPTY_OBJECT_ARRAY - Static variable in class org.infinispan.commons.util.Util
 
EMPTY_STRING_ARRAY - Static variable in class org.infinispan.client.hotrod.impl.HotRodURI
 
EMPTY_STRING_ARRAY - Static variable in class org.infinispan.commons.util.Util
 
EMPTY_THROWABLE_ARRAY - Static variable in class org.infinispan.commons.util.Util
 
EmptyAsyncInterceptorChain - Class in org.infinispan.interceptors
 
EmptyAsyncInterceptorChain() - Constructor for class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
EmptyConstructorFactory - Class in org.infinispan.factories
Factory for building global-scope components which have default empty constructors
EmptyConstructorFactory() - Constructor for class org.infinispan.factories.EmptyConstructorFactory
 
EmptyConstructorNamedCacheFactory - Class in org.infinispan.factories
Simple factory that just uses reflection and an empty constructor of the component type.
EmptyConstructorNamedCacheFactory() - Constructor for class org.infinispan.factories.EmptyConstructorNamedCacheFactory
 
emptyConsumer() - Static method in class org.infinispan.commons.reactive.RxJavaInterop
 
emptyElementTag - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
EmptyRaftManager - Enum in org.infinispan.remoting.transport.impl
A NO-OP implementation of RaftManager.
emptyResponse(HotRodHeader, HotRodServer, Channel, OperationStatus) - Method in class org.infinispan.server.hotrod.Encoder4x
 
emptyResponse(HotRodHeader, HotRodServer, Channel, OperationStatus) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
 
emptyString() - Static method in class org.infinispan.util.ByteString
 
enable() - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
Enables authentication
enable() - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
Enables the SSL support
enable() - Method in class org.infinispan.client.hotrod.configuration.StatisticsConfigurationBuilder
Enables client-side statistics collection
enable() - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
 
enable() - Method in class org.infinispan.configuration.cache.IndexReaderConfigurationBuilder
 
enable() - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
 
enable() - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
If true, all modifications to this cache store happen asynchronously on a separate thread.
enable() - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
Enables authorization for this cache.
enable() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
enable() - Method in interface org.infinispan.configuration.cache.IndexingConfigurationChildBuilder
 
enable() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
 
enable() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
Deprecated.
Enable statistics gathering and reporting
enable() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
enable() - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
Enable recovery for this cache
enable() - Method in class org.infinispan.configuration.cache.StatisticsConfigurationBuilder
Enable statistics gathering.
enable() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
 
enable() - Method in class org.infinispan.configuration.global.GlobalJmxConfigurationBuilder
Enables JMX in the cache manager.
enable() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
Deprecated.
Enables JMX in the cache manager.
enable() - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
 
enable() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
Enables authentication
enable() - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
Enables the SSL support
enable() - Method in class org.infinispan.rest.configuration.AuthenticationConfigurationBuilder
 
enable() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
 
enable() - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
Enables the SSL support
enable() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
 
enable(boolean) - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
 
enableBackOff() - Method in class org.infinispan.xsite.irac.IracExecutor
 
enabled - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
enabled() - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfiguration
 
enabled() - Method in enum org.infinispan.client.hotrod.configuration.NearCacheMode
 
enabled() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
 
enabled() - Method in class org.infinispan.client.hotrod.configuration.StatisticsConfiguration
 
enabled() - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
If true, all modifications to this cache store happen asynchronously, on a separate thread.
enabled() - Method in class org.infinispan.configuration.cache.AuthorizationConfiguration
 
enabled() - Method in class org.infinispan.configuration.cache.BackupConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
Since 14.0. To be removed without replacement.
enabled() - Method in class org.infinispan.configuration.cache.GroupsConfiguration
If grouping support is enabled, then Group annotations are honored and any configured groupers will be invoked
enabled() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
Enable grouping support so that Group annotations are honored and any configured groupers will be invoked
enabled() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
Determines if indexing is enabled for this cache configuration.
enabled() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
enabled() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfiguration
 
enabled() - Method in interface org.infinispan.configuration.cache.JMXStatisticsConfiguration
Deprecated.
 
enabled() - Method in class org.infinispan.configuration.cache.L1Configuration
 
enabled() - Method in class org.infinispan.configuration.cache.RecoveryConfiguration
Determines if recovery is enabled for the cache.
enabled() - Method in class org.infinispan.configuration.cache.StatisticsConfiguration
 
enabled() - Method in class org.infinispan.configuration.cache.TakeOfflineConfiguration
 
enabled() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
enabled() - Method in class org.infinispan.configuration.global.GlobalJmxConfiguration
 
enabled() - Method in class org.infinispan.configuration.global.GlobalJmxConfigurationBuilder
 
enabled() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
Deprecated.
 
enabled() - Method in class org.infinispan.configuration.global.GlobalMetricsConfiguration
Metrics are enabled if at least one of the metric types is enabled.
enabled() - Method in class org.infinispan.configuration.global.GlobalMetricsConfigurationBuilder
Metrics are enabled if at least one of the metric types is enabled.
enabled() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
 
enabled() - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
 
enabled() - Method in class org.infinispan.jmx.CacheJmxRegistration
Checks that JMX is effectively enabled.
enabled() - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
Checks that JMX is effectively enabled.
enabled() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
 
enabled() - Method in class org.infinispan.persistence.remote.configuration.SslConfiguration
 
enabled() - Method in class org.infinispan.rest.configuration.AuthenticationConfiguration
 
enabled() - Method in class org.infinispan.rest.configuration.AuthenticationConfigurationBuilder
 
enabled() - Method in class org.infinispan.server.core.configuration.SslConfiguration
 
enabled() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfiguration
 
enabled() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
 
enabled(boolean) - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
Configures whether authentication should be enabled or not
enabled(boolean) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
Enables or disables the SSL support
enabled(boolean) - Method in class org.infinispan.client.hotrod.configuration.StatisticsConfigurationBuilder
Enables or disables client-side statistics collection
enabled(boolean) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
enabled(boolean) - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
Enables/disables authorization for this cache.
enabled(boolean) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 14.0. To be removed without replacement.
enabled(boolean) - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
Enable grouping support so that Group annotations are honored and any configured groupers will be invoked
enabled(boolean) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
enabled(boolean) - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
Deprecated.
Enable or disable statistics gathering and reporting
enabled(boolean) - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
enabled(boolean) - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
Enable recovery for this cache
enabled(boolean) - Method in class org.infinispan.configuration.cache.StatisticsConfigurationBuilder
Enable or disable statistics gathering.
enabled(boolean) - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
 
enabled(boolean) - Method in class org.infinispan.configuration.global.GlobalJmxConfigurationBuilder
Enables JMX in the cache manager.
enabled(boolean) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
Deprecated.
Enables JMX in the cache manager.
enabled(boolean) - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
Enables or disables the storage of global state.
enabled(boolean) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
Configures whether authentication should be enabled or not
enabled(boolean) - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
Enables or disables the SSL support
enabled(boolean) - Method in class org.infinispan.rest.configuration.AuthenticationConfigurationBuilder
 
enabled(boolean) - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
Enables or disables the SSL support
enabled(boolean) - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
 
ENABLED - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
ENABLED - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
 
ENABLED - Static variable in class org.infinispan.client.hotrod.configuration.StatisticsConfiguration
 
ENABLED - Static variable in class org.infinispan.configuration.cache.AsyncStoreConfiguration
 
ENABLED - Static variable in class org.infinispan.configuration.cache.AuthorizationConfiguration
 
ENABLED - Static variable in class org.infinispan.configuration.cache.GroupsConfiguration
 
ENABLED - Static variable in class org.infinispan.configuration.cache.IndexingConfiguration
 
ENABLED - Static variable in class org.infinispan.configuration.cache.InvocationBatchingConfiguration
 
ENABLED - Static variable in class org.infinispan.configuration.cache.L1Configuration
 
ENABLED - Static variable in class org.infinispan.configuration.cache.RecoveryConfiguration
 
ENABLED - Static variable in class org.infinispan.configuration.cache.StatisticsConfiguration
 
ENABLED - Static variable in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
ENABLED - Static variable in class org.infinispan.configuration.global.GlobalJmxConfiguration
 
ENABLED - Static variable in class org.infinispan.configuration.global.GlobalStateConfiguration
 
enabledBackups() - Method in class org.infinispan.configuration.cache.SitesConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
Since 14.0. To be removed without replacement. Use SitesConfiguration.allBackups() or SitesConfiguration.allBackupsStream().
enabledBackupStream() - Method in class org.infinispan.configuration.cache.SitesConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
Since 14.0. To be removed without replacement. Use SitesConfiguration.allBackups() or SitesConfiguration.allBackupsStream().
EnableInfinispanEmbeddedHttpSession - Annotation Type in org.infinispan.spring.embedded.session.configuration
Add this annotation to a @Configuration class to expose the SessionRepositoryFilter as a bean named "springSessionRepositoryFilter" and backed on Infinispan.
EnableInfinispanRemoteHttpSession - Annotation Type in org.infinispan.spring.remote.session.configuration
Add this annotation to a @Configuration class to expose the SessionRepositoryFilter as a bean named "springSessionRepositoryFilter" and backed on Infinispan.
enableReaper() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
Enable the background reaper to test entries for expiration.
enableRemoteQuery() - Method in class org.infinispan.query.impl.LifecycleManager
 
encode(byte[]) - Static method in class org.infinispan.commons.dataconversion.Base16Codec
 
encode(int) - Static method in class org.infinispan.commons.io.SignedNumeric
 
encode(CounterState) - Method in class org.infinispan.counter.api.CounterState$___Marshaller_93aa5d27c0d57954ec79247b055254b02d5c87a64e0764e392772b387eb7542d
 
encode(CounterType) - Method in class org.infinispan.counter.api.CounterType$___Marshaller_4dd4ef0972bf79fd96da56b8ce9348d84b1c42596acd7df3abf86c5e467887f5
 
encode(Storage) - Method in class org.infinispan.counter.api.Storage$___Marshaller_ed04a8616efd062a7c88e9e578efa97c99224ac3211dd20ca76376455f84a9ae
 
encode(AuthorizationPermission) - Method in class org.infinispan.security.AuthorizationPermission$___Marshaller_e4a67ef18a1f2ebc30b0d1e396f24e2098535911da768fa734361c9903b14240
 
encodeConfiguration(CounterConfiguration, Consumer<Byte>, LongConsumer, IntConsumer) - Static method in class org.infinispan.counter.util.EncodeUtil
Encodes the configuration.
encodeContent(Object, MediaType) - Method in class org.infinispan.commons.dataconversion.AbstractTranscoder
Encode the content after transcoding if necessary.
encodeEntries(Map<? extends K, ?>) - Method in class org.infinispan.functional.impl.ReadOnlyMapImpl
 
encodeEntries(Map<? extends K, ?>) - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
 
encodeEntries(Map<? extends K, ?>) - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
encodeKeys(Set<? extends K>) - Method in class org.infinispan.functional.impl.ReadOnlyMapImpl
 
encodeKeys(Set<? extends K>) - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
 
encodeKeys(Set<? extends K>) - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
encoder - Variable in class org.infinispan.server.core.transport.NettyChannelInitializer
 
encoder() - Method in class org.infinispan.server.hotrod.HotRodHeader
 
Encoder - Interface in org.infinispan.commons.dataconversion
Deprecated, for removal: This API element is subject to removal in a future version.
Since 12.1, without replacement. To be removed in a future version.
ENCODER - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
ENCODER_ENTRY_MAPPER - Static variable in interface org.infinispan.commons.marshall.Ids
 
ENCODER_KEY_MAPPER - Static variable in interface org.infinispan.commons.marshall.Ids
 
ENCODER_VALUE_MAPPER - Static variable in interface org.infinispan.commons.marshall.Ids
 
Encoder4x - Class in org.infinispan.server.hotrod
 
Encoder4x() - Constructor for class org.infinispan.server.hotrod.Encoder4x
 
EncoderCache<K,V> - Class in org.infinispan.cache.impl
Cache decoration that makes use of the Encoder and Wrapper to convert between storage value and read/write value.
EncoderCache(AdvancedCache<K, V>, InternalEntryFactory, BasicComponentRegistry, DataConversion, DataConversion) - Constructor for class org.infinispan.cache.impl.EncoderCache
 
EncoderEntryMapper<K,V,T> - Class in org.infinispan.cache.impl
Function that uses an encoder to converter entries from the configured storage format to the requested format.
EncoderEntryMapper.Externalizer - Class in org.infinispan.cache.impl
 
EncoderIds - Interface in org.infinispan.commons.dataconversion
Deprecated, for removal: This API element is subject to removal in a future version.
since 12.1, to be removed in a future version.
EncoderKeyMapper<K> - Class in org.infinispan.cache.impl
Function that uses a keyEncoder to converter keys from the configured storage format to the requested format.
EncoderKeyMapper(DataConversion) - Constructor for class org.infinispan.cache.impl.EncoderKeyMapper
 
EncoderKeyMapper.Externalizer - Class in org.infinispan.cache.impl
 
EncoderRegistry - Interface in org.infinispan.marshall.core
Manages existent Encoder, Wrapper and Transcoder instances.
EncoderRegistryFactory - Class in org.infinispan.factories
Factory for EncoderRegistryImpl objects.
EncoderRegistryFactory() - Constructor for class org.infinispan.factories.EncoderRegistryFactory
 
EncoderRegistryImpl - Class in org.infinispan.marshall.core
 
EncoderRegistryImpl() - Constructor for class org.infinispan.marshall.core.EncoderRegistryImpl
 
EncoderValueMapper<V> - Class in org.infinispan.cache.impl
Function that uses a valueEncoder to converter values from the configured storage format to the requested format.
EncoderValueMapper(DataConversion) - Constructor for class org.infinispan.cache.impl.EncoderValueMapper
 
EncoderValueMapper.Externalizer - Class in org.infinispan.cache.impl
 
encodeTimeUnits(long, TimeUnit, long, TimeUnit) - Static method in class org.infinispan.client.hotrod.impl.TimeUnitParam
 
encodeTimeUnits(long, TimeUnit, long, TimeUnit) - Static method in enum org.infinispan.server.hotrod.TimeUnitValue
 
encodeTypeAndStorage(CounterConfiguration) - Static method in class org.infinispan.counter.util.EncodeUtil
Encodes the Storage and the CounterType.
EncodeUtil - Class in org.infinispan.counter.util
Utility class to handle encoding or decoding counter's classes.
encoding() - Method in class org.infinispan.configuration.cache.AbstractCustomInterceptorsConfigurationChildBuilder
 
encoding() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationChildBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.AbstractPersistenceConfigurationChildBuilder
 
encoding() - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
encoding() - Method in class org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.remote.configuration.AbstractSecurityConfigurationChildBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.AbstractTransportConfigurationChildBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
 
encoding() - Method in class org.infinispan.security.impl.CreatePermissionConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.CustomStoreConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.IndexReaderConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder.StringTableManipulationConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.jdbc.common.configuration.ManagedConnectionFactoryConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.remote.configuration.MechanismConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.MemoryStorageConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.QueryConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.SecurityConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.parsing.SFSToSIFSConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.StatisticsConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
 
encoding() - Method in class org.infinispan.persistence.remote.configuration.TrustStoreConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
 
encoding() - Method in class org.infinispan.configuration.cache.Configuration
 
encoding() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
encoding() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
ENCODING - Enum constant in enum org.infinispan.configuration.parsing.Element
 
EncodingConfiguration - Class in org.infinispan.configuration.cache
Controls encoding configuration for keys and values in the cache.
EncodingConfiguration(AttributeSet, ContentTypeConfiguration, ContentTypeConfiguration) - Constructor for class org.infinispan.configuration.cache.EncodingConfiguration
 
EncodingConfigurationBuilder - Class in org.infinispan.configuration.cache
 
EncodingException - Exception Class in org.infinispan.commons.dataconversion
 
EncodingException(String) - Constructor for exception class org.infinispan.commons.dataconversion.EncodingException
 
EncodingException(String, Throwable) - Constructor for exception class org.infinispan.commons.dataconversion.EncodingException
 
EncodingFunction<T> - Interface in org.infinispan.cache.impl
This is a marker interface to signal that this function may perform an encoding of the provided value.
EncodingUtils - Class in org.infinispan.commons.dataconversion
Deprecated.
Use the org.infinispan.encoding.DataConversion obtained from the AdvancedCache.
encryption() - Method in class org.infinispan.rest.configuration.RestServerConfiguration
 
encryption() - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
 
encryption() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
 
encryption() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
 
ENCRYPTION - Enum constant in enum org.infinispan.persistence.remote.configuration.Element
 
ENCRYPTION - Enum constant in enum org.infinispan.server.hotrod.configuration.Element
 
EncryptionConfiguration - Class in org.infinispan.server.core.configuration
 
EncryptionConfigurationBuilder - Class in org.infinispan.server.core.configuration
 
EncryptionConfigurationBuilder(SslConfigurationBuilder) - Constructor for class org.infinispan.server.core.configuration.EncryptionConfigurationBuilder
 
end(Xid, int) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
END - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
 
END_DOCUMENT - Enum constant in enum org.infinispan.commons.configuration.io.ConfigurationReader.ElementType
 
END_DOCUMENT - Static variable in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Logical end of the xml document.
END_ELEMENT - Enum constant in enum org.infinispan.commons.configuration.io.ConfigurationReader.ElementType
 
END_ITERATOR - Static variable in interface org.infinispan.commons.marshall.Ids
 
END_SIZE - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
 
END_TAG - Static variable in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returned from getEventType(), next(), or nextToken() when an end tag was read.
endAtomic() - Method in class org.infinispan.batch.AutoBatchSupport
 
endBatch(boolean) - Method in class org.infinispan.batch.BatchContainer
 
endBatch(boolean) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
endBatch(boolean) - Method in class org.infinispan.cache.impl.CacheImpl
 
endBatch(boolean) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
endBatch(boolean) - Method in interface org.infinispan.commons.api.BatchingCache
Completes a batch if one has been started using BatchingCache.startBatch().
endBatch(boolean) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
endBatch(boolean, boolean) - Method in class org.infinispan.batch.BatchContainer
 
endMapItem() - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
endMapItem() - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationReader
 
endMapItem() - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationReader
 
endMapItem() - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader
 
endStateTransfer(String) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateConsumer
It notifies the end of state transfer from other site.
endStateTransfer(String) - Method in class org.infinispan.xsite.statetransfer.XSiteStateConsumerImpl
 
EnhancedQueueExecutorFactory - Class in org.infinispan.factories.threads
Executor Factory used for blocking executors which utilizes EnhancedQueueExecutor internally.
EnhancedQueueExecutorFactory(int, int, int, long) - Constructor for class org.infinispan.factories.threads.EnhancedQueueExecutorFactory
 
enlist(Transaction, LocalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
 
enlist(Transaction, LocalTransaction) - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
enlistClientTransaction(Transaction, LocalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
 
enlistClientTransaction(Transaction, LocalTransaction) - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
enlistResource(XAResource) - Method in class org.infinispan.commons.tx.TransactionImpl
Enlist an XA resource with this transaction.
ensureAttributesCapacity(int) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
Make sure that in attributes temporary array is enough space.
ensureElementsCapacity() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
Make sure that we have enough space to keep element stack if passed size.
ensureEntityCapacity() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
ensureNamespacesCapacity(int) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
ensurePC(int) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
enterSynchronizationAsync(CompletableFuture<Void>) - Method in class org.infinispan.transaction.impl.RemoteTransaction
 
entity(Object) - Method in interface org.infinispan.rest.framework.impl.RestResponseBuilder
 
entity(Object) - Method in class org.infinispan.rest.framework.impl.SimpleRestResponse.Builder
 
entity(Object) - Method in class org.infinispan.rest.NettyRestResponse.Builder
 
ENTITY_PROJECTION_KEY - Static variable in class org.infinispan.query.remote.json.JsonQueryResponse
 
ENTITY_REF - Static variable in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
An entity reference was just read; this token is available from nextToken() only.
EntityConverter - Interface in org.infinispan.search.mapper.mapping
Can convert an entity before indexing it.
EntityConverter.ConvertedEntity - Interface in org.infinispan.search.mapper.mapping
The result of an entity conversion
entityEnd - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
EntityLoader<E> - Class in org.infinispan.query.impl
 
EntityLoader(AdvancedCache<?, E>, LocalQueryStatistics) - Constructor for class org.infinispan.query.impl.EntityLoader
 
entityName - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
entityName() - Method in interface org.infinispan.search.mapper.mapping.EntityConverter.ConvertedEntity
 
entityNameBuf - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
entityNameHash - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
EntityProjection - Class in org.infinispan.query.remote.json
 
EntityProjection(Object) - Constructor for class org.infinispan.query.remote.json.EntityProjection
 
EntityReference - Interface in org.infinispan.search.mapper.common
A reference to an indexed entity.
entityReferenceFactory() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
 
EntityReferenceImpl - Class in org.infinispan.search.mapper.common.impl
 
EntityReferenceImpl(PojoRawTypeIdentifier<?>, String, Object) - Constructor for class org.infinispan.search.mapper.common.impl.EntityReferenceImpl
 
entityRefName - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
entityReplacement - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
entityReplacementBuf - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
entries - Variable in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
entries() - Method in interface org.infinispan.functional.FunctionalMap.ReadOnlyMap
Provides a Traversable that allows clients to navigate all cached entries.
entries() - Method in class org.infinispan.functional.impl.ReadOnlyMapImpl
 
ENTRY_WRITER - Static variable in interface org.infinispan.persistence.remote.ExternalizerIds
 
entryAdded(InternalCacheEntry<K, V>) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
entryCommitted(CacheNotifier, FunctionalNotifier, boolean, boolean, boolean, CacheEntry, InvocationContext, FlagAffectedCommand, Object, Metadata, EvictionManager) - Static method in class org.infinispan.notifications.cachelistener.NotifyHelper
 
entryCreated(long) - Method in interface org.infinispan.container.offheap.OffHeapConcurrentMap.EntryListener
Invoked when an entry is about to be created.
entryExpiredInMemory(InternalCacheEntry<K, V>, long, boolean) - Method in class org.infinispan.expiration.impl.ClusterExpirationManager
 
entryExpiredInMemory(InternalCacheEntry<K, V>, long, boolean) - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
entryExpiredInMemory(InternalCacheEntry<K, V>, long, boolean) - Method in interface org.infinispan.expiration.impl.InternalExpirationManager
This should be invoked passing in an entry that is now expired.
entryFactory - Variable in class org.infinispan.container.impl.AbstractInternalDataContainer
 
entryFactory - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
 
EntryFactory - Interface in org.infinispan.container.impl
A factory for constructing MVCCEntry instances for use in the InvocationContext.
EntryFactoryImpl - Class in org.infinispan.container.impl
EntryFactory implementation to be used for optimistic locking scheme.
EntryFactoryImpl() - Constructor for class org.infinispan.container.impl.EntryFactoryImpl
 
entryFromResultSet(ResultSet, Object, boolean, Predicate<? super K>) - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
 
entryFromResultSet(ResultSet, Object, boolean, Predicate<? super K>) - Method in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.SchemaTableOperations
 
EntryHeader - Class in org.infinispan.persistence.sifs
 
EntryHeader(ByteBuffer) - Constructor for class org.infinispan.persistence.sifs.EntryHeader
 
EntryHeader(ByteBuffer, boolean) - Constructor for class org.infinispan.persistence.sifs.EntryHeader
 
EntryInfo - Class in org.infinispan.persistence.sifs
 
EntryInfo(int, int, int) - Constructor for class org.infinispan.persistence.sifs.EntryInfo
 
entryIterator() - Method in interface org.infinispan.query.dsl.Query
Returns a CloseableIterator over the results, including both key and value.
entryIterator() - Method in interface org.infinispan.query.impl.IndexedQuery
Returns the matching entries (both key and value).
entryIterator() - Method in class org.infinispan.query.impl.IndexedQueryImpl
 
entryIterator(IntSet) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
entryIterator(IntSet) - Method in interface org.infinispan.client.hotrod.impl.InternalRemoteCache
 
entryIterator(IntSet) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
EntryIterator(Iterator<InternalCacheEntry<K, V>>) - Constructor for class org.infinispan.container.impl.AbstractInternalDataContainer.EntryIterator
 
EntryLoader<K,V> - Interface in org.infinispan.persistence.util
Interface that describes methods used for loading entries from the underlying PersistenceManager and store those entries into the DataContainer if necessary.
EntryLookup - Interface in org.infinispan.context
Interface that can look up MVCC wrapped entries.
EntryMergePolicy<K,V> - Interface in org.infinispan.conflict
 
EntryMergePolicyFactory - Interface in org.infinispan.conflict
 
EntryMergePolicyFactoryRegistry - Class in org.infinispan.conflict
A registry for EntryMergePolicyFactory implementations, which allows EntryMergePolicy implementations to be eagerly/lazily loaded across multiple contexts.
EntryMergePolicyFactoryRegistry() - Constructor for class org.infinispan.conflict.EntryMergePolicyFactoryRegistry
 
EntryMetadata - Class in org.infinispan.persistence.sifs
Object to hold metadata bytes and timestamps.
EntryMetadata(byte[], long, long) - Constructor for class org.infinispan.persistence.sifs.EntryMetadata
 
EntryMetaFactory - Class in org.infinispan.factories
 
EntryMetaFactory() - Constructor for class org.infinispan.factories.EntryMetaFactory
 
entryPublisher(Predicate<? super K>, boolean, boolean) - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader
Deprecated.
Publishes all entries from this store.
entryPublisher(Predicate<? super K>, boolean, boolean) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
entryPublisher(IntSet, Predicate<? super K>, boolean, boolean) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
Deprecated.
Publishes all entries from this store.
entryPublisher(IntSet, Predicate<? super K>, boolean, boolean) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
entryPublisher(IntSet, Set<K>, Set<K>, long, DeliveryGuarantee, Function<? super Publisher<CacheEntry<K, V>>, ? extends Publisher<R>>) - Method in interface org.infinispan.reactive.publisher.impl.LocalPublisherManager
Performs the given transformer on data in the cache that is local, resulting in a stream of values of possibly varying size.
entryPublisher(IntSet, Set<K>, Set<K>, long, DeliveryGuarantee, Function<? super Publisher<CacheEntry<K, V>>, ? extends Publisher<R>>) - Method in class org.infinispan.reactive.publisher.impl.LocalPublisherManagerImpl
 
entryPublisher(IntSet, Set<K>, InvocationContext, long, DeliveryGuarantee, int, Function<? super Publisher<CacheEntry<K, V>>, ? extends Publisher<R>>) - Method in interface org.infinispan.reactive.publisher.impl.ClusterPublisherManager
Performs the given transformer on data in the cache, resulting in multiple values.
entryPublisher(IntSet, Set<K>, InvocationContext, long, DeliveryGuarantee, int, Function<? super Publisher<CacheEntry<K, V>>, ? extends Publisher<R>>) - Method in class org.infinispan.reactive.publisher.impl.ClusterPublisherManagerImpl
 
entryPublisher(IntSet, Set<K>, InvocationContext, long, DeliveryGuarantee, int, Function<? super Publisher<CacheEntry<K, V>>, ? extends Publisher<R>>) - Method in class org.infinispan.reactive.publisher.impl.LocalClusterPublisherManagerImpl
 
entryPublisher(IntSet, Set<K>, InvocationContext, long, DeliveryGuarantee, int, Function<? super Publisher<CacheEntry<K, V>>, ? extends Publisher<R>>) - Method in class org.infinispan.reactive.publisher.impl.PartitionAwareClusterPublisherManager
 
entryPurged(K) - Method in interface org.infinispan.persistence.spi.AdvancedCacheWriter.PurgeListener
Deprecated.
Optional.
EntryRecord - Class in org.infinispan.persistence.sifs
Helper for reading/writing entries into file.
entryReduction(boolean, IntSet, Set<K>, Set<K>, long, DeliveryGuarantee, Function<? super Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>>, Function<? super Publisher<R>, ? extends CompletionStage<R>>) - Method in interface org.infinispan.reactive.publisher.impl.LocalPublisherManager
Performs the given transformer and finalizer on data in the cache that is local, resulting in a single value.
entryReduction(boolean, IntSet, Set<K>, Set<K>, long, DeliveryGuarantee, Function<? super Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>>, Function<? super Publisher<R>, ? extends CompletionStage<R>>) - Method in class org.infinispan.reactive.publisher.impl.LocalPublisherManagerImpl
 
entryReduction(boolean, IntSet, Set<K>, InvocationContext, long, DeliveryGuarantee, Function<? super Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>>, Function<? super Publisher<R>, ? extends CompletionStage<R>>) - Method in interface org.infinispan.reactive.publisher.impl.ClusterPublisherManager
Performs the given transformer and finalizer on data in the cache, resulting in a single value.
entryReduction(boolean, IntSet, Set<K>, InvocationContext, long, DeliveryGuarantee, Function<? super Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>>, Function<? super Publisher<R>, ? extends CompletionStage<R>>) - Method in class org.infinispan.reactive.publisher.impl.ClusterPublisherManagerImpl
 
entryReduction(boolean, IntSet, Set<K>, InvocationContext, long, DeliveryGuarantee, Function<? super Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>>, Function<? super Publisher<R>, ? extends CompletionStage<R>>) - Method in class org.infinispan.reactive.publisher.impl.LocalClusterPublisherManagerImpl
 
entryReduction(boolean, IntSet, Set<K>, InvocationContext, long, DeliveryGuarantee, Function<? super Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>>, Function<? super Publisher<R>, ? extends CompletionStage<R>>) - Method in class org.infinispan.reactive.publisher.impl.PartitionAwareClusterPublisherManager
 
entryRemoved(long) - Method in interface org.infinispan.container.offheap.OffHeapConcurrentMap.EntryListener
Invoked when an entry is about to be removed.
entryRemoved(InternalCacheEntry<K, V>) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
entryReplaced(long, long) - Method in interface org.infinispan.container.offheap.OffHeapConcurrentMap.EntryListener
Invoked when an entry is about to be replaced with a new one.
entryRetrieved(long) - Method in interface org.infinispan.container.offheap.OffHeapConcurrentMap.EntryListener
Invoked when an entry is successfully retrieved.
entrySet - Variable in class org.infinispan.commons.util.AbstractMap
 
entrySet() - Method in interface org.infinispan.Cache
Returns a set view of the mappings contained in this cache and cache loader across the entire cluster.
entrySet() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
entrySet() - Method in class org.infinispan.cache.impl.CacheImpl
 
entrySet() - Method in class org.infinispan.cache.impl.DecoratedCache
 
entrySet() - Method in class org.infinispan.cache.impl.EncoderCache
 
entrySet() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
entrySet() - Method in interface org.infinispan.client.hotrod.RemoteCache
 
entrySet() - Method in class org.infinispan.commons.util.AbstractDelegatingMap
 
entrySet() - Method in class org.infinispan.commons.util.ArrayMap
 
entrySet() - Method in class org.infinispan.commons.util.FastCopyHashMap
 
entrySet() - Method in class org.infinispan.commons.util.WeakValueHashMap
 
entrySet() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
entrySet() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
 
entrySet() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
entrySet(IntSet) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
entrySet(IntSet) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
entrySet(IntSet) - Method in interface org.infinispan.client.hotrod.RemoteCache
This method is identical to RemoteCache.entrySet() except that it will only return entries that map to the given segments.
EntrySet() - Constructor for class org.infinispan.cache.impl.SimpleCacheImpl.EntrySet
 
EntrySet() - Constructor for class org.infinispan.commons.util.FastCopyHashMap.EntrySet
 
EntrySetBase() - Constructor for class org.infinispan.cache.impl.SimpleCacheImpl.EntrySetBase
 
EntrySizeCalculator<K,V> - Interface in org.infinispan.commons.util
 
entryToKeyFunction() - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
 
entryToKeyFunction() - Method in class org.infinispan.cache.impl.CacheBackedEntrySet
 
entryToKeyFunction() - Method in class org.infinispan.cache.impl.CacheBackedKeySet
 
entryToKeyFunction() - Static method in class org.infinispan.commons.reactive.RxJavaInterop
Provides a Function that can be used to convert from an instance of Map.Entry to the key of the entry.
entryToKeyFunction() - Static method in class org.infinispan.stream.StreamMarshalling
Provides a function that returns the key of the entry when invoked.
entryToValueFunction() - Static method in class org.infinispan.commons.reactive.RxJavaInterop
Provides a Function that can be used to convert from an instance of Map.Entry to the value of the entry.
entryToValueFunction() - Static method in class org.infinispan.stream.StreamMarshalling
Provides a function that returns the value of the entry when invoked.
entryUpdated(InternalCacheEntry<K, V>, InternalCacheEntry<K, V>) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
entryVersion() - Method in class org.infinispan.metadata.impl.PrivateMetadata
 
entryVersion(IncrementableEntryVersion) - Method in class org.infinispan.metadata.impl.PrivateMetadata.Builder
Sets the IncrementableEntryVersion to store.
EntryVersion - Interface in org.infinispan.container.versioning
A version is used to compare entries against one another.
EntryVersionParamExternalizer() - Constructor for class org.infinispan.marshall.exts.MetaParamExternalizers.EntryVersionParamExternalizer
 
EntryView - Class in org.infinispan.functional
Entry views expose cached entry information to the user.
EntryView.ReadEntryView<K,V> - Interface in org.infinispan.functional
Expose read-only information about a cache entry potentially associated with a key in the functional map.
EntryView.ReadWriteEntryView<K,V> - Interface in org.infinispan.functional
Expose information about a cache entry potentially associated with a key in the functional map, and allows that cache entry to be written with new value and/or new metadata parameters.
EntryView.WriteEntryView<K,V> - Interface in org.infinispan.functional
Expose a write-only facade for a cache entry potentially associated with a key in the functional map which allows the cache entry to be written with new value and/or new metadata parameters.
EntryViews - Class in org.infinispan.functional.impl
Entry views implementation class holder.
EntryViews.AccessLoggingReadWriteView<K,V> - Interface in org.infinispan.functional.impl
 
EntryViews.NoValueReadOnlyViewExternalizer - Class in org.infinispan.functional.impl
 
EntryViews.ReadOnlySnapshotViewExternalizer - Class in org.infinispan.functional.impl
 
EntryViews.ReadWriteSnapshotViewExternalizer - Class in org.infinispan.functional.impl
 
EntryWrapper<K,V> - Class in org.infinispan.util
Wrapper for CacheEntry(s) that can be used to update the cache when it's value is set.
EntryWrapper(Cache<K, V>, CacheEntry<K, V>) - Constructor for class org.infinispan.util.EntryWrapper
Creates a new entry wrapper given the cache and entry.
EntryWriter(V) - Constructor for class org.infinispan.persistence.remote.upgrade.MigrationTask.EntryWriter
 
EntryWriterExternalizer() - Constructor for class org.infinispan.persistence.remote.upgrade.MigrationTask.EntryWriterExternalizer
 
ENUM_COLLECTION - Static variable in interface org.infinispan.commons.configuration.attributes.AttributeSerializer
 
ENUM_SET_ID - Static variable in interface org.infinispan.commons.marshall.Ids
 
enumArrayOf(long, Class<E>) - Static method in class org.infinispan.commons.util.EnumUtil
 
EnumerationList<T> - Class in org.infinispan.commons.util
An Enumeration → List adaptor
EnumerationList(Enumeration<T>) - Constructor for class org.infinispan.commons.util.EnumerationList
Constructor
EnumExternalizer - Class in org.infinispan.marshall.exts
An externalizer for internal enum types.
EnumExternalizer() - Constructor for class org.infinispan.marshall.exts.EnumExternalizer
 
EnumSetExternalizer - Class in org.infinispan.marshall.exts
EnumSet externalizer.
EnumSetExternalizer() - Constructor for class org.infinispan.marshall.exts.EnumSetExternalizer
 
enumSetOf(long, Class<E>) - Static method in class org.infinispan.commons.util.EnumUtil
 
EnumUtil - Class in org.infinispan.commons.util
Utilities method to Enums.
epollNotAvailable(String) - Method in interface org.infinispan.client.hotrod.logging.Log
 
epollNotAvailable(String) - Method in interface org.infinispan.server.core.logging.Log
 
eq(Object) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Deprecated.
Checks that the left argument is equal to the given value.
eq(Object, Object) - Static method in class org.infinispan.commons.util.AbstractMap
 
equal(Object) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
Deprecated.
EQUAL - Enum constant in enum org.infinispan.container.versioning.InequalVersionComparisonResult
Denotes that the two versions being compared are equal.
equalityPredicate(Object) - Static method in class org.infinispan.stream.StreamMarshalling
Provides a predicate that returns true when the object is equal.
equals(long, int) - Method in class org.infinispan.persistence.sifs.EntryInfo
 
equals(Object) - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
 
equals(Object) - Method in class org.infinispan.client.hotrod.impl.ClientTopology
 
equals(Object) - Method in class org.infinispan.commands.CommandInvocationId
 
equals(Object) - Method in class org.infinispan.commons.configuration.AbstractTypedPropertiesConfiguration
 
equals(Object) - Method in class org.infinispan.commons.configuration.attributes.Attribute
 
equals(Object) - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
 
equals(Object) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
 
equals(Object) - Method in class org.infinispan.commons.configuration.attributes.ConfigurationElement
 
equals(Object) - Method in class org.infinispan.commons.dataconversion.MediaType
 
equals(Object) - Method in class org.infinispan.commons.hash.MurmurHash3
 
equals(Object) - Method in class org.infinispan.commons.io.ByteBufferImpl
 
equals(Object) - Method in class org.infinispan.commons.marshall.WrappedByteArray
 
equals(Object) - Method in class org.infinispan.commons.tx.TransactionImpl
 
equals(Object) - Method in class org.infinispan.commons.tx.XidImpl
 
equals(Object) - Method in class org.infinispan.commons.util.AbstractMap.SimpleEntry
 
equals(Object) - Method in class org.infinispan.commons.util.ForwardingList
 
equals(Object) - Method in class org.infinispan.commons.util.ImmutableListCopy
 
equals(Object) - Method in class org.infinispan.commons.util.KeyValueWithPrevious
 
equals(Object) - Method in class org.infinispan.commons.util.RangeSet
Deprecated.
 
equals(Object) - Method in class org.infinispan.commons.util.SegmentAwareKey
 
equals(Object) - Method in class org.infinispan.commons.util.SimpleImmutableEntry
 
equals(Object) - Method in class org.infinispan.commons.util.SmallIntSet
Deprecated.
 
equals(Object) - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.Configuration
 
equals(Object) - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfiguration
Deprecated.
 
equals(Object) - Method in class org.infinispan.configuration.cache.InvocationBatchingConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.MemoryStorageConfiguration
Deprecated.
 
equals(Object) - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.cache.SecurityConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.global.AllowListConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
equals(Object) - Method in class org.infinispan.configuration.global.GlobalJmxConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.global.GlobalMetricsConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.global.GlobalSecurityConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.global.SerializationConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.global.ShutdownConfiguration
 
equals(Object) - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
 
equals(Object) - Method in class org.infinispan.configuration.global.SiteConfiguration
Deprecated.
 
equals(Object) - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
Deprecated.
 
equals(Object) - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
 
equals(Object) - Method in class org.infinispan.configuration.global.WhiteListConfiguration
Deprecated.
 
equals(Object) - Method in class org.infinispan.configuration.parsing.ParserRegistry.QName
 
equals(Object) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
equals(Object) - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
equals(Object) - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
equals(Object) - Method in class org.infinispan.container.entries.MortalCacheValue
 
equals(Object) - Method in class org.infinispan.container.entries.TransientCacheValue
 
equals(Object) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
equals(Object) - Method in class org.infinispan.container.versioning.irac.IracEntryVersion
 
equals(Object) - Method in class org.infinispan.container.versioning.irac.IracEntryVersion.MapEntry
 
equals(Object) - Method in class org.infinispan.container.versioning.irac.IracTombstoneInfo
 
equals(Object) - Method in class org.infinispan.container.versioning.irac.TopologyIracVersion
 
equals(Object) - Method in class org.infinispan.container.versioning.NumericVersion
 
equals(Object) - Method in class org.infinispan.container.versioning.SimpleClusteredVersion
 
equals(Object) - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
equals(Object) - Method in class org.infinispan.counter.api.CounterConfiguration
 
equals(Object) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
 
equals(Object) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
 
equals(Object) - Method in class org.infinispan.distribution.ch.impl.HashFunctionPartitioner
 
equals(Object) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
equals(Object) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory
 
equals(Object) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
 
equals(Object) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory
 
equals(Object) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory
 
equals(Object) - Method in class org.infinispan.encoding.DataConversion
 
equals(Object) - Method in class org.infinispan.extendedstats.topK.StreamSummaryContainer
 
equals(Object) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
 
equals(Object) - Method in class org.infinispan.functional.MetaParam.MetaBoolean
 
equals(Object) - Method in class org.infinispan.functional.MetaParam.MetaEntryVersion
 
equals(Object) - Method in class org.infinispan.functional.MetaParam.MetaLong
 
equals(Object) - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
 
equals(Object) - Method in class org.infinispan.globalstate.ScopedState
 
equals(Object) - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
Deprecated.
 
equals(Object) - Method in class org.infinispan.io.GridFile
Deprecated.
 
equals(Object) - Method in class org.infinispan.io.ImmutableMarshalledValueByteStream
Deprecated.
 
equals(Object) - Method in class org.infinispan.jmx.ResourceDMBean
 
equals(Object) - Method in class org.infinispan.metadata.EmbeddedMetadata.EmbeddedExpirableMetadata
 
equals(Object) - Method in class org.infinispan.metadata.EmbeddedMetadata.EmbeddedLifespanExpirableMetadata
 
equals(Object) - Method in class org.infinispan.metadata.EmbeddedMetadata.EmbeddedMaxIdleExpirableMetadata
 
equals(Object) - Method in class org.infinispan.metadata.EmbeddedMetadata
 
equals(Object) - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
Deprecated.
 
equals(Object) - Method in class org.infinispan.metadata.impl.IracMetadata
 
equals(Object) - Method in class org.infinispan.metadata.impl.PrivateMetadata
 
equals(Object) - Method in class org.infinispan.metrics.config.MicrometerMeterRegisterConfigurationBuilder
 
equals(Object) - Method in class org.infinispan.metrics.config.MicrometerMeterRegistryConfiguration
 
equals(Object) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
equals(Object) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
equals(Object) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
equals(Object) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfiguration
 
equals(Object) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractUnmanagedConnectionFactoryConfiguration
 
equals(Object) - Method in class org.infinispan.persistence.jdbc.common.configuration.ManagedConnectionFactoryConfiguration
 
equals(Object) - Method in class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfiguration
 
equals(Object) - Method in class org.infinispan.persistence.jdbc.configuration.DataColumnConfiguration
 
equals(Object) - Method in class org.infinispan.persistence.jdbc.configuration.IdColumnConfiguration
 
equals(Object) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfiguration
 
equals(Object) - Method in class org.infinispan.persistence.jdbc.configuration.SegmentColumnConfiguration
 
equals(Object) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
equals(Object) - Method in class org.infinispan.persistence.jdbc.configuration.TimestampColumnConfiguration
 
equals(Object) - Method in class org.infinispan.persistence.modifications.ModificationsList
 
equals(Object) - Method in class org.infinispan.persistence.modifications.Remove
 
equals(Object) - Method in class org.infinispan.persistence.modifications.Store
 
equals(Object) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
 
equals(Object) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
 
equals(Object) - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfiguration
 
equals(Object) - Method in class org.infinispan.persistence.remote.configuration.MechanismConfiguration
 
equals(Object) - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfiguration
 
equals(Object) - Method in class org.infinispan.persistence.remote.configuration.SecurityConfiguration
 
equals(Object) - Method in class org.infinispan.persistence.remote.configuration.TrustStoreConfiguration
 
equals(Object) - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBExpirationConfiguration
 
equals(Object) - Method in class org.infinispan.persistence.sifs.configuration.DataConfiguration
 
equals(Object) - Method in class org.infinispan.persistence.sifs.configuration.IndexConfiguration
 
equals(Object) - Method in class org.infinispan.persistence.sifs.EntryInfo
 
equals(Object) - Method in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.Parameter
 
equals(Object) - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfiguration
 
equals(Object) - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfiguration
 
equals(Object) - Method in class org.infinispan.query.impl.EntityLoader
 
equals(Object) - Method in class org.infinispan.remoting.LocalInvocation
 
equals(Object) - Method in class org.infinispan.remoting.responses.SuccessfulResponse
 
equals(Object) - Method in class org.infinispan.remoting.responses.UnsuccessfulResponse
 
equals(Object) - Method in class org.infinispan.remoting.rpc.RpcOptions
 
equals(Object) - Method in class org.infinispan.remoting.transport.AggregateBackupResponse
 
equals(Object) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
equals(Object) - Method in class org.infinispan.remoting.transport.SiteAddress
 
equals(Object) - Method in class org.infinispan.search.mapper.common.impl.EntityReferenceImpl
 
equals(Object) - Method in class org.infinispan.security.audit.LoggingAuditLogger
 
equals(Object) - Method in class org.infinispan.security.audit.NullAuditLogger
 
equals(Object) - Method in class org.infinispan.security.CachePermission
 
equals(Object) - Method in class org.infinispan.security.impl.CacheRoleImpl
 
equals(Object) - Method in class org.infinispan.security.impl.CacheSubjectPair
 
equals(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
equals(Object) - Method in class org.infinispan.security.mappers.CommonNameRoleMapper
 
equals(Object) - Method in class org.infinispan.security.mappers.IdentityRoleMapper
 
equals(Object) - Method in class org.infinispan.server.core.security.InetAddressPrincipal
 
equals(Object) - Method in class org.infinispan.server.core.security.simple.SimpleUserPrincipal
 
equals(Object) - Method in class org.infinispan.server.hotrod.MultiHomedServerAddress
 
equals(Object) - Method in class org.infinispan.server.hotrod.SingleHomedServerAddress
 
equals(Object) - Method in class org.infinispan.server.hotrod.tx.table.CacheXid
 
equals(Object) - Method in class org.infinispan.server.hotrod.tx.table.ClientAddress
 
equals(Object) - Method in class org.infinispan.server.hotrod.tx.table.TxState
 
equals(Object) - Method in class org.infinispan.topology.CacheJoinInfo
 
equals(Object) - Method in class org.infinispan.topology.CacheTopology
 
equals(Object) - Method in class org.infinispan.topology.PersistentUUID
 
equals(Object) - Method in class org.infinispan.transaction.impl.LocalTransaction
 
equals(Object) - Method in class org.infinispan.transaction.impl.RemoteTransaction
 
equals(Object) - Method in class org.infinispan.transaction.synchronization.SynchronizationAdapter
 
equals(Object) - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
equals(Object) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfo
 
equals(Object) - Method in class org.infinispan.transaction.xa.recovery.RecoveryInfoKey
 
equals(Object) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
equals(Object) - Method in class org.infinispan.util.ByteString
 
equals(Object) - Method in class org.infinispan.util.KeyValuePair
 
equals(Object) - Method in class org.infinispan.xsite.events.XSiteEvent
 
equals(Object) - Method in class org.infinispan.xsite.irac.IracManagerKeyInfoImpl
 
equals(Object) - Method in class org.infinispan.xsite.spi.SiteEntry
 
equals(Object) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferCollector
 
equals(SimpleUserPrincipal) - Method in class org.infinispan.server.core.security.simple.SimpleUserPrincipal
 
equalsKey(long, WrappedBytes) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
Returns whether the given key as bytes is the same key as the key stored in the entry for the given address.
equalsKey(long, WrappedBytes, int) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
Returns whether the given key as bytes is the same key as the key stored in the entry for the given address.
equalsKey(long, WrappedBytes, int) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
 
equalsWrappedBytes(WrappedBytes) - Method in class org.infinispan.commons.marshall.WrappedByteArray
 
equalsWrappedBytes(WrappedBytes) - Method in interface org.infinispan.commons.marshall.WrappedBytes
 
EQUIVALENCE - Static variable in interface org.infinispan.commons.marshall.Ids
 
ERROR - Enum constant in enum org.infinispan.security.AuditResponse
 
ERROR - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
ERROR - Enum constant in enum org.infinispan.server.hotrod.tx.table.Status
 
ERROR - Static variable in interface org.infinispan.query.remote.json.JSONConstants
 
ERROR - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
 
errorClosingIteration(String) - Method in interface org.infinispan.client.hotrod.logging.Log
 
errorCreatingBackup(Throwable) - Method in interface org.infinispan.server.core.logging.Log
 
errorCreatingPropagationContext(Throwable) - Method in interface org.infinispan.client.hotrod.logging.Log
 
errorCreatingTable(String, SQLException) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
 
errorDeserializing(String) - Method in interface org.infinispan.server.core.logging.Log
 
errorDetectingCrashedMember(Throwable) - Method in interface org.infinispan.server.hotrod.logging.Log
 
errorExecutingMassIndexer(Throwable) - Method in interface org.infinispan.rest.logging.Log
 
errorFromServer(String) - Method in interface org.infinispan.client.hotrod.logging.Log
 
errorFromUnknownOperation(Channel, Throwable, SocketAddress) - Method in interface org.infinispan.client.hotrod.logging.Log
 
errorInIndexUpdater(Throwable) - Method in interface org.infinispan.persistence.sifs.Log
 
errorMarshallingObject(Throwable, Object) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
 
errorPersistingCountersConfiguration(Throwable) - Method in interface org.infinispan.counter.logging.Log
 
errorProcessingIndexingOperation(Throwable) - Method in interface org.infinispan.search.mapper.log.impl.Log
 
errorReadingCountersConfiguration(Throwable) - Method in interface org.infinispan.counter.logging.Log
 
errorResponse(HotRodHeader, HotRodServer, Channel, String, OperationStatus) - Method in class org.infinispan.server.hotrod.Encoder4x
 
errorResponse(HotRodHeader, HotRodServer, Channel, String, OperationStatus) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
 
errorRestoringBackup(Path, Throwable) - Method in interface org.infinispan.server.core.logging.Log
 
errorRetrievingNext(String) - Method in interface org.infinispan.client.hotrod.logging.Log
 
errorRetrievingTypeModel(Class<?>, Exception) - Method in interface org.infinispan.search.mapper.log.impl.Log
 
ERRORS_KEY_SUFFIX - Static variable in interface org.infinispan.query.remote.client.ProtobufMetadataManagerConstants
All error status keys end with this suffix.
errorSerializingResponse(Object) - Method in interface org.infinispan.server.hotrod.logging.Log
 
errorStatus(Throwable) - Method in class org.infinispan.server.hotrod.Encoder4x
 
errorStatus(Throwable) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
 
errorWhileResponding(Throwable) - Method in interface org.infinispan.rest.logging.Log
 
escape(CharSequence, Appendable) - Static method in class org.infinispan.commons.dataconversion.internal.Json
 
escape(String) - Static method in class org.infinispan.commons.dataconversion.internal.Json.help
Perform JSON escaping so that ", invalid input: '<', >, etc.
estimateSize() - Method in class org.infinispan.client.hotrod.transaction.manager.RemoteXid
 
estimateSize() - Method in class org.infinispan.commons.util.FilterSpliterator
 
estimateSize() - Method in class org.infinispan.commons.util.FlattenSpliterator
 
estimateSize() - Method in class org.infinispan.commons.util.SpliteratorMapper
 
estimateSizeOverhead(long) - Static method in class org.infinispan.container.offheap.UnpooledOffHeapMemoryAllocator
Tries to estimate overhead of the allocation by first adding 8 to account for underlying allocator housekeeping and then rounds up to nearest power of 16 to account for 16 byte alignment.
eTag(String) - Method in interface org.infinispan.rest.framework.impl.RestResponseBuilder
 
eTag(String) - Method in class org.infinispan.rest.framework.impl.SimpleRestResponse.Builder
 
eTag(String) - Method in class org.infinispan.rest.NettyRestResponse.Builder
 
ETAG_HEADER - Enum constant in enum org.infinispan.rest.ResponseHeader
 
eval(K, Consumer<EntryView.WriteEntryView<K, V>>) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Evaluate a write-only Consumer operation with a EntryView.WriteEntryView of the value associated with the key, and return a CompletableFuture which will be completed with the object returned by the operation.
eval(K, Consumer<EntryView.WriteEntryView<K, V>>) - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
eval(K, Function<EntryView.ReadEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadOnlyMap
Evaluate a read-only function on the value associated with the key and return a CompletableFuture with the return type of the function.
eval(K, Function<EntryView.ReadEntryView<K, V>, R>) - Method in class org.infinispan.functional.impl.ReadOnlyMapImpl
 
eval(K, Function<EntryView.ReadWriteEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
Evaluate a read-write function on the value and metadata associated with the key and return a CompletableFuture with the return type of the function.
eval(K, Function<EntryView.ReadWriteEntryView<K, V>, R>) - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
 
eval(K, SerializableConsumer<EntryView.WriteEntryView<K, V>>) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Same as FunctionalMap.WriteOnlyMap.eval(Object, Consumer) except that the function must also implement Serializable
eval(K, SerializableFunction<EntryView.ReadEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadOnlyMap
Same as FunctionalMap.ReadOnlyMap.eval(Object, Function) except that the function must also implement Serializable
eval(K, SerializableFunction<EntryView.ReadWriteEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
Same as FunctionalMap.ReadWriteMap.eval(Object, Function) except that the function must also implement Serializable
eval(K, T, BiConsumer<T, EntryView.WriteEntryView<K, V>>) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Evaluate a write-only BiConsumer operation, with an argument passed in and a EntryView.WriteEntryView of the value associated with the key, and return a CompletableFuture which will be completed when the operation completes.
eval(K, T, BiConsumer<T, EntryView.WriteEntryView<K, V>>) - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
eval(K, T, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
Evaluate a read-write function, with an argument passed in and a EntryView.WriteEntryView of the value associated with the key, and return a CompletableFuture which will be completed with the returned value by the function.
eval(K, T, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>) - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
 
eval(K, T, SerializableBiConsumer<T, EntryView.WriteEntryView<K, V>>) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Same as FunctionalMap.WriteOnlyMap.eval(Object, Object, BiConsumer) except that the function must also implement Serializable
eval(K, T, SerializableBiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
Same as FunctionalMap.ReadWriteMap.eval(Object, Object, BiFunction) except that the function must also implement Serializable
evalAll(Consumer<EntryView.WriteEntryView<K, V>>) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Evaluate a write-only Consumer operation with the EntryView.WriteEntryView of the value associated with the key, for all existing keys in functional map, and returns a CompletableFuture that will be completed when the write-only operation has been executed against all the entries.
evalAll(Consumer<EntryView.WriteEntryView<K, V>>) - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
evalAll(Function<EntryView.ReadWriteEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
Evaluate a read-write Function operation with the EntryView.ReadWriteEntryView of the value associated with the key, for all existing keys, and returns a Traversable to navigate each of the Function invocation returns.
evalAll(Function<EntryView.ReadWriteEntryView<K, V>, R>) - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
 
evalAll(SerializableConsumer<EntryView.WriteEntryView<K, V>>) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Same as FunctionalMap.WriteOnlyMap.evalAll(Consumer) except that the function must also implement Serializable
evalAll(SerializableFunction<EntryView.ReadWriteEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
Same as FunctionalMap.ReadWriteMap.evalAll(Function) except that the function must also implement Serializable
evalMany(Map<? extends K, ? extends T>, BiConsumer<T, EntryView.WriteEntryView<K, V>>) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Evaluate a write-only BiConsumer operation, with an argument passed in and a EntryView.WriteEntryView of the value associated with the key, for each of the keys in the set passed in, and returns a CompletableFuture that will be completed when the write-only operation has been executed against all the entries.
evalMany(Map<? extends K, ? extends T>, BiConsumer<T, EntryView.WriteEntryView<K, V>>) - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
evalMany(Map<? extends K, ? extends T>, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
Evaluate a read-write BiFunction, with an argument passed in and a EntryView.ReadWriteEntryView of the value associated with the key, for each of the keys in the set passed in, and returns an Traversable to navigate each of the BiFunction invocation returns.
evalMany(Map<? extends K, ? extends T>, BiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>) - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
 
evalMany(Map<? extends K, ? extends T>, SerializableBiConsumer<T, EntryView.WriteEntryView<K, V>>) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Same as FunctionalMap.WriteOnlyMap.evalMany(Map, BiConsumer) except that the function must also implement Serializable
evalMany(Map<? extends K, ? extends T>, SerializableBiFunction<T, EntryView.ReadWriteEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
Same as FunctionalMap.ReadWriteMap.evalMany(Map, BiFunction) except that the function must also implement Serializable
evalMany(Set<? extends K>, Consumer<EntryView.WriteEntryView<K, V>>) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Evaluate a write-only Consumer operation with the EntryView.WriteEntryView of the value associated with the key, for each of the keys in the set passed in, and returns a CompletableFuture that will be completed when the write-only operation has been executed against all the entries.
evalMany(Set<? extends K>, Consumer<EntryView.WriteEntryView<K, V>>) - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
evalMany(Set<? extends K>, Function<EntryView.ReadEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadOnlyMap
Evaluate a read-only function on a key and potential value associated in the functional map, for each of the keys in the set passed in, and returns an Traversable to work on each computed function's result.
evalMany(Set<? extends K>, Function<EntryView.ReadEntryView<K, V>, R>) - Method in class org.infinispan.functional.impl.ReadOnlyMapImpl
 
evalMany(Set<? extends K>, Function<EntryView.ReadWriteEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
Evaluate a read-write Function operation with the EntryView.ReadWriteEntryView of the value associated with the key, for each of the keys in the set passed in, and returns a Traversable to navigate each of the Function invocation returns.
evalMany(Set<? extends K>, Function<EntryView.ReadWriteEntryView<K, V>, R>) - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
 
evalMany(Set<? extends K>, SerializableConsumer<EntryView.WriteEntryView<K, V>>) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
Same as FunctionalMap.WriteOnlyMap.evalMany(Set, Consumer) except that the function must also implement Serializable
evalMany(Set<? extends K>, SerializableFunction<EntryView.ReadEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadOnlyMap
Same as FunctionalMap.ReadOnlyMap.evalMany(Set, Function) except that the function must also implement Serializable
evalMany(Set<? extends K>, SerializableFunction<EntryView.ReadWriteEntryView<K, V>, R>) - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
Same as FunctionalMap.ReadWriteMap.evalMany(Set, Function) except that the function must also implement Serializable
evaluateResponse(byte[]) - Method in class org.infinispan.server.core.security.SubjectSaslServer
 
Event<K,V> - Interface in org.infinispan.notifications.cachelistener.event
An interface that defines common characteristics of events
Event - Interface in org.infinispan.notifications.cachemanagerlistener.event
Common characteristics of events that occur on a cache manager
EVENT - Static variable in class org.infinispan.server.core.transport.AccessControlFilter
 
EVENT_LOG_CATEGORY - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
EVENT_LOG_LEVEL - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
EVENT_LOGGER_LOWER_BOUND - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
EVENT_STREAM - Enum constant in enum org.infinispan.rest.ResponseWriter
 
Event.Type - Enum in org.infinispan.notifications.cachelistener.event
 
Event.Type - Enum in org.infinispan.notifications.cachemanagerlistener.event
 
EventDispatcher<T> - Class in org.infinispan.client.hotrod.event.impl
 
EventImpl<K,V> - Class in org.infinispan.notifications.cachelistener.event.impl
Basic implementation of an event that covers all event types.
EventImpl - Class in org.infinispan.notifications.cachemanagerlistener.event.impl
Implementation of cache manager events
EventImpl() - Constructor for class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
EventImpl() - Constructor for class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
EventImpl(String, EmbeddedCacheManager, Event.Type, List<Address>, List<Address>, Address, int) - Constructor for class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
EventLoggerViewListener - Class in org.infinispan.topology
 
EventLoggerViewListener(EventLogManager) - Constructor for class org.infinispan.topology.EventLoggerViewListener
 
EventLoggerViewListener(EventLogManager, Consumer<ViewChangedEvent>) - Constructor for class org.infinispan.topology.EventLoggerViewListener
 
eventSource - Variable in class org.infinispan.spring.common.session.AbstractApplicationPublisherBridge
 
eventStream - Variable in class org.infinispan.rest.resources.CacheResourceV2.BaseCacheListener
 
EventStream - Class in org.infinispan.rest
 
EventStream(Consumer<EventStream>, Runnable) - Constructor for class org.infinispan.rest.EventStream
 
eventType - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
EventType - Class in org.infinispan.notifications.cachelistener.filter
Enum that provides information to allow for an event to know which type and if this event was generated due to a retry usually caused by a topology change while replicating.
EventType(boolean, boolean, Event.Type) - Constructor for class org.infinispan.notifications.cachelistener.filter.EventType
 
EventWrapper<K,V,E> - Class in org.infinispan.notifications.cachelistener
Simple wrapper that keeps the original key along with the converted event and command.
EventWrapper(K, E, FlagAffectedCommand) - Constructor for class org.infinispan.notifications.cachelistener.EventWrapper
 
evict(int, K) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
evict(int, K) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
evict(int, K) - Method in interface org.infinispan.container.impl.InternalDataContainer
Same as DataContainer.evict(Object) except that the segment of the key can provided to remove the entry without calculating the segment for the given key.
evict(int, WrappedBytes) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
evict(Object) - Method in class org.infinispan.spring.common.provider.SpringCache
 
evict(K) - Method in interface org.infinispan.Cache
Evicts an entry from the memory of the cache.
evict(K) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
evict(K) - Method in class org.infinispan.cache.impl.CacheImpl
 
evict(K) - Method in class org.infinispan.cache.impl.DecoratedCache
 
evict(K) - Method in class org.infinispan.cache.impl.EncoderCache
 
evict(K) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
evict(K) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
evict(K) - Method in interface org.infinispan.container.DataContainer
Atomically, it removes the key from DataContainer and passivates it to persistence.
evict(K) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
evict(K) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
evict(K) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
evict(WrappedBytes) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
EVICTED - Enum constant in enum org.infinispan.container.entries.ReadCommittedEntry.Flags
 
Eviction - Search tag in interface org.infinispan.multimap.api.BasicMultimapCache
Section
EVICTION - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
EVICTION - Enum constant in enum org.infinispan.configuration.parsing.Element
 
EVICTION_EXECUTOR - Enum constant in enum org.infinispan.configuration.parsing.Attribute
Deprecated, for removal: This API element is subject to removal in a future version.
EVICTION_STRATEGY - Enum constant in enum org.infinispan.configuration.parsing.Attribute
Deprecated, for removal: This API element is subject to removal in a future version.
EVICTION_STRATEGY - Static variable in class org.infinispan.configuration.cache.MemoryStorageConfiguration
Deprecated.
 
EVICTION_TYPE - Static variable in class org.infinispan.configuration.cache.MemoryStorageConfiguration
Deprecated.
 
evictionCache - Variable in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
EvictionListener<K,V> - Interface in org.infinispan.commons.util
Deprecated, for removal: This API element is subject to removal in a future version.
since 10.0 - This class is not used internally anymore
evictionManager - Variable in class org.infinispan.container.impl.AbstractInternalDataContainer
 
evictionManager - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
EvictionManager<K,V> - Interface in org.infinispan.eviction
Central component that deals with eviction of cache entries.
EvictionManagerImpl<K,V> - Class in org.infinispan.eviction.impl
 
EvictionManagerImpl() - Constructor for class org.infinispan.eviction.impl.EvictionManagerImpl
 
evictionSize() - Method in interface org.infinispan.container.DataContainer
Returns how large the eviction size is currently.
evictionSize() - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
evictionSize() - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
evictionSize() - Method in class org.infinispan.container.impl.DefaultDataContainer
 
evictionSize() - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
evictionStrategy() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
evictionStrategy() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 11.0, use MemoryConfigurationBuilder.whenFull() instead.
evictionStrategy() - Method in class org.infinispan.configuration.cache.MemoryStorageConfiguration
Deprecated.
 
evictionStrategy(EvictionStrategy) - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
EvictionStrategy - Enum in org.infinispan.eviction
Supported eviction strategies
evictionType() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
Since 11.0, use MemoryConfiguration.maxCount() or MemoryConfiguration.maxSize() to obtain either the maximum number of entries or the maximum size of the data container.
evictionType() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
evictionType() - Method in class org.infinispan.configuration.cache.MemoryStorageConfiguration
Deprecated.
 
evictionType(EvictionType) - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
since 11.0, use MemoryConfigurationBuilder.maxCount(long) or MemoryConfigurationBuilder.maxSize(String) to define data container bounds by size or by count.
EvictionType - Enum in org.infinispan.eviction
Deprecated, for removal: This API element is subject to removal in a future version.
Since 11.0, MemoryConfiguration.maxCount() and MemoryConfiguration.maxSize() should be used to differentiate between the eviction thresholds.
EXACTLY_ONCE - Enum constant in enum org.infinispan.reactive.publisher.impl.DeliveryGuarantee
The most strict guarantee that guarantees that an entry is seen exactly one time in results.
exactlyOnceHandleLostSegments(CompletionStage<R>, LocalPublisherManagerImpl.SegmentListener) - Method in class org.infinispan.reactive.publisher.impl.LocalPublisherManagerImpl
 
exactlyOnceParallel(CacheSet<I>, Set<K>, Function<I, K>, IntSet, Function<? super Publisher<I>, ? extends CompletionStage<R>>, LocalPublisherManagerImpl.SegmentListener, IntSet) - Method in class org.infinispan.reactive.publisher.impl.LocalPublisherManagerImpl
This method iteratively submits a task to operate on the cpu bound thread pool up to the number of cores - 1.
exactlyOnceSequential(CacheSet<I>, Set<K>, Function<I, K>, IntSet, Function<? super Publisher<I>, ? extends CompletionStage<R>>, LocalPublisherManagerImpl.SegmentListener, IntSet) - Method in class org.infinispan.reactive.publisher.impl.LocalPublisherManagerImpl
 
Example - Search tag in interface org.infinispan.multimap.api.BasicMultimapCache
Section
Example 1 - Method receiving a single event, sync - Search tag in annotation type org.infinispan.notifications.Listener
Section
Example 2 - Method receiving multiple events - sync - Search tag in annotation type org.infinispan.notifications.Listener
Section
Example 3 - Multiple methods receiving the same event - async - Search tag in annotation type org.infinispan.notifications.Listener
Section
Example 4 - Processing only events with a committed transaction - sync/non-blocking - Search tag in annotation type org.infinispan.notifications.Listener
Section
EXCEPTION - Enum constant in enum org.infinispan.client.hotrod.configuration.ExhaustedAction
 
EXCEPTION - Enum constant in enum org.infinispan.eviction.EvictionStrategy
Strategy where the cache will block new entries from being written if they would exceed the configured size
EXCEPTION - Enum constant in enum org.infinispan.persistence.remote.configuration.ExhaustedAction
 
EXCEPTION_RESPONSE - Static variable in interface org.infinispan.commons.marshall.Ids
 
exceptionAndNoRetriesLeft(int, int, Throwable) - Method in interface org.infinispan.client.hotrod.logging.Log
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.infinispan.rest.RestRequestHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.infinispan.server.hotrod.HotRodDecoder
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.infinispan.server.memcached.MemcachedDecoder
 
exceptionDuringPrepare(Xid, Exception) - Method in interface org.infinispan.client.hotrod.logging.Log
 
exceptionInvokingListener(String, Method, Object, Throwable) - Method in interface org.infinispan.client.hotrod.logging.Log
 
exceptionReported(Throwable) - Method in interface org.infinispan.server.hotrod.logging.Log
 
exceptionReported(Throwable) - Method in interface org.infinispan.server.memcached.logging.Log
 
ExceptionResponse - Class in org.infinispan.remoting.responses
A response that encapsulates an exception
ExceptionResponse() - Constructor for class org.infinispan.remoting.responses.ExceptionResponse
 
ExceptionResponse(Exception) - Constructor for class org.infinispan.remoting.responses.ExceptionResponse
 
ExceptionResponse.Externalizer - Class in org.infinispan.remoting.responses
 
EXCEPTIONS - Static variable in interface org.infinispan.commons.marshall.Ids
 
ExceptionSyncInvocationStage - Class in org.infinispan.interceptors
ExceptionSyncInvocationStage(Throwable) - Constructor for class org.infinispan.interceptors.ExceptionSyncInvocationStage
 
exec(HotRodHeader, Subject, String, Map<String, byte[]>) - Method in class org.infinispan.server.hotrod.TaskRequestProcessor
 
EXEC - Enum constant in enum org.infinispan.security.AuthorizationPermission
Allows performing task execution (e.g.
EXEC - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
EXEC_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
execute() - Method in interface org.infinispan.query.dsl.Query
Executes the query (a SELECT statement).
execute() - Method in interface org.infinispan.query.impl.IndexedQuery
Executes an Ickle statement returning results (query aka.
execute() - Method in class org.infinispan.query.impl.IndexedQueryImpl
 
execute(Flowable<XSiteState>, CompletionStage<Void>) - Method in interface org.infinispan.xsite.statetransfer.XSiteStatePushTask
Perform the state transfer with the state from Flowable.
execute(Runnable) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
execute(Runnable) - Method in class org.infinispan.executors.LazyInitializingExecutorService
 
execute(Runnable) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
 
execute(Runnable) - Method in class org.infinispan.executors.LimitedExecutor
 
execute(Runnable) - Method in interface org.infinispan.manager.ClusterExecutor
execute(Runnable) - Method in class org.infinispan.server.core.transport.NonRecursiveEventLoopGroup
 
execute(Runnable) - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
 
execute(Runnable) - Method in class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
 
execute(Runnable) - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
 
execute(Runnable, Object) - Method in interface org.infinispan.util.concurrent.BlockingManager.BlockingExecutor
Executes the given runnable on the blocking executor.
execute(String) - Method in interface org.infinispan.client.hotrod.RemoteCache
Executes a remote task without passing any parameters
execute(String, Map<String, ?>) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
execute(String, Map<String, ?>) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
execute(String, Map<String, ?>) - Method in interface org.infinispan.client.hotrod.RemoteCache
Executes a remote task passing a set of named parameters
execute(String, Map<String, ?>, Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
execute(String, Map<String, ?>, Object) - Method in interface org.infinispan.client.hotrod.RemoteCache
Executes a remote task passing a set of named parameters, hinting that the task should be executed on the server that is expected to store given key.
execute(EmbeddedCacheManager, Map<String, List<String>>, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.server.core.admin.AdminServerTask
 
execute(EmbeddedCacheManager, Map<String, List<String>>, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.server.core.admin.embeddedserver.CacheCreateTask
 
execute(EmbeddedCacheManager, Map<String, List<String>>, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.server.core.admin.embeddedserver.CacheGetOrCreateTask
 
execute(EmbeddedCacheManager, Map<String, List<String>>, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.server.core.admin.embeddedserver.CacheNamesTask
 
execute(EmbeddedCacheManager, Map<String, List<String>>, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.server.core.admin.embeddedserver.CacheReindexTask
 
execute(EmbeddedCacheManager, Map<String, List<String>>, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.server.core.admin.embeddedserver.CacheRemoveTask
 
execute(EmbeddedCacheManager, Map<String, List<String>>, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.server.core.admin.embeddedserver.CacheUpdateConfigurationAttributeTask
 
execute(EmbeddedCacheManager, Map<String, List<String>>, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.server.core.admin.embeddedserver.CacheUpdateIndexSchemaTask
 
execute(EmbeddedCacheManager, Map<String, List<String>>, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.server.core.admin.embeddedserver.TemplateCreateTask
 
execute(EmbeddedCacheManager, Map<String, List<String>>, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.server.core.admin.embeddedserver.TemplateNamesTask
 
execute(EmbeddedCacheManager, Map<String, List<String>>, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.server.core.admin.embeddedserver.TemplateRemoveTask
 
execute(TaskContext) - Method in class org.infinispan.server.core.admin.AdminServerTask
 
execute(BlockingRunnable) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
execute(BlockingRunnable) - Method in interface org.infinispan.util.concurrent.BlockingTaskAwareExecutorService
Executes the given command at some time in the future when the command is less probably to block a thread.
execute(BlockingRunnable) - Method in class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
 
execute(SerializableRunnable) - Method in interface org.infinispan.manager.ClusterExecutor
The same as Executor.execute(Runnable), except the Runnable must also implement Serializable.
executeAsync(Supplier<CompletionStage<Void>>) - Method in class org.infinispan.executors.LimitedExecutor
Similar to LimitedExecutor.execute(Runnable), but the task can continue executing asynchronously, without blocking the OS thread, while still counting against this executor's limit.
executedScript(String, String) - Method in class org.infinispan.scripting.logging.Messages_$bundle
 
executedScript(String, String) - Method in interface org.infinispan.scripting.logging.Messages
 
executedScript$str() - Method in class org.infinispan.scripting.logging.Messages_$bundle
 
executeFailover() - Method in class org.infinispan.client.hotrod.event.impl.ClientEventDispatcher
 
executeFailover() - Method in class org.infinispan.client.hotrod.event.impl.CounterEventDispatcher
 
executeFailover() - Method in class org.infinispan.client.hotrod.event.impl.EventDispatcher
 
executeOnClusterAsync(Transport, ReplicableCommand) - Method in class org.infinispan.topology.TopologyManagementHelper
 
executeOnClusterSync(Transport, ReplicableCommand, int, ResponseCollector<T>) - Method in class org.infinispan.topology.TopologyManagementHelper
 
executeOnCoordinator(Transport, ReplicableCommand, long) - Method in class org.infinispan.topology.TopologyManagementHelper
 
executeOnCoordinatorAsync(Transport, AbstractCacheControlCommand) - Method in class org.infinispan.topology.TopologyManagementHelper
 
executeOnCoordinatorRetry(ReplicableCommand, int, long) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
executeOperation(Channel) - Method in class org.infinispan.client.hotrod.counter.operation.AddListenerOperation
 
executeOperation(Channel) - Method in class org.infinispan.client.hotrod.counter.operation.AddOperation
 
executeOperation(Channel) - Method in class org.infinispan.client.hotrod.counter.operation.CompareAndSwapOperation
 
executeOperation(Channel) - Method in class org.infinispan.client.hotrod.counter.operation.DefineCounterOperation
 
executeOperation(Channel) - Method in class org.infinispan.client.hotrod.counter.operation.GetConfigurationOperation
 
executeOperation(Channel) - Method in class org.infinispan.client.hotrod.counter.operation.GetCounterNamesOperation
 
executeOperation(Channel) - Method in class org.infinispan.client.hotrod.counter.operation.GetValueOperation
 
executeOperation(Channel) - Method in class org.infinispan.client.hotrod.counter.operation.IsDefinedOperation
 
executeOperation(Channel) - Method in class org.infinispan.client.hotrod.counter.operation.RemoveListenerOperation
 
executeOperation(Channel) - Method in class org.infinispan.client.hotrod.counter.operation.RemoveOperation
 
executeOperation(Channel) - Method in class org.infinispan.client.hotrod.counter.operation.ResetOperation
 
executeOperation(BackupReceiver) - Method in class org.infinispan.xsite.commands.remote.IracClearKeysRequest
 
executeOperation(BackupReceiver) - Method in class org.infinispan.xsite.commands.remote.IracPutManyRequest
 
executeOperation(BackupReceiver) - Method in class org.infinispan.xsite.commands.remote.IracTouchKeyRequest
 
executeOperation(BackupReceiver) - Method in class org.infinispan.xsite.commands.remote.IracUpdateKeyRequest
 
executeStatement() - Method in interface org.infinispan.query.dsl.Query
Executes a data modifying statement (typically a DELETE) that does not return results; instead it returns an affected entries count.
executeStatement() - Method in interface org.infinispan.query.impl.IndexedQuery
Executes an Ickle statement not returning any results (ie.
executeStatement() - Method in class org.infinispan.query.impl.IndexedQueryImpl
 
EXECUTION_MODE - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
EXECUTION_MODE_ID - Static variable in class org.infinispan.functional.ParamIds
 
executor - Variable in class org.infinispan.executors.ManageableExecutorService
 
executor - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
executor - Variable in class org.infinispan.server.hotrod.HotRodDecoder
 
executor - Variable in class org.infinispan.server.hotrod.BaseRequestProcessor
 
executor - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
executor() - Method in class org.infinispan.manager.DefaultCacheManager
 
executor() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Providess the cache manager based executor.
executor() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
EXECUTOR - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
ExecutorAllCompletionService - Class in org.infinispan.executors
Exectues given tasks in provided executor.
ExecutorAllCompletionService(Executor) - Constructor for class org.infinispan.executors.ExecutorAllCompletionService
 
executorFactory(int, int, boolean) - Static method in class org.infinispan.factories.threads.CoreExecutorFactory
 
executorFactory(int, int, int, long, boolean) - Static method in class org.infinispan.factories.threads.CoreExecutorFactory
 
ExecutorFactory - Interface in org.infinispan.commons.executors
Used to configure and create executors
ExecutorFactoryConfiguration - Class in org.infinispan.client.hotrod.configuration
ExecutorFactoryConfiguration.
ExecutorFactoryConfiguration - Class in org.infinispan.configuration.global
 
ExecutorFactoryConfiguration - Class in org.infinispan.persistence.remote.configuration
 
ExecutorFactoryConfigurationBuilder - Class in org.infinispan.client.hotrod.configuration
Configures executor factory.
ExecutorFactoryConfigurationBuilder - Class in org.infinispan.configuration.global
Configures executor factory.
ExecutorFactoryConfigurationBuilder - Class in org.infinispan.persistence.remote.configuration
Configures executor factory.
EXHAUSTED_ACTION - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
 
exhaustedAction() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfiguration
 
exhaustedAction() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
Returns the configured action when the pool has become exhausted.
exhaustedAction() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
 
exhaustedAction(ExhaustedAction) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
Specifies what happens when asking for a connection from a server's pool, and that pool is exhausted.
exhaustedAction(ExhaustedAction) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
Specifies what happens when asking for a connection from a server's pool, and that pool is exhausted.
ExhaustedAction - Enum in org.infinispan.client.hotrod.configuration
Enumeration for whenExhaustedAction.
ExhaustedAction - Enum in org.infinispan.persistence.remote.configuration
 
existingStoreNoSegmentation() - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
 
existingStoreSegmentMismatch(int, int) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
 
exists() - Method in class org.infinispan.io.GridFile
Deprecated.
 
EXISTS - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
 
ExpandableMarshalledValueByteStream - Class in org.infinispan.io
Deprecated, for removal: This API element is subject to removal in a future version.
since 10.0
ExpandableMarshalledValueByteStream() - Constructor for class org.infinispan.io.ExpandableMarshalledValueByteStream
Deprecated.
 
ExpandableMarshalledValueByteStream(int) - Constructor for class org.infinispan.io.ExpandableMarshalledValueByteStream
Deprecated.
 
ExpandableMarshalledValueByteStream(int, int) - Constructor for class org.infinispan.io.ExpandableMarshalledValueByteStream
Deprecated.
Creates a new byte array output stream, with a buffer capacity of the specified size, in bytes.
expectedEndTime(long, TimeUnit) - Method in class org.infinispan.commons.time.DefaultTimeService
 
expectedEndTime(long, TimeUnit) - Method in interface org.infinispan.commons.time.TimeService
 
expectedSize(int) - Method in class org.infinispan.server.hotrod.tx.operation.CommitTransactionOperation
 
expectedSize(int) - Method in class org.infinispan.server.hotrod.tx.operation.RollbackTransactionOperation
 
expectedSize(int) - Method in interface org.infinispan.server.hotrod.tx.table.CacheNameCollector
Sets the expected number of caches involved in the transaction.
expectedTransactionalCache(String) - Method in interface org.infinispan.server.hotrod.logging.Log
 
Expected wrapping patterns - Search tag in interface org.infinispan.container.impl.EntryFactory
Section
Experimental - Annotation Type in org.infinispan.commons.util
An experimental user-facing API.
expiration - Variable in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.AbstractCustomInterceptorsConfigurationChildBuilder
 
expiration() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationChildBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.AbstractPersistenceConfigurationChildBuilder
 
expiration() - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
expiration() - Method in class org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.remote.configuration.AbstractSecurityConfigurationChildBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.AbstractTransportConfigurationChildBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
 
expiration() - Method in class org.infinispan.security.impl.CreatePermissionConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.CustomStoreConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.IndexReaderConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder.StringTableManipulationConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.jdbc.common.configuration.ManagedConnectionFactoryConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.remote.configuration.MechanismConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.MemoryStorageConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.QueryConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.SecurityConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.parsing.SFSToSIFSConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.StatisticsConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
 
expiration() - Method in class org.infinispan.persistence.remote.configuration.TrustStoreConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
 
expiration() - Method in class org.infinispan.configuration.cache.Configuration
 
expiration() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
 
expiration() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
 
expiration() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfiguration
 
EXPIRATION - Enum constant in enum org.infinispan.configuration.parsing.Element
 
EXPIRATION - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.Element
 
EXPIRATION - Enum constant in enum org.infinispan.persistence.spi.NonBlockingStore.Characteristic
If this store uses expiration metadata so that it never returns expired entries via any methods such as NonBlockingStore.load(int, Object), NonBlockingStore.publishKeys(IntSet, Predicate) or NonBlockingStore.publishEntries(IntSet, Predicate, boolean).
EXPIRATION_DEFAULT - Static variable in class org.infinispan.server.core.ServerConstants
 
EXPIRATION_EXECUTOR - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
EXPIRATION_NONE - Static variable in class org.infinispan.server.core.ServerConstants
 
EXPIRATION_SCHEDULED_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
 
expirationCheckDelay(CompletionStage<Void>, CompletableFuture<Void>) - Static method in interface org.infinispan.container.impl.EntryFactory
ExpirationConfiguration - Class in org.infinispan.configuration.cache
Controls the default expiration settings for entries in the cache.
ExpirationConfigurationBuilder - Class in org.infinispan.configuration.cache
Controls the default expiration settings for entries in the cache.
expirationManager - Variable in class org.infinispan.container.impl.AbstractInternalDataContainer
 
ExpirationManager<K,V> - Interface in org.infinispan.expiration
Central component that deals with expiration of cache entries.
ExpirationManagerFactory - Class in org.infinispan.factories
Constructs the expiration manager
ExpirationManagerFactory() - Constructor for class org.infinispan.factories.ExpirationManagerFactory
 
ExpirationManagerImpl<K,V> - Class in org.infinispan.expiration.impl
 
ExpirationManagerImpl() - Constructor for class org.infinispan.expiration.impl.ExpirationManagerImpl
 
expirationTask - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.CachedThreadPoolConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.GlobalJmxConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.GlobalMetricsConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.GlobalStatePathConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.GlobalStorageConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.JGroupsConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.PrincipalRoleMapperConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.RolePermissionMapperConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.ScheduledThreadPoolConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.StackConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.StackFileConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.TemporaryGlobalStatePathConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.ThreadFactoryConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
expirationThreadPool() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
Configuration for the expiration thread pool
expirationThreadPool() - Method in class org.infinispan.configuration.global.ThreadsConfiguration
 
expirationThreadPool() - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
 
expirationThreadPoolName() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
expirationThreadPoolName(String) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
expired(T, U, Metadata, PrivateMetadata) - Method in interface org.infinispan.expiration.impl.InternalExpirationManager.ExpirationConsumer
Invoked when an entry is expired.
EXPIRED - Enum constant in enum org.infinispan.container.entries.ReadCommittedEntry.Flags
 
EXPIRED - Enum constant in enum org.infinispan.transaction.impl.TransactionTable.CompletedTransactionStatus
 
EXPIRED_LOCATION - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.Attribute
 
expiredDbOptions() - Method in class org.infinispan.persistence.rocksdb.RocksDBStore
 
ExpiredEventImpl<K> - Class in org.infinispan.client.hotrod.event.impl
 
ExpiredEventImpl(byte[], K) - Constructor for class org.infinispan.client.hotrod.event.impl.ExpiredEventImpl
 
expiredIterationPredicate(long) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
Returns a predicate that will return false when an entry is expired.
expiredLocation() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBExpirationConfiguration
 
expiredLocation() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfiguration
 
expiredLocation(String) - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBExpirationConfigurationBuilder
 
expiredLocation(String) - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
 
expires(Date) - Method in interface org.infinispan.rest.framework.impl.RestResponseBuilder
 
expires(Date) - Method in class org.infinispan.rest.framework.impl.SimpleRestResponse.Builder
 
expires(Date) - Method in class org.infinispan.rest.NettyRestResponse.Builder
 
EXPIRES_HEADER - Enum constant in enum org.infinispan.rest.ResponseHeader
 
expiring - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
This map is used for performance reasons.
EXPIRY_QUEUE_SIZE - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.Attribute
 
ExpiryBucket$___Marshaller_c1bbd47a4aa119c6b21703d5030cb689b65205a24de2638d9c9f2ce1f3a222f6 - Class in org.infinispan.persistence.rocksdb
WARNING: Generated code! Do not edit!
ExpiryBucket$___Marshaller_c1bbd47a4aa119c6b21703d5030cb689b65205a24de2638d9c9f2ce1f3a222f6() - Constructor for class org.infinispan.persistence.rocksdb.ExpiryBucket$___Marshaller_c1bbd47a4aa119c6b21703d5030cb689b65205a24de2638d9c9f2ce1f3a222f6
 
ExpiryHelper - Class in org.infinispan.container.entries
Provide utility methods for dealing with expiration of cache entries.
ExpiryHelper() - Constructor for class org.infinispan.container.entries.ExpiryHelper
 
expiryQueueSize() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
There is no more queue in RocksDBStore
expiryQueueSize(int) - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.1, there is no more queue in RocksDBStore
expiryTime() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
 
expiryTime() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
Deprecated.
 
expiryTime() - Method in interface org.infinispan.metadata.InternalMetadata
Deprecated.
 
expiryTime() - Method in class org.infinispan.persistence.sifs.EntryHeader
 
expiryTime() - Method in interface org.infinispan.persistence.spi.MarshallableEntry
 
explicitFlags - Variable in class org.infinispan.cache.impl.AbstractCacheBackedSet
 
explicitFlags - Variable in class org.infinispan.stream.impl.AbstractCacheStream
 
ExponentialBackOff - Interface in org.infinispan.util
Interface to implement an exponential back-off algorithm that retries the request based on the result of the remote operation.
ExponentialBackOffImpl - Class in org.infinispan.util
The default ExponentialBackOff implementation for IRAC (asynchronous cross-site replication).
ExponentialBackOffImpl(ScheduledExecutorService) - Constructor for class org.infinispan.util.ExponentialBackOffImpl
 
EXPOSE_HEADERS - Static variable in class org.infinispan.rest.configuration.CorsRuleConfiguration
 
ExposedByteArrayOutputStream - Class in org.infinispan.commons.io
Deprecated, for removal: This API element is subject to removal in a future version.
Since 13.0, please use LazyByteArrayOutputStream instead.
ExposedByteArrayOutputStream() - Constructor for class org.infinispan.commons.io.ExposedByteArrayOutputStream
Deprecated.
 
ExposedByteArrayOutputStream(int) - Constructor for class org.infinispan.commons.io.ExposedByteArrayOutputStream
Deprecated.
 
ExposedByteArrayOutputStream(int, int) - Constructor for class org.infinispan.commons.io.ExposedByteArrayOutputStream
Deprecated.
Creates a new byte array output stream, with a buffer capacity of the specified size, in bytes.
exposeHeaders(String[]) - Method in class org.infinispan.rest.configuration.CorsRuleConfigurationBuilder
 
Expression - Interface in org.infinispan.query.dsl
Deprecated.
since 10.1. See deprecation note on QueryBuilder.
extend() - Method in class org.infinispan.configuration.global.StackConfiguration
 
extend(String) - Method in class org.infinispan.configuration.global.StackConfigurationBuilder
 
EXTENDED_HEADER - Enum constant in enum org.infinispan.rest.RequestHeader
 
EXTENDED_HEADERS - Static variable in class org.infinispan.rest.configuration.RestServerConfiguration
 
ExtendedByteBuf - Class in org.infinispan.server.core.transport
Static helper class that provides methods to be used with a ByteBuf that are useful for Infinispan.
ExtendedByteBuf - Class in org.infinispan.server.hotrod.transport
 
ExtendedByteBuf() - Constructor for class org.infinispan.server.hotrod.transport.ExtendedByteBuf
 
ExtendedByteBufJava - Class in org.infinispan.server.core.transport
Utilities to read from a ByteBuf
extendedHeaders() - Method in class org.infinispan.rest.configuration.RestServerConfiguration
 
extendedHeaders(ExtendedHeaders) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
 
ExtendedHeaders - Enum in org.infinispan.rest.configuration
 
ExtendedLockPromise - Interface in org.infinispan.util.concurrent.locks
An extended LockPromise interface that allows a better control over it.
ExtendedRiverMarshaller - Class in org.infinispan.jboss.marshalling.commons
RiverMarshaller extension that allows Infinispan code to directly create instances of it.
ExtendedRiverMarshaller(RiverMarshallerFactory, SerializableClassRegistry, MarshallingConfiguration) - Constructor for class org.infinispan.jboss.marshalling.commons.ExtendedRiverMarshaller
 
ExtendedRiverUnmarshaller - Class in org.infinispan.jboss.marshalling.commons
An extended RiverUnmarshaller that allows to track lifecycle of unmarshaller so that pools can be notified when not in use any more.
ExtendedRiverUnmarshaller(RiverMarshallerFactory, SerializableClassRegistry, MarshallingConfiguration) - Constructor for class org.infinispan.jboss.marshalling.commons.ExtendedRiverUnmarshaller
 
ExtendedStatistic - Enum in org.infinispan.extendedstats.container
The available extended statistics
ExtendedStatisticInterceptor - Class in org.infinispan.extendedstats.wrappers
Take the statistics about relevant visitable commands.
ExtendedStatisticInterceptor() - Constructor for class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
ExtendedStatisticLockManager - Class in org.infinispan.extendedstats.wrappers
Takes statistic about lock acquisition.
ExtendedStatisticLockManager(LockManager, CacheStatisticManager, TimeService) - Constructor for class org.infinispan.extendedstats.wrappers.ExtendedStatisticLockManager
 
ExtendedStatisticNotFoundException - Exception Class in org.infinispan.extendedstats
 
ExtendedStatisticNotFoundException(String) - Constructor for exception class org.infinispan.extendedstats.ExtendedStatisticNotFoundException
 
extendedStatisticNotFoundForPercentile(ExtendedStatistic, Throwable) - Method in interface org.infinispan.extendedstats.logging.Log
 
ExtendedStatisticRpcManager - Class in org.infinispan.extendedstats.wrappers
Takes statistics about the RPC invocations.
ExtendedStatisticRpcManager(RpcManager, CacheStatisticManager, TimeService, StreamingMarshaller) - Constructor for class org.infinispan.extendedstats.wrappers.ExtendedStatisticRpcManager
 
ExtendedStatisticsContainer - Interface in org.infinispan.extendedstats.container
Contains the statistic's values and allows to perform modifications on them.
EXTENDS - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
EXTERNAL_HOST - Enum constant in enum org.infinispan.server.hotrod.configuration.Attribute
 
EXTERNAL_PORT - Enum constant in enum org.infinispan.server.hotrod.configuration.Attribute
 
Externalizer<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.
Externalizer() - Constructor for class org.infinispan.cache.impl.BiFunctionMapper.Externalizer
 
Externalizer() - Constructor for class org.infinispan.cache.impl.EncoderEntryMapper.Externalizer
 
Externalizer() - Constructor for class org.infinispan.cache.impl.EncoderKeyMapper.Externalizer
 
Externalizer() - Constructor for class org.infinispan.cache.impl.EncoderValueMapper.Externalizer
 
Externalizer() - Constructor for class org.infinispan.cache.impl.FunctionMapper.Externalizer
 
Externalizer() - Constructor for class org.infinispan.commons.hash.MurmurHash3.Externalizer
 
Externalizer() - Constructor for class org.infinispan.commons.io.ByteBufferImpl.Externalizer
 
Externalizer() - Constructor for class org.infinispan.commons.marshall.WrappedByteArray.Externalizer
 
Externalizer() - Constructor for class org.infinispan.commons.util.ImmutableListCopy.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.ImmortalCacheEntry.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.ImmortalCacheValue.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.metadata.MetadataImmortalCacheEntry.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.metadata.MetadataMortalCacheValue.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.metadata.MetadataTransientCacheValue.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.MortalCacheEntry.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.MortalCacheValue.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.RemoteMetadata.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.TransientCacheEntry.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.TransientCacheValue.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.TransientMortalCacheEntry.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.entries.TransientMortalCacheValue.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.versioning.NumericVersion.Externalizer
 
Externalizer() - Constructor for class org.infinispan.container.versioning.SimpleClusteredVersion.Externalizer
 
Externalizer() - Constructor for class org.infinispan.context.Flag.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.impl.DefaultConsistentHash.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.impl.ScatteredConsistentHash.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.impl.TopologyAwareConsistentHashFactory.Externalizer
 
Externalizer() - Constructor for class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory.Externalizer
 
Externalizer() - Constructor for class org.infinispan.encoding.DataConversion.Externalizer
 
Externalizer() - Constructor for class org.infinispan.filter.AcceptAllKeyValueFilter.Externalizer
 
Externalizer() - Constructor for class org.infinispan.filter.CompositeKeyValueFilter.Externalizer
 
Externalizer() - Constructor for class org.infinispan.functional.impl.StatsEnvelope.Externalizer
 
Externalizer() - Constructor for class org.infinispan.globalstate.impl.CacheState.Externalizer
 
Externalizer() - Constructor for class org.infinispan.globalstate.ScopedState.Externalizer
 
Externalizer() - Constructor for class org.infinispan.globalstate.ScopeFilter.Externalizer
 
Externalizer() - Constructor for class org.infinispan.metadata.EmbeddedMetadata.Externalizer
 
Externalizer() - Constructor for class org.infinispan.metadata.impl.InternalMetadataImpl.Externalizer
Deprecated.
 
Externalizer() - Constructor for class org.infinispan.notifications.cachelistener.cluster.ClusterEvent.Externalizer
 
Externalizer() - Constructor for class org.infinispan.notifications.cachelistener.cluster.ClusterListenerRemoveCallable.Externalizer
 
Externalizer() - Constructor for class org.infinispan.notifications.cachelistener.cluster.ClusterListenerReplicateCallable.Externalizer
 
Externalizer() - Constructor for class org.infinispan.notifications.cachelistener.filter.CacheEventConverterAsConverter.Externalizer
 
Externalizer() - Constructor for class org.infinispan.notifications.cachelistener.filter.CacheEventFilterAsKeyValueFilter.Externalizer
 
Externalizer() - Constructor for class org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverterAsKeyValueFilterConverter.Externalizer
 
Externalizer() - Constructor for class org.infinispan.notifications.cachelistener.filter.KeyValueFilterAsCacheEventFilter.Externalizer
 
Externalizer() - Constructor for class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter.Externalizer
 
Externalizer() - Constructor for class org.infinispan.partitionhandling.AvailabilityMode.Externalizer
 
Externalizer() - Constructor for class org.infinispan.persistence.remote.upgrade.AddSourceRemoteStoreTask.Externalizer
 
Externalizer() - Constructor for class org.infinispan.persistence.remote.upgrade.CheckRemoteStoreTask.Externalizer
 
Externalizer() - Constructor for class org.infinispan.persistence.remote.upgrade.DisconnectRemoteStoreTask.Externalizer
 
Externalizer() - Constructor for class org.infinispan.persistence.remote.upgrade.MigrationTask.Externalizer
 
Externalizer() - Constructor for class org.infinispan.persistence.remote.upgrade.RemovedFilter.Externalizer
 
Externalizer() - Constructor for class org.infinispan.query.impl.QueryDefinition.Externalizer
 
Externalizer() - Constructor for class org.infinispan.remoting.responses.BiasRevocationResponse.Externalizer
 
Externalizer() - Constructor for class org.infinispan.remoting.responses.CacheNotFoundResponse.Externalizer
 
Externalizer() - Constructor for class org.infinispan.remoting.responses.ExceptionResponse.Externalizer
 
Externalizer() - Constructor for class org.infinispan.remoting.responses.SuccessfulResponse.Externalizer
 
Externalizer() - Constructor for class org.infinispan.remoting.responses.UnsuccessfulResponse.Externalizer
 
Externalizer() - Constructor for class org.infinispan.remoting.responses.UnsureResponse.Externalizer
 
Externalizer() - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsAddress.Externalizer
 
Externalizer() - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress.Externalizer
 
Externalizer() - Constructor for class org.infinispan.server.core.security.simple.SimpleGroupPrincipal.Externalizer
 
Externalizer() - Constructor for class org.infinispan.server.core.security.simple.SimpleSubjectUserInfo.Externalizer
 
Externalizer() - Constructor for class org.infinispan.stream.impl.CacheBiConsumers.Externalizer
 
Externalizer() - Constructor for class org.infinispan.topology.CacheJoinInfo.Externalizer
 
Externalizer() - Constructor for class org.infinispan.topology.CacheStatusResponse.Externalizer
 
Externalizer() - Constructor for class org.infinispan.topology.CacheTopology.Externalizer
 
Externalizer() - Constructor for class org.infinispan.topology.ManagerStatusResponse.Externalizer
 
Externalizer() - Constructor for class org.infinispan.topology.PersistentUUID.Externalizer
 
Externalizer() - Constructor for class org.infinispan.transaction.xa.GlobalTransaction.Externalizer
 
Externalizer() - Constructor for class org.infinispan.util.KeyValuePair.Externalizer
 
EXTERNALIZER - Static variable in class org.infinispan.commands.CommandInvocationId
 
EXTERNALIZER - Static variable in class org.infinispan.commons.tx.XidImpl
 
EXTERNALIZER - Static variable in class org.infinispan.distribution.group.impl.CacheEntryGroupPredicate
 
EXTERNALIZER - Static variable in class org.infinispan.remoting.responses.PrepareResponse
 
EXTERNALIZER - Static variable in class org.infinispan.server.hotrod.tx.table.CacheXid
 
EXTERNALIZER - Static variable in class org.infinispan.server.hotrod.tx.table.ClientAddress
 
EXTERNALIZER - Static variable in class org.infinispan.server.hotrod.tx.table.functions.ConditionalMarkAsRollbackFunction
 
EXTERNALIZER - Static variable in class org.infinispan.server.hotrod.tx.table.functions.CreateStateFunction
 
EXTERNALIZER - Static variable in class org.infinispan.server.hotrod.tx.table.functions.PreparingDecisionFunction
 
EXTERNALIZER - Static variable in class org.infinispan.server.hotrod.tx.table.functions.SetCompletedTransactionFunction
 
EXTERNALIZER - Static variable in class org.infinispan.server.hotrod.tx.table.functions.SetDecisionFunction
 
EXTERNALIZER - Static variable in class org.infinispan.server.hotrod.tx.table.functions.SetPreparedFunction
 
EXTERNALIZER - Static variable in class org.infinispan.server.hotrod.tx.table.functions.XidPredicate
 
EXTERNALIZER - Static variable in class org.infinispan.server.hotrod.tx.table.TxState
 
EXTERNALIZER - Static variable in class org.infinispan.transaction.xa.recovery.InDoubtTxInfo
 
EXTERNALIZER - Static variable in class org.infinispan.xsite.response.AutoStateTransferResponse
 
ExternalizerIds - Class in org.infinispan.server.core
Externalizer ids used by Server module AdvancedExternalizer implementations.
ExternalizerIds - Interface in org.infinispan.multimap.impl
Ids range: 2050 - 2099 Externalizer Ids that identity the functions used in EmbeddedMultimapCache
ExternalizerIds - Interface in org.infinispan.persistence.remote
1800 to 1899 range is reserved for this module
externalMechNotAllowedWithoutSSLClientCert() - Method in interface org.infinispan.server.hotrod.logging.Log
 
ExternalSaslServerFactory - Class in org.infinispan.server.core.security.external
 
ExternalSaslServerFactory(X500Principal) - Constructor for class org.infinispan.server.core.security.external.ExternalSaslServerFactory
 
ExternalStore<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
extractCreated(CacheEntry) - Static method in class org.infinispan.server.hotrod.MetadataUtils
 
extractException(Throwable) - Static method in class org.infinispan.commons.util.concurrent.CompletableFutures
 
extractFieldName(String) - Static method in class org.infinispan.commons.util.ReflectionUtil
 
extractIndexable(Object) - Method in class org.infinispan.encoding.DataConversion
Convert the stored object in a format suitable to be indexed.
extractKey(Object) - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
Extract the key from a set element.
extractKey(Object) - Method in class org.infinispan.cache.impl.CacheBackedEntrySet
 
extractKey(Object) - Method in class org.infinispan.cache.impl.CacheBackedKeySet
 
extractLastUsed(CacheEntry) - Static method in class org.infinispan.server.hotrod.MetadataUtils
 
extractLifespan(CacheEntry) - Static method in class org.infinispan.server.hotrod.MetadataUtils
 
extractMaxIdle(CacheEntry) - Static method in class org.infinispan.server.hotrod.MetadataUtils
 
extractMetadata(Metadata) - Static method in class org.infinispan.metadata.impl.InternalMetadataImpl
Deprecated.
 
extractSegment(ReplicableCommand, Object, KeyPartitioner) - Static method in interface org.infinispan.commands.SegmentSpecificCommand
Utility to extract the segment from a given command that may be a SegmentSpecificCommand.
extractSegmentAwareKey(ReplicableCommand, K, KeyPartitioner) - Static method in interface org.infinispan.commands.SegmentSpecificCommand
Create an SegmentAwareKey instance with the key and its segment.
extractStateTransferFlag(InvocationContext, FlagAffectedCommand) - Static method in class org.infinispan.context.impl.FlagBitSets
 
extractVersion(CacheEntry) - Static method in class org.infinispan.server.hotrod.MetadataUtils
 
extraStopSteps() - Method in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
Method to extend to add additional steps when the store is shutting down.
extraStopSteps() - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 

F

factor() - Method in class org.infinispan.configuration.cache.IndexMergeConfiguration
 
factor() - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
 
factor(int) - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
 
FACTOR - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
FACTOR - Static variable in class org.infinispan.configuration.cache.IndexMergeConfiguration
 
factory - Variable in class org.infinispan.client.hotrod.counter.impl.BaseCounter
 
factory - Static variable in class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller
 
factory() - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfiguration
 
factory() - Static method in class org.infinispan.commons.dataconversion.internal.Json
Return the Json.Factory currently in effect.
factory() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfiguration
 
factory() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfiguration
 
factory() - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfiguration
 
factory(ExecutorFactory) - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfigurationBuilder
Specify factory class for executor
factory(ExecutorFactory) - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
Specify factory class for executor NOTE: Currently Infinispan will not use the object instance, but instead instantiate a new instance of the class.
factory(ExecutorFactory) - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
Specify factory class for executor NOTE: Currently Infinispan will not use the object instance, but instead instantiate a new instance of the class.
factory(ScheduledExecutorFactory) - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
Specify factory class for executor NOTE: Currently Infinispan will not use the object instance, but instead instantiate a new instance of the class.
Factory() - Constructor for class org.infinispan.stats.impl.StatsCollector.Factory
 
FACTORY - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
 
factoryClass() - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfiguration
 
factoryClass(Class<? extends ExecutorFactory>) - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfigurationBuilder
Specify factory class for executor
factoryClass(String) - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfigurationBuilder
 
fail() - Method in interface org.infinispan.scattered.BiasManager.Revocation
 
FAIL - Enum constant in enum org.infinispan.configuration.cache.BackupFailurePolicy
 
FAIL_SILENTLY - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
FAIL_SILENTLY - Enum constant in enum org.infinispan.context.Flag
Swallows any exceptions, logging them instead at a low log level.
FAIL_SILENTLY - Static variable in class org.infinispan.configuration.cache.AsyncStoreConfiguration
 
FAIL_SILENTLY - Static variable in class org.infinispan.context.impl.FlagBitSets
 
failAfter(long, TimeUnit) - Method in class org.infinispan.query.impl.QueryDefinition
 
failAtomic() - Method in class org.infinispan.batch.AutoBatchSupport
 
FAILED - Enum constant in enum org.infinispan.health.HealthStatus
The cache did not start due to a error.
FAILED - Enum constant in enum org.infinispan.lifecycle.ComponentStatus
The component is in a failed state due to a problem with one of the other lifecycle transition phases.
FAILED - Enum constant in enum org.infinispan.server.core.BackupManager.Status
 
failedAcquiringLockFile(Throwable, FileSystemLock) - Method in interface org.infinispan.persistence.sifs.Log
 
failedAddingNewServer(SocketAddress, Throwable) - Method in interface org.infinispan.client.hotrod.logging.Log
 
failedClearingJdbcCacheStore(Exception) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
 
failedClosingNamingCtx(NamingException) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
 
failedToAddListener(Object, short) - Method in interface org.infinispan.client.hotrod.logging.Log
 
failedToCloseIndex(IOException) - Method in interface org.infinispan.persistence.sifs.Log
 
failedToCreatePredefinedSerializationContextInitializer(String, Throwable) - Method in interface org.infinispan.client.hotrod.logging.Log
 
failedToParseSystemProperty(String, Exception) - Method in interface org.infinispan.query.logging.Log
 
failedToPurgeIndexForSegments(Throwable, IntSet) - Method in interface org.infinispan.query.logging.Log
 
FAILOVER_EVENT_SINGLETON - Static variable in class org.infinispan.client.hotrod.event.impl.ClientEventDispatcher
 
failoverClientListener(byte[]) - Method in class org.infinispan.client.hotrod.event.impl.ClientListenerNotifier
 
failoverListeners(Set<SocketAddress>) - Method in class org.infinispan.client.hotrod.event.impl.ClientListenerNotifier
 
FailoverRequestBalancingStrategy - Interface in org.infinispan.client.hotrod
Defines what servers will be selected when a smart-routed request fails.
failSilently() - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
 
failSilently(boolean) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
failStateTransfer() - Method in class org.infinispan.xsite.statetransfer.RemoteSiteStatus
 
FAILURE_POLICY - Static variable in class org.infinispan.configuration.cache.BackupConfiguration
 
FAILURE_POLICY_CLASS - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
FAILURE_POLICY_CLASS - Static variable in class org.infinispan.configuration.cache.BackupConfiguration
 
failureClosingConnection(SQLException) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
 
failureCompletingTransaction(Transaction) - Method in class org.infinispan.transaction.impl.TransactionTable
 
failureCompletingTransaction(Transaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
 
failureHandler() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
 
failurePolicyClass() - Method in class org.infinispan.configuration.cache.BackupConfiguration
If the failure policy is set to BackupFailurePolicy.CUSTOM then the failurePolicyClass is required and should return the fully qualified name of a class implementing CustomFailurePolicy
failurePolicyClass() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
If the failure policy is set to BackupFailurePolicy.CUSTOM then the failurePolicyClass is required and should return the fully qualified name of a class implementing CustomFailurePolicy
failurePolicyClass(String) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
FakeJTATransaction - Class in org.infinispan.transaction.impl
 
FakeJTATransaction() - Constructor for class org.infinispan.transaction.impl.FakeJTATransaction
 
FastCopyHashMap<K,V> - Class in org.infinispan.commons.util
A HashMap that is optimized for fast shallow copies.
FastCopyHashMap() - Constructor for class org.infinispan.commons.util.FastCopyHashMap
 
FastCopyHashMap(int) - Constructor for class org.infinispan.commons.util.FastCopyHashMap
 
FastCopyHashMap(int, float) - Constructor for class org.infinispan.commons.util.FastCopyHashMap
 
FastCopyHashMap(Map<? extends K, ? extends V>) - Constructor for class org.infinispan.commons.util.FastCopyHashMap
 
FastCopyHashMap.EntrySet - Class in org.infinispan.commons.util
 
FastCopyHashMap.KeySet - Class in org.infinispan.commons.util
 
FastCopyHashMap.Values - Class in org.infinispan.commons.util
 
fastHash(char[], int, int) - Static method in class org.infinispan.commons.configuration.io.xml.MXParser
simplistic implementation of hash function that has constant time to compute - so it also means diminishing hash quality for long strings but for XML parsing it should be good enough ...
fatalIndexError(Throwable) - Method in interface org.infinispan.persistence.sifs.Log
 
fclose(OutputStream) - Static method in class org.infinispan.util.stream.Streams
Deprecated.
Attempt to flush and close an OutputStream.
fclose(OutputStream[]) - Static method in class org.infinispan.util.stream.Streams
Deprecated.
Attempt to flush and close an array of OutputStreams.
FEATURE_NAMES_INTERNED - Static variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
FEATURE_PREFIX - Static variable in class org.infinispan.commons.util.Features
 
FEATURE_PROCESS_DOCDECL - Static variable in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
This feature determines whether the document declaration is processed.
FEATURE_PROCESS_NAMESPACES - Static variable in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
This feature determines whether the parser processes namespaces.
FEATURE_REPORT_NAMESPACE_ATTRIBUTES - Static variable in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
This feature determines whether namespace attributes are exposed via the attribute access methods.
FEATURE_VALIDATION - Static variable in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
If this feature is activated, all validation errors as defined in the XML 1.0 sepcification are reported.
FEATURE_XML_ROUNDTRIP - Static variable in class org.infinispan.commons.configuration.io.xml.MXParser
 
features() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
features() - Method in class org.infinispan.configuration.global.GlobalConfiguration
 
Features - Class in org.infinispan.commons.util
Features allow conditional enabling/disabling of Infinispan's functionality.
Features() - Constructor for class org.infinispan.commons.util.Features
 
Features(ClassLoader) - Constructor for class org.infinispan.commons.util.Features
 
FETCH_IN_MEMORY_STATE - Static variable in class org.infinispan.configuration.cache.StateTransferConfiguration
 
FETCH_SIZE - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
 
FETCH_SIZE - Static variable in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
FETCH_STATE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
FETCH_TX_RECOVERY - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
FETCH_TX_RECOVERY - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
fetchChannelAndInvoke(int, Set<SocketAddress>) - Method in class org.infinispan.client.hotrod.counter.operation.AddListenerOperation
 
fetchChannelAndInvoke(int, Set<SocketAddress>) - Method in class org.infinispan.client.hotrod.counter.operation.AddOperation
 
fetchChannelAndInvoke(int, Set<SocketAddress>) - Method in class org.infinispan.client.hotrod.counter.operation.CompareAndSwapOperation
 
fetchChannelAndInvoke(int, Set<SocketAddress>) - Method in class org.infinispan.client.hotrod.counter.operation.DefineCounterOperation
 
fetchChannelAndInvoke(int, Set<SocketAddress>) - Method in class org.infinispan.client.hotrod.counter.operation.GetConfigurationOperation
 
fetchChannelAndInvoke(int, Set<SocketAddress>) - Method in class org.infinispan.client.hotrod.counter.operation.GetCounterNamesOperation
 
fetchChannelAndInvoke(int, Set<SocketAddress>) - Method in class org.infinispan.client.hotrod.counter.operation.GetValueOperation
 
fetchChannelAndInvoke(int, Set<SocketAddress>) - Method in class org.infinispan.client.hotrod.counter.operation.IsDefinedOperation
 
fetchChannelAndInvoke(int, Set<SocketAddress>) - Method in class org.infinispan.client.hotrod.counter.operation.RemoveOperation
 
fetchChannelAndInvoke(int, Set<SocketAddress>) - Method in class org.infinispan.client.hotrod.counter.operation.ResetOperation
 
fetchChannelAndInvoke(int, Set<SocketAddress>) - Method in class org.infinispan.client.hotrod.counter.operation.RemoveListenerOperation
 
fetchInMemoryState() - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
If true, the cache will fetch data from the neighboring caches when it starts up, so the cache starts 'warm', although it will impact startup time.
fetchInMemoryState(boolean) - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
If true, the cache will fetch data from the neighboring caches when it starts up, so the cache starts 'warm', although it will impact startup time.
fetchPersistentState() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
since 14.0. Always returns false. The first non shared store is used instead.
fetchPersistentState() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
since 14.0. This will always return false
fetchPersistentState() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
If true, fetch persistent state when joining a cluster.
fetchPersistentState(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
Deprecated since 14.0. There is no replacement. First non shared store is picked instead.
fetchPersistentState(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
 
fetchPersistentState(boolean) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
since 14.0. This method does nothing. Only the first non shared store that supports publishEntries is used for state transfer.
fetchSize - Variable in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
 
fetchSize() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
 
fetchSize(int) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
For DB queries the fetch size is on ResultSet.setFetchSize(int).
file - Variable in class org.infinispan.persistence.sifs.EntryInfo
 
FILE - Static variable in class org.infinispan.io.GridFile.Metadata
Deprecated.
 
FILE_CACHE_KEY - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
FILE_LIST_CACHE_KEY - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
FILE_LIST_CACHE_VALUE - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
FILE_METADATA - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
FILE_NAME - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
 
FILE_READ_LOCK_KEY - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
 
FILE_STORE - Enum constant in enum org.infinispan.configuration.parsing.Element
 
fileChannel - Variable in class org.infinispan.persistence.sifs.FileProvider.Log
 
fileChannelConfigurator(FileJGroupsChannelConfigurator) - Method in class org.infinispan.configuration.global.StackFileConfigurationBuilder
 
fileId - Variable in class org.infinispan.persistence.sifs.FileProvider.Log
 
FileJGroupsChannelConfigurator - Class in org.infinispan.remoting.transport.jgroups
A JGroups JGroupsChannelConfigurator which loads configuration from an XML file supplied as an InputStream
FileJGroupsChannelConfigurator(String, String, InputStream, Properties) - Constructor for class org.infinispan.remoting.transport.jgroups.FileJGroupsChannelConfigurator
 
fileLocationTransform(String, int) - Static method in class org.infinispan.configuration.cache.AbstractSegmentedStoreConfiguration
Transforms a file location to a segment based one.
FileLookup - Interface in org.infinispan.commons.util
 
FileLookupFactory - Class in org.infinispan.commons.util
 
FileLookupFactory() - Constructor for class org.infinispan.commons.util.FileLookupFactory
 
FileLookupFactory.DefaultFileLookup - Class in org.infinispan.commons.util
 
filename(String) - Static method in class org.infinispan.io.GridFile
Deprecated.
 
FILENAME - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
 
FileProvider - Class in org.infinispan.persistence.sifs
Provides resource management for files - only limited amount of files may be opened in one moment, and opened file should not be deleted.
FileProvider(Path, int, String, int) - Constructor for class org.infinispan.persistence.sifs.FileProvider
 
FileProvider.Handle - Class in org.infinispan.persistence.sifs
 
FileProvider.Log - Class in org.infinispan.persistence.sifs
 
FILESYSTEM - Enum constant in enum org.infinispan.configuration.cache.IndexStorage
 
FileSystemLock - Class in org.infinispan.commons.util.concurrent
A simplified global lock backed by the file system.
FileSystemLock(Path, String) - Constructor for class org.infinispan.commons.util.concurrent.FileSystemLock
Creates new instance of the lock.
fillBuf() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
fillInStackTrace() - Method in exception class org.infinispan.commons.marshall.NotSerializableException
 
filter - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
filter(Object) - Method in interface org.infinispan.objectfilter.ObjectFilter
Tests if an object matches the filter.
filter(Object, Object) - Method in interface org.infinispan.objectfilter.ObjectFilter
Tests if an object matches the filter.
filter(DoublePredicate) - Method in interface org.infinispan.DoubleCacheStream
filter(DoublePredicate) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
filter(DoublePredicate) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
filter(IntPredicate) - Method in interface org.infinispan.IntCacheStream
filter(IntPredicate) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
filter(IntPredicate) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
filter(LongPredicate) - Method in interface org.infinispan.LongCacheStream
filter(LongPredicate) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
filter(LongPredicate) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
filter(Predicate<? super CacheEntry<K, V>>) - Method in interface org.infinispan.LockedStream
Returns a locked stream consisting of the elements of this stream that match the given predicate.
filter(Predicate<? super CacheEntry<K, V>>) - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
filter(Predicate<? super R>) - Method in interface org.infinispan.CacheStream
filter(Predicate<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
filter(Predicate<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
filter(Predicate<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
filter(Predicate<? super T>) - Method in interface org.infinispan.functional.Traversable
An intermediate operation that returns a traversable containing elements matching the given predicate.
filter(SerializableDoublePredicate) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleCacheStream.filter(DoublePredicate) except that the DoublePredicate must also implement Serializable
filter(SerializableDoublePredicate) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
filter(SerializableIntPredicate) - Method in interface org.infinispan.IntCacheStream
Same as IntCacheStream.filter(IntPredicate) except that the IntPredicate must also implement Serializable
filter(SerializableIntPredicate) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
filter(SerializableLongPredicate) - Method in interface org.infinispan.LongCacheStream
Same as LongCacheStream.filter(LongPredicate) except that the LongPredicate must also implement Serializable.
filter(SerializableLongPredicate) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
filter(SerializablePredicate<? super CacheEntry<K, V>>) - Method in interface org.infinispan.LockedStream
Same as LockedStream.filter(Predicate) except that the Predicate must also implement Serializable
filter(SerializablePredicate<? super R>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.filter(Predicate) except that the Predicate must also implement Serializable
filterAndConvert - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
filterAndConvert(Stream<CacheEntry<K, V>>, KeyValueFilterConverter<? super K, ? super V, C>) - Static method in class org.infinispan.filter.CacheFilters
Adds needed intermediate operations to the provided stream, returning a possibly new stream as a result of the operations.
filterAndConvert(K, V, Metadata) - Method in interface org.infinispan.filter.KeyValueFilterConverter
Will both filter the entry and if passed subsequently convert the value to a new value.
filterAndConvert(K, V, Metadata) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverterAsKeyValueFilterConverter
 
filterAndConvert(K, V, Metadata) - Method in class org.infinispan.server.hotrod.iteration.IterationFilter
 
filterAndConvert(K, V, Metadata, V, Metadata, EventType) - Method in interface org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverter
Will both filter the entry and if passed subsequently convert the value to a new value.
filterAndConvert(K, V, Metadata, V, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter
 
filterAndConvert(CacheStream<CacheEntry<K, V>>, KeyValueFilterConverter<? super K, ? super V, C>) - Static method in class org.infinispan.filter.CacheFilters
 
filterAndConvertToKey(CacheStream<CacheEntry<K, V>>, KeyValueFilterConverter<? super K, ? super V, C>) - Static method in class org.infinispan.filter.CacheFilters
 
filterAndConvertToValue(CacheStream<CacheEntry<K, V>>, KeyValueFilterConverter<? super K, ? super V, C>) - Static method in class org.infinispan.filter.CacheFilters
 
filterAnnotations - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
filterBySegment(LocalizedCacheTopology, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
FilterCallback - Interface in org.infinispan.objectfilter
A single-method callback that is specified when registering a filter with a Matcher.
filterCause(Throwable) - Static method in class org.infinispan.rest.RestRequestHandler
 
FilterConditionBeginContext - Interface in org.infinispan.query.dsl
Deprecated.
since 10.1. See deprecation note on QueryBuilder.
FilterConditionContext - Interface in org.infinispan.query.dsl
Deprecated.
since 10.1. See deprecation note on QueryBuilder.
FilterConditionContextQueryBuilder - Interface in org.infinispan.query.dsl
Deprecated.
since 10.1. See deprecation note on QueryBuilder.
FilterConditionEndContext - Interface in org.infinispan.query.dsl
Deprecated.
since 10.1. See deprecation note on QueryBuilder.
filterEntries(Map<K, V>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
 
filterExpiredEntries(Spliterator<InternalCacheEntry<K, V>>) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
Returns a new spliterator that will not return entries that have expired.
filterFactoryName() - Element in annotation type org.infinispan.client.hotrod.annotation.ClientListener
Defines the key/value filter factory for this client listener.
FilterIndexingServiceProvider - Interface in org.infinispan.notifications.cachelistener.filter
A service provider for filter indexing services.
FilteringListenable<K,V> - Interface in org.infinispan.notifications
A Listenable that can also filter events based on key
FilterIterator<E> - Class in org.infinispan.commons.util
Iterator that also filters out entries based on the provided predicate.
FilterIterator(Iterator<E>, Predicate<? super E>) - Constructor for class org.infinispan.commons.util.FilterIterator
 
filterKeys(Set<?>) - Method in interface org.infinispan.BaseCacheStream
Filters which entries are returned by only returning ones that map to the given key.
filterKeys(Set<?>) - Method in interface org.infinispan.CacheStream
Filters which entries are returned by only returning ones that map to the given key.
filterKeys(Set<?>) - Method in interface org.infinispan.DoubleCacheStream
Filters which entries are returned by only returning ones that map to the given key.
filterKeys(Set<?>) - Method in interface org.infinispan.IntCacheStream
Filters which entries are returned by only returning ones that map to the given key.
filterKeys(Set<?>) - Method in interface org.infinispan.LockedStream
Filters which entries are returned by only returning ones that map to the given key.
filterKeys(Set<?>) - Method in interface org.infinispan.LongCacheStream
Filters which entries are returned by only returning ones that map to the given key.
filterKeys(Set<?>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
filterKeys(Set<?>) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
filterKeys(Set<?>) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
filterKeys(Set<?>) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
filterKeys(Set<?>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
filterKeys(Set<?>) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
filterKeys(Set<?>) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
filterKeys(Set<?>) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
filterKeys(Set<?>) - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
filterKeys(Set<?>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
filterKeySegments(Set<Integer>) - Method in interface org.infinispan.BaseCacheStream
Deprecated.
since 9.3 This is to be replaced by BaseCacheStream.filterKeySegments(IntSet)
filterKeySegments(Set<Integer>) - Method in interface org.infinispan.CacheStream
Deprecated.
This is to be replaced by CacheStream.filterKeySegments(IntSet)
filterKeySegments(Set<Integer>) - Method in interface org.infinispan.DoubleCacheStream
Filters which entries are returned by what segment they are present in.
filterKeySegments(Set<Integer>) - Method in interface org.infinispan.IntCacheStream
Filters which entries are returned by what segment they are present in.
filterKeySegments(Set<Integer>) - Method in interface org.infinispan.LockedStream
Deprecated.
This is to be replaced by LockedStream.filterKeySegments(IntSet)
filterKeySegments(Set<Integer>) - Method in interface org.infinispan.LongCacheStream
Filters which entries are returned by what segment they are present in.
filterKeySegments(Set<Integer>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
filterKeySegments(Set<Integer>) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
filterKeySegments(Set<Integer>) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
filterKeySegments(Set<Integer>) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
filterKeySegments(Set<Integer>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
filterKeySegments(Set<Integer>) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
filterKeySegments(Set<Integer>) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
filterKeySegments(Set<Integer>) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
filterKeySegments(Set<Integer>) - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
filterKeySegments(Set<Integer>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
filterKeySegments(IntSet) - Method in interface org.infinispan.BaseCacheStream
Filters which entries are returned by what segment they are present in.
filterKeySegments(IntSet) - Method in interface org.infinispan.CacheStream
Filters which entries are returned by what segment they are present in.
filterKeySegments(IntSet) - Method in interface org.infinispan.LockedStream
Filters which entries are returned by what segment they are present in.
filterKeySegments(IntSet) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
filterKeySegments(IntSet) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
filterKeySegments(IntSet) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
filterKeySegments(IntSet) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
filterKeySegments(IntSet) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
filterKeySegments(IntSet) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
filterKeySegments(IntSet) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
filterKeySegments(IntSet) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
filterKeySegments(IntSet) - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
filterKeySegments(IntSet) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
FilterMapResponseCollector - Class in org.infinispan.remoting.transport.impl
FilterMapResponseCollector(ResponseFilter, boolean, int) - Constructor for class org.infinispan.remoting.transport.impl.FilterMapResponseCollector
 
filterNotSupportedWithQueryString() - Method in interface org.infinispan.query.logging.Log
 
filterPrivateCaches(Set<String>) - Method in class org.infinispan.registry.impl.InternalCacheRegistryImpl
 
FilterResult - Class in org.infinispan.query.remote.client
When using Ickle based filters with client event listeners you will get the event data (see org.infinispan.client.hotrod.event.ClientCacheEntryCustomEvent.getEventData) wrapped by this FilterResult.
FilterResult(Object, Object[], Comparable[]) - Constructor for class org.infinispan.query.remote.client.FilterResult
 
Filters - Class in org.infinispan.client.hotrod.filter
 
FilterSpliterator<T> - Class in org.infinispan.commons.util
Spliterator that only returns entries that pass the given predicate.
FilterSpliterator(Spliterator<T>, Predicate<? super T>) - Constructor for class org.infinispan.commons.util.FilterSpliterator
 
FilterSubscription - Interface in org.infinispan.objectfilter
A subscription for match notifications.
filterTargets(Collection<Address>) - Method in interface org.infinispan.manager.ClusterExecutor
Allows for filtering of address nodes by only allowing addresses in this collection from being contacted.
filterTargets(Predicate<? super Address>) - Method in interface org.infinispan.manager.ClusterExecutor
Allows for filtering of address nodes dynamically per invocation.
filterTargets(ClusterExecutionPolicy) - Method in interface org.infinispan.manager.ClusterExecutor
Allows for filtering of address nodes by only allowing addresses that match the given execution policy to be used.
filterTargets(ClusterExecutionPolicy, Predicate<? super Address>) - Method in interface org.infinispan.manager.ClusterExecutor
Allows for filtering of address nodes dynamically per invocation.
finalizeMapping() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMappingPartialBuildState
 
find() - Method in interface org.infinispan.functional.EntryView.ReadEntryView
Optional value.
find(Class<T>) - Method in class org.infinispan.functional.impl.MetaParams
 
findAddress(byte[]) - Method in class org.infinispan.client.hotrod.event.impl.ClientListenerNotifier
 
findAny() - Method in interface org.infinispan.functional.Traversable
A terminal operation that returns an optional containing an element of the traversable, or an empty optional if empty.
findAny() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
findAny() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
findAny() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
findAny() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
findAny() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
findAny() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
findAny() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
findAny() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
findAny() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
findAttribute(String) - Method in class org.infinispan.commons.configuration.attributes.ConfigurationElement
 
findById(String) - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository
 
findByIndexNameAndIndexValue(String, String) - Method in class org.infinispan.spring.embedded.session.InfinispanEmbeddedSessionRepository
 
findByIndexNameAndIndexValue(String, String) - Method in class org.infinispan.spring.remote.session.InfinispanRemoteSessionRepository
 
findCacheMgmtInterceptor() - Method in class org.infinispan.eviction.impl.EvictionManagerImpl
 
findClass(String) - Method in class org.infinispan.commons.util.AggregatedClassLoader
 
findExternalizerFor(Object) - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
findFirst() - Static method in class org.infinispan.reactive.publisher.PublisherReducers
 
findFirst() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
findFirst() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
findFirst() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
findFirst() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
findFirst() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
findFirst() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
findFirst() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
findFirst() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
findFirst() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
findFork(JChannel) - Static method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
findGetterForField(Class<?>, String) - Static method in class org.infinispan.commons.util.ReflectionUtil
 
findInterceptorExtending(Class<T>) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Returns the first interceptor extending the given class, or null if there is none.
findInterceptorExtending(Class<T>) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
findInterceptorWithClass(Class<T>) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
Returns the first interceptor with the given class, or null if there is none.
findInterceptorWithClass(Class<T>) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
findIracMetadataFromCacheEntry(CacheEntry<?, ?>) - Static method in class org.infinispan.util.IracUtils
 
findListenerCallbacks(Object) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
 
findListenerId(Object) - Method in class org.infinispan.client.hotrod.event.impl.ClientListenerNotifier
 
findMetaParam(Class<T>) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
 
findMetaParam(Class<T>) - Method in interface org.infinispan.functional.MetaParam.Lookup
Returns a non-empty Optional instance containing a metadata parameter instance that can be assigned to the type Class passed in, or an empty Optional if no metadata can be assigned to that type.
findMethod(Class<?>, String) - Static method in class org.infinispan.commons.util.ReflectionUtil
 
findMethod(Class<?>, String, Class<?>...) - Static method in class org.infinispan.commons.util.ReflectionUtil
 
findMethods(Object) - Static method in class org.infinispan.client.hotrod.event.impl.ClientEventDispatcher
 
findNewBackupOwner(DefaultConsistentHashFactory.Builder, Collection<Address>, Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
 
findNewPrimaryOwner(AbstractConsistentHashFactory.Builder, Collection<Address>, Address) - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHashFactory
 
findNext() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator
 
findNextHighestPowerOfTwo(int) - Static method in class org.infinispan.commons.util.Util
Returns a number such that the number is a power of two that is equal to, or greater than, the number passed in as an argument.
findProvider(String, String, String) - Static method in class org.infinispan.commons.util.SslContextFactory
 
findResource(String) - Method in class org.infinispan.commons.util.AggregatedClassLoader
 
findScopeAll() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
 
findScopeAll() - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
 
findSetterForField(Class<?>, String) - Static method in class org.infinispan.commons.util.ReflectionUtil
 
findWorstPrimaryOwner(AbstractConsistentHashFactory.Builder, List<Address>) - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHashFactory
 
finish() - Method in class org.infinispan.jboss.marshalling.commons.ExtendedRiverMarshaller
 
finish() - Method in class org.infinispan.jboss.marshalling.commons.ExtendedRiverUnmarshaller
 
finish() - Method in class org.infinispan.remoting.transport.impl.FilterMapResponseCollector
 
finish() - Method in class org.infinispan.remoting.transport.impl.MapResponseCollector
 
finish() - Method in class org.infinispan.remoting.transport.impl.PassthroughMapResponseCollector
 
finish() - Method in class org.infinispan.remoting.transport.impl.PassthroughSingleResponseCollector
 
finish() - Method in class org.infinispan.remoting.transport.impl.VoidResponseCollector
 
finish() - Method in interface org.infinispan.remoting.transport.ResponseCollector
Called after ResponseCollector.addResponse(Address, Response) returns null for the last response.
finish() - Method in class org.infinispan.remoting.transport.ValidResponseCollector
 
finish() - Method in class org.infinispan.remoting.transport.ValidSingleResponseCollector
 
finish() - Method in class org.infinispan.xsite.response.AutoStateTransferResponseCollector
 
finisher() - Method in class org.infinispan.commons.dataconversion.internal.JsonArrayCollector
 
finisher() - Method in class org.infinispan.commons.util.ArrayCollector
 
finishObjectInput(ObjectInput) - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
Deprecated.
Finish using the given ObjectInput.
finishObjectInput(ObjectInput) - Method in class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller
 
finishObjectInput(ObjectInput) - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
finishObjectOutput(ObjectOutput) - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
Deprecated.
Finish using the given ObjectOutput.
finishObjectOutput(ObjectOutput) - Method in class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller
 
finishObjectOutput(ObjectOutput) - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
FIREBIRD - Enum constant in enum org.infinispan.persistence.jdbc.common.DatabaseType
 
fireParserListeners() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
first() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
 
FIRST - Enum constant in enum org.infinispan.configuration.cache.InterceptorConfiguration.Position
Specifies that the new interceptor is placed first in the chain.
firstAddress - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
firstEnlistedResource() - Method in class org.infinispan.transaction.tm.EmbeddedTransaction
 
firstEnlistedResource() - Method in class org.infinispan.transaction.tm.EmbeddedTransactionManager
 
firstResult(int) - Method in interface org.infinispan.query.impl.IndexedQuery
Sets the index of the first result, skipping the previous ones.
firstResult(int) - Method in class org.infinispan.query.impl.IndexedQueryImpl
Sets the result of the given integer value to the first result.
fixedArray(ByteBuf, int) - Static method in class org.infinispan.server.hotrod.Intrinsics
 
Flag - Enum in org.infinispan.client.hotrod
Defines all the flags available in the Hot Rod client that can influence the behavior of operations.
Flag - Enum in org.infinispan.context
Available flags, which may be set on a per-invocation basis.
FLAG - Static variable in interface org.infinispan.commons.marshall.Ids
 
Flag.Externalizer - Class in org.infinispan.context
 
FlagAffectedCommand - Interface in org.infinispan.commands
Flags modify behavior of command such as whether or not to invoke certain commands remotely, check cache store etc.
FlagAffectedStore<K,V> - Interface in org.infinispan.persistence.spi
Implemented by stores that can skip writes based on certain flags present in the invocation.
FlagBitSets - Class in org.infinispan.context.impl
Pre-computed bitsets containing each flag.
FlagBitSets() - Constructor for class org.infinispan.context.impl.FlagBitSets
 
flags - Variable in class org.infinispan.container.entries.ReadCommittedEntry
 
flags() - Method in class org.infinispan.functional.impl.StatsEnvelope
 
FLAGS - Enum constant in enum org.infinispan.server.core.admin.AdminOperationParameter
 
FLAGS - Static variable in class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
 
FLAGS_HEADER - Enum constant in enum org.infinispan.rest.RequestHeader
 
flatMap(DoubleFunction<? extends DoubleStream>) - Method in interface org.infinispan.DoubleCacheStream
flatMap(DoubleFunction<? extends DoubleStream>) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
flatMap(DoubleFunction<? extends DoubleStream>) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
flatMap(Function<? super R, ? extends Stream<? extends R1>>) - Method in interface org.infinispan.CacheStream
flatMap(Function<? super R, ? extends Stream<? extends R1>>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
flatMap(Function<? super R, ? extends Stream<? extends R1>>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
flatMap(Function<? super R, ? extends Stream<? extends R1>>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
flatMap(Function<? super T, ? extends Traversable<? extends R>>) - Method in interface org.infinispan.functional.Traversable
An intermediate operation that returns a traversable containing the results of replacing each element of this traversable with the contents of a traversable produced by applying the provided function to each element.
flatMap(IntFunction<? extends IntStream>) - Method in interface org.infinispan.IntCacheStream
flatMap(IntFunction<? extends IntStream>) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
flatMap(IntFunction<? extends IntStream>) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
flatMap(LongFunction<? extends LongStream>) - Method in interface org.infinispan.LongCacheStream
flatMap(LongFunction<? extends LongStream>) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
flatMap(LongFunction<? extends LongStream>) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
flatMap(SerializableDoubleFunction<? extends DoubleStream>) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleCacheStream.flatMap(DoubleFunction) except that the DoubleFunction must also implement Serializable
flatMap(SerializableDoubleFunction<? extends DoubleStream>) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
flatMap(SerializableFunction<? super R, ? extends Stream<? extends R1>>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.flatMap(Function) except that the Function must also implement Serializable
flatMap(SerializableIntFunction<? extends IntStream>) - Method in interface org.infinispan.IntCacheStream
Same as IntCacheStream.flatMap(IntFunction) except that the IntFunction must also implement Serializable
flatMap(SerializableIntFunction<? extends IntStream>) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
flatMap(SerializableLongFunction<? extends LongStream>) - Method in interface org.infinispan.LongCacheStream
Same as LongCacheStream.flatMap(LongFunction) except that the LongFunction must also implement Serializable.
flatMap(SerializableLongFunction<? extends LongStream>) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
flatMapToDouble(Function<? super R, ? extends DoubleStream>) - Method in interface org.infinispan.CacheStream
flatMapToDouble(Function<? super R, ? extends DoubleStream>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
flatMapToDouble(Function<? super R, ? extends DoubleStream>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
flatMapToDouble(Function<? super R, ? extends DoubleStream>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
flatMapToDouble(SerializableFunction<? super R, ? extends DoubleStream>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.flatMapToDouble(Function) except that the Function must also implement Serializable
flatMapToInt(Function<? super R, ? extends IntStream>) - Method in interface org.infinispan.CacheStream
flatMapToInt(Function<? super R, ? extends IntStream>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
flatMapToInt(Function<? super R, ? extends IntStream>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
flatMapToInt(Function<? super R, ? extends IntStream>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
flatMapToInt(SerializableFunction<? super R, ? extends IntStream>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.flatMapToInt(Function) except that the Function must also implement Serializable
flatMapToLong(Function<? super R, ? extends LongStream>) - Method in interface org.infinispan.CacheStream
flatMapToLong(Function<? super R, ? extends LongStream>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
flatMapToLong(Function<? super R, ? extends LongStream>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
flatMapToLong(Function<? super R, ? extends LongStream>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
flatMapToLong(SerializableFunction<? super R, ? extends LongStream>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.flatMapToLong(Function) except that the Function must also implement Serializable
FlattenSpliterator<E> - Class in org.infinispan.commons.util
Composes an array of Collections into a spliterator.
FlattenSpliterator(IntFunction<Collection<E>>, int, int) - Constructor for class org.infinispan.commons.util.FlattenSpliterator
 
FLOAT - Enum constant in enum org.infinispan.persistence.sql.AbstractSchemaJdbcStore.ProtostreamFieldType
 
FlowableConnection(Connection, Consumer<Connection>, String) - Constructor for class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations.FlowableConnection
 
FlowableCreate<T> - Class in org.infinispan.reactive
Copied from rxjava3 80c83a4e000f0d054ea88a3bd500d36c2c041b05 This has been modified to allow for Flowable create method to be invoked per subscription request instead of during the initial subscribe, which may not even include a request of any size.
FlowableCreate(FlowableOnSubscribe<T>, BackpressureStrategy) - Constructor for class org.infinispan.reactive.FlowableCreate
 
fluentSetterName(String) - Static method in class org.infinispan.commons.util.BeanUtils
Retrieves a setter name based on a field name passed in
flush() - Method in class org.infinispan.commons.io.StringBuilderWriter
 
flush() - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
 
flush() - Method in class org.infinispan.io.GridOutputStream
Deprecated.
 
flush() - Method in class org.infinispan.io.UnclosableObjectOutputStream
Deprecated.
 
flush() - Method in class org.infinispan.io.WritableGridFileChannel
Deprecated.
 
flush() - Method in interface org.infinispan.search.mapper.scope.SearchWorkspace
Flush to disk the changes to indexes that were not committed yet.
flush(ChannelHandlerContext) - Method in class org.infinispan.server.core.transport.SaslQopHandler
 
flush(OutputStream) - Static method in class org.infinispan.util.stream.Streams
Deprecated.
Attempt to flush an OutputStream.
flush(OutputStream[]) - Static method in class org.infinispan.util.stream.Streams
Deprecated.
Attempt to flush an array of OutputStreams.
FLUSH_LOCK_TIMEOUT - Enum constant in enum org.infinispan.configuration.parsing.Attribute
Deprecated, for removal: This API element is subject to removal in a future version.
FlushAllRequest - Enum constant in enum org.infinispan.server.memcached.MemcachedOperation
 
flushCache(Collection<Object>, Address, boolean) - Method in class org.infinispan.distribution.impl.L1ManagerImpl
 
flushCache(Collection<Object>, Address, boolean) - Method in interface org.infinispan.distribution.L1Manager
 
flushGlobalACLCache() - Method in interface org.infinispan.security.GlobalSecurityManager
Flushes the ACL cache for this node
flushGlobalACLCache() - Method in class org.infinispan.security.impl.GlobalSecurityManagerImpl
 
flushGlobalACLCache0() - Method in class org.infinispan.security.impl.GlobalSecurityManagerImpl
 
flushing() - Method in class org.infinispan.extendedstats.container.ConcurrentGlobalContainer
 
flushingIndex(String) - Method in interface org.infinispan.query.logging.Log
 
flushMode - Variable in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository
 
flushTo(ConcurrentGlobalContainer) - Method in class org.infinispan.extendedstats.TransactionStatistics
Merges this statistics in the global container.
fmap - Variable in class org.infinispan.functional.impl.ReadOnlyMapImpl
 
fmap - Variable in class org.infinispan.functional.impl.ReadWriteMapImpl
 
fmap - Variable in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
forAddress(String, int, boolean) - Static method in interface org.infinispan.server.hotrod.ServerAddress
 
force - Variable in class org.infinispan.commons.maven.AbstractArtifact
 
force(boolean) - Method in class org.infinispan.commons.maven.AbstractArtifact
 
force(boolean) - Method in interface org.infinispan.commons.maven.Artifact
 
force(boolean) - Method in class org.infinispan.persistence.sifs.FileProvider.Handle
 
FORCE_ASYNCHRONOUS - Enum constant in enum org.infinispan.context.Flag
Forces asynchronous network calls where possible, even if otherwise configured to use synchronous network calls.
FORCE_ASYNCHRONOUS - Static variable in class org.infinispan.context.impl.FlagBitSets
 
FORCE_RETURN_VALUE - Enum constant in enum org.infinispan.client.hotrod.Flag
By default, previously existing values for Map operations are not returned.
FORCE_RETURN_VALUES - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
 
FORCE_RETURN_VALUES - Static variable in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
 
FORCE_RETURN_VALUES - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
FORCE_SYNCHRONOUS - Enum constant in enum org.infinispan.context.Flag
Forces synchronous network calls where possible, even if otherwise configured to use asynchronous network calls.
FORCE_SYNCHRONOUS - Static variable in class org.infinispan.context.impl.FlagBitSets
 
FORCE_WRITE_LOCK - Enum constant in enum org.infinispan.context.Flag
Forces a write lock, even if the invocation is a read operation.
FORCE_WRITE_LOCK - Static variable in class org.infinispan.context.impl.FlagBitSets
 
forceAvailabilityMode(String, AvailabilityMode) - Method in interface org.infinispan.topology.ClusterTopologyManager
 
forceAvailabilityMode(String, AvailabilityMode) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
forceAvailabilityMode(AvailabilityMode) - Method in class org.infinispan.topology.ClusterCacheStatus
 
forceCommit(int, byte[], byte[]) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
forceCommit(long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
forceRebalance() - Method in class org.infinispan.topology.ClusterCacheStatus
 
forceRebalance(String) - Method in interface org.infinispan.topology.ClusterTopologyManager
 
forceRebalance(String) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
forceRelease(String) - Method in interface org.infinispan.lock.api.ClusteredLockManager
Releases - or unlocks - a ClusteredLock if such exists.
ForceReturnPreviousValue - Enum constant in enum org.infinispan.server.hotrod.ProtocolFlag
 
forceReturnValues() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
forceReturnValues() - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
 
forceReturnValues() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
 
forceReturnValues(boolean) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
 
forceReturnValues(boolean) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
 
forceReturnValues(boolean) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
Whether or not to implicitly FORCE_RETURN_VALUE for all calls.
forceReturnValues(boolean) - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfigurationBuilder
Whether or not to implicitly FORCE_RETURN_VALUE for all calls to this cache.
forceReturnValues(boolean) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
forceReturnValues(boolean) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
forceReturnValues(boolean) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
Whether or not to implicitly FORCE_RETURN_VALUE for all calls.
forceRollback(int, byte[], byte[]) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
forceRollback(long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
forceTransactionCompletion(XidImpl, boolean) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Replays the given transaction by re-running the prepare and commit.
forceTransactionCompletion(XidImpl, boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
forceTransactionCompletionFromCluster(XidImpl, Address, boolean) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
This method invokes RecoveryManager.forceTransactionCompletion(XidImpl, boolean) on the specified node.
forceTransactionCompletionFromCluster(XidImpl, Address, boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
forEach(BiConsumer<? super K, ? super V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
forEach(BiConsumer<? super K, ? super V>) - Method in class org.infinispan.cache.impl.EncoderCache
 
forEach(BiConsumer<? super K, ? super V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
forEach(BiConsumer<? super K, ? super V>) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
 
forEach(BiConsumer<String, String>) - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
 
forEach(BiConsumer<String, String>) - Method in interface org.infinispan.globalstate.ScopedPersistentState
Performs the specified action on every entry of the state
forEach(BiConsumer<Cache<K, V>, ? super CacheEntry<K, V>>) - Method in interface org.infinispan.LockedStream
Performs an action for each element of this stream on the primary owner of the given key.
forEach(BiConsumer<Cache<K, V>, ? super CacheEntry<K, V>>) - Method in class org.infinispan.stream.impl.LockedStreamImpl
 
forEach(BiConsumer<Cache<K, V>, ? super CacheEntry<K, V>>) - Method in class org.infinispan.stream.impl.TxLockedStreamImpl
 
forEach(BiConsumer<Cache<K, V>, ? super R>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.forEach(Consumer) except that it takes a BiConsumer that provides access to the underlying Cache that is backing this stream.
forEach(BiConsumer<Cache<K, V>, ? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
forEach(BiConsumer<Cache<K, V>, ? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
forEach(BiConsumer<Cache<K, V>, ? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
forEach(BiConsumer<ByteString, TopologyIracVersion>) - Method in class org.infinispan.container.versioning.irac.IracEntryVersion
Iterates over all entries of this version as pairs (site name, site version).
forEach(Consumer<? super E>) - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
 
forEach(Consumer<? super E>) - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
 
forEach(Consumer<? super E>) - Method in class org.infinispan.commons.util.ImmutableHopscotchHashSet
 
forEach(Consumer<? super E>) - Method in class org.infinispan.InternalCacheSet
 
forEach(Consumer<? super Integer>) - Method in class org.infinispan.commons.util.ImmutableIntSet
Deprecated.
 
forEach(Consumer<? super Integer>) - Method in class org.infinispan.commons.util.RangeSet
Deprecated.
 
forEach(Consumer<? super Integer>) - Method in class org.infinispan.commons.util.SmallIntSet
Deprecated.
 
forEach(Consumer<? super InternalCacheEntry<K, V>>) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
forEach(Consumer<? super R>) - Method in interface org.infinispan.CacheStream
forEach(Consumer<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
forEach(Consumer<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
forEach(Consumer<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
forEach(Consumer<? super R>) - Method in class org.infinispan.util.CollectionMapper
 
forEach(Consumer<? super T>) - Method in interface org.infinispan.functional.Traversable
A terminal operation that applies an operation to all elements of this traversable.
forEach(Consumer<Request<?>>) - Method in class org.infinispan.remoting.transport.impl.RequestRepository
 
forEach(DoubleConsumer) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
forEach(DoubleConsumer) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
forEach(IntConsumer) - Method in class org.infinispan.commons.util.ImmutableIntSet
Deprecated.
 
forEach(IntConsumer) - Method in interface org.infinispan.commons.util.IntSet
Performs the given action for each int of the IntSet until all elements have been processed or the action throws an exception.
forEach(IntConsumer) - Method in class org.infinispan.commons.util.RangeSet
Deprecated.
 
forEach(IntConsumer) - Method in class org.infinispan.commons.util.SmallIntSet
Deprecated.
 
forEach(IntConsumer) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
forEach(IntConsumer) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
forEach(LongConsumer) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
forEach(LongConsumer) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
forEach(ObjDoubleConsumer<Cache<K, V>>) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleStream.forEach(DoubleConsumer) except that it takes an ObjDoubleConsumer that provides access to the underlying Cache that is backing this stream.
forEach(ObjDoubleConsumer<Cache<K, V>>) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
forEach(ObjDoubleConsumer<Cache<K, V>>) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
forEach(ObjIntConsumer<? super AdvancedLoadWriteStore>) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
Method that allows user to directly invoke some method(s) on the underlying store.
forEach(ObjIntConsumer<Cache<K, V>>) - Method in interface org.infinispan.IntCacheStream
Same as IntStream.forEach(IntConsumer) except that it takes an ObjIntConsumer that provides access to the underlying Cache that is backing this stream.
forEach(ObjIntConsumer<Cache<K, V>>) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
forEach(ObjIntConsumer<Cache<K, V>>) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
forEach(ObjLongConsumer<Cache<K, V>>) - Method in interface org.infinispan.LongCacheStream
Same as LongStream.forEach(LongConsumer) except that it takes an ObjLongConsumer that provides access to the underlying Cache that is backing this stream.
forEach(ObjLongConsumer<Cache<K, V>>) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
forEach(ObjLongConsumer<Cache<K, V>>) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
forEach(IntSet, Consumer<? super InternalCacheEntry<K, V>>) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
forEach(IntSet, Consumer<? super InternalCacheEntry<K, V>>) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
forEach(IntSet, Consumer<? super InternalCacheEntry<K, V>>) - Method in interface org.infinispan.container.impl.InternalDataContainer
Performs the given action for each element of the container that maps to the given set of segments until all elements have been processed or the action throws an exception.
forEach(SerializableBiConsumer<Cache<K, V>, ? super CacheEntry<K, V>>) - Method in interface org.infinispan.LockedStream
Same as LockedStream.forEach(BiConsumer) except that the BiConsumer must also implement Serializable
forEach(SerializableBiConsumer<Cache<K, V>, ? super R>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.forEach(BiConsumer) except that the BiConsumer must also implement Serializable
forEach(SerializableConsumer<? super R>) - Method in interface org.infinispan.CacheStream
Same as CacheStream.forEach(Consumer) except that the Consumer must also implement Serializable
forEach(SerializableDoubleConsumer) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleStream.forEach(DoubleConsumer) except that the DoubleConsumer must also implement Serializable
forEach(SerializableDoubleConsumer) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
forEach(SerializableIntConsumer) - Method in interface org.infinispan.IntCacheStream
Same as IntStream.forEach(IntConsumer) except that the IntConsumer must also implement Serializable
forEach(SerializableIntConsumer) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
forEach(SerializableLongConsumer) - Method in interface org.infinispan.LongCacheStream
Same as LongStream.forEach(LongConsumer) except that the LongConsumer must also implement Serializable.
forEach(SerializableLongConsumer) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
forEach(SerializableObjDoubleConsumer<Cache<K, V>>) - Method in interface org.infinispan.DoubleCacheStream
Same as DoubleCacheStream.forEach(ObjDoubleConsumer) except that the BiConsumer must also implement Serializable
forEach(SerializableObjDoubleConsumer<Cache<K, V>>) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
forEach(SerializableObjIntConsumer<Cache<K, V>>) - Method in interface org.infinispan.IntCacheStream
Same as IntCacheStream.forEach(ObjIntConsumer) except that the BiConsumer must also implement Serializable
forEach(SerializableObjIntConsumer<Cache<K, V>>) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
forEach(SerializableObjLongConsumer<Cache<K, V>>) - Method in interface org.infinispan.LongCacheStream
Same as LongCacheStream.forEach(ObjLongConsumer) except that the BiConsumer must also implement Serializable
forEach(SerializableObjLongConsumer<Cache<K, V>>) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
forEach(T[], Consumer<T>) - Static method in class org.infinispan.commons.util.InfinispanCollections
 
forEachBackupLock(Consumer<Object>) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
forEachBackupLock(Consumer<Object>) - Method in interface org.infinispan.transaction.xa.CacheTransaction
Invokes the Consumer with each backup lock.
forEachCache(BiConsumer<WrappedBytes, CacheInfo>) - Method in class org.infinispan.client.hotrod.impl.TopologyInfo
 
forEachEntry(BiConsumer<Object, CacheEntry>) - Method in interface org.infinispan.context.EntryLookup
Execute an action for each entry in the context.
forEachEntry(BiConsumer<Object, CacheEntry>) - Method in class org.infinispan.context.impl.ImmutableContext
 
forEachEntry(BiConsumer<Object, CacheEntry>) - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
forEachEntry(BiConsumer<Object, CacheEntry>) - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
 
forEachLock(Consumer<Object>) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
forEachLock(Consumer<Object>) - Method in interface org.infinispan.transaction.xa.CacheTransaction
Invokes the Consumer with each lock.
forEachOrdered(Consumer<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
forEachOrdered(Consumer<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
 
forEachOrdered(Consumer<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
 
forEachOrdered(DoubleConsumer) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
forEachOrdered(DoubleConsumer) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
 
forEachOrdered(IntConsumer) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
forEachOrdered(IntConsumer) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
 
forEachOrdered(LongConsumer) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
forEachOrdered(LongConsumer) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
 
forEachRemaining(Consumer<? super E>) - Method in class org.infinispan.commons.util.AbstractIterator
 
forEachRemaining(Consumer<? super E>) - Method in class org.infinispan.commons.util.FlattenSpliterator
 
forEachRemaining(Consumer<? super E>) - Method in class org.infinispan.commons.util.Immutables.ImmutableIteratorWrapper
 
forEachRemaining(Consumer<? super E>) - Method in class org.infinispan.util.CloseableSuppliedIterator
 
forEachRemaining(Consumer<? super S>) - Method in class org.infinispan.commons.util.SpliteratorMapper
 
forEachRemaining(Consumer<? super T>) - Method in class org.infinispan.commons.util.FilterSpliterator
 
forEachSegment(ObjIntConsumer<PeekableTouchableMap<K, V>>) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
forEachSegment(ObjIntConsumer<PeekableTouchableMap<K, V>>) - Method in class org.infinispan.container.impl.DefaultDataContainer
 
forEachSegment(ObjIntConsumer<PeekableTouchableMap<K, V>>) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
forEachSegment(ObjIntConsumer<PeekableTouchableMap<K, V>>) - Method in interface org.infinispan.container.impl.InternalDataContainer
Performs the given consumer for each map inside this container, once for each segment until all maps have been processed or the action throws an exception.
forEachSegment(ObjIntConsumer<PeekableTouchableMap<WrappedBytes, WrappedBytes>>) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
forEachValue(BiConsumer<Object, CacheEntry>) - Method in interface org.infinispan.context.EntryLookup
Execute an action for each value in the context.
forEachValue(BiConsumer<Object, CacheEntry>) - Method in class org.infinispan.context.impl.ImmutableContext
 
forEachValue(BiConsumer<Object, CacheEntry>) - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
 
forElement(String) - Static method in enum org.infinispan.configuration.cache.StorageType
 
forget(int, byte[], byte[]) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
forget(long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
 
forget(Xid) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
FORGET_TX - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
FORGET_TX - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
forgetTransaction(XidImpl) - Method in class org.infinispan.server.hotrod.tx.table.GlobalTxTable
 
format() - Method in interface org.infinispan.filter.KeyValueFilter
 
format() - Method in interface org.infinispan.notifications.cachelistener.filter.CacheEventConverter
 
format() - Method in interface org.infinispan.notifications.cachelistener.filter.CacheEventFilter
 
format() - Method in interface org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverter
 
format() - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter
 
format() - Method in class org.infinispan.persistence.remote.upgrade.RemovedFilter
 
format(Thread, String) - Method in class org.infinispan.factories.threads.ThreadNameInfo
Format the thread name string.
format(Configuration) - Method in class org.infinispan.configuration.format.PropertyFormatter
 
format(GlobalConfiguration) - Method in class org.infinispan.configuration.format.PropertyFormatter
 
format(CounterConfiguration) - Method in class org.infinispan.counter.api.PropertyFormatter
 
FORMAT_MESSAGE - Static variable in exception class org.infinispan.counter.exception.CounterOutOfBoundsException
 
formatLocation(DecimalFormat, TopologyInfo.Location, String) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
formatString(Object, Object...) - Static method in class org.infinispan.commons.util.Util
 
forName(String) - Static method in enum org.infinispan.configuration.parsing.Attribute
 
forName(String) - Static method in enum org.infinispan.configuration.parsing.Element
 
forName(String) - Static method in enum org.infinispan.counter.configuration.Attribute
 
forName(String) - Static method in enum org.infinispan.counter.configuration.Element
 
forName(String) - Static method in enum org.infinispan.lock.configuration.Attribute
 
forName(String) - Static method in enum org.infinispan.lock.configuration.Element
 
forName(String) - Static method in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
 
forName(String) - Static method in enum org.infinispan.persistence.jdbc.common.configuration.Element
 
forName(String) - Static method in enum org.infinispan.persistence.remote.configuration.Attribute
 
forName(String) - Static method in enum org.infinispan.persistence.remote.configuration.Element
 
forName(String) - Static method in enum org.infinispan.persistence.rocksdb.configuration.Attribute
 
forName(String) - Static method in enum org.infinispan.persistence.rocksdb.configuration.Element
 
forName(String) - Static method in enum org.infinispan.server.hotrod.configuration.Attribute
 
forName(String) - Static method in enum org.infinispan.server.hotrod.configuration.Element
 
forVersion(byte) - Static method in enum org.infinispan.server.hotrod.HotRodVersion
 
FORWARD_COMMIT - Static variable in interface org.infinispan.server.hotrod.command.Ids
 
FORWARD_ROLLBACK - Static variable in interface org.infinispan.server.hotrod.command.Ids
 
FORWARD_SECRECY - Enum constant in enum org.infinispan.server.hotrod.configuration.Element
 
FORWARD_SECRECY - Enum constant in enum org.infinispan.server.hotrod.configuration.Policy
 
ForwardCommitCommand - Class in org.infinispan.server.hotrod.command.tx
A CacheRpcCommand implementation to forward the commit request from a client to the member that run the transaction.
ForwardCommitCommand(ByteString) - Constructor for class org.infinispan.server.hotrod.command.tx.ForwardCommitCommand
 
ForwardCommitCommand(ByteString, XidImpl, long) - Constructor for class org.infinispan.server.hotrod.command.tx.ForwardCommitCommand
 
ForwardingCacheEntry<K,V> - Class in org.infinispan.container.entries
A class designed to forward all method invocations for a CacheEntry to the provided delegate.
ForwardingCacheEntry() - Constructor for class org.infinispan.container.entries.ForwardingCacheEntry
 
ForwardingList<E> - Class in org.infinispan.commons.util
A list which forwards all its method calls to another list.
ForwardingList() - Constructor for class org.infinispan.commons.util.ForwardingList
Constructor for use by subclasses.
ForwardRollbackCommand - Class in org.infinispan.server.hotrod.command.tx
A CacheRpcCommand implementation to forward the rollback request from a client to the member that run the transaction.
ForwardRollbackCommand(ByteString) - Constructor for class org.infinispan.server.hotrod.command.tx.ForwardRollbackCommand
 
ForwardRollbackCommand(ByteString, XidImpl, long) - Constructor for class org.infinispan.server.hotrod.command.tx.ForwardRollbackCommand
 
FOUND - Enum constant in enum org.infinispan.rest.framework.LookupResult.Status
A resource was found to handle the request
FRAGMENTATION_FACTOR - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
FRAGMENTATION_FACTOR - Static variable in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
 
fragmentationFactor() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
 
fragmentationFactor(float) - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
The store tries to fit in a new entry into an existing entry from a free entry pool (if one is available) However, this existing free entry may be quite bigger than what is required to contain the new entry It may then make sense to split the free entry into two parts: 1.
freeze() - Method in class org.infinispan.transaction.impl.ModificationList
Freezes this list.
freeze() - Method in interface org.infinispan.util.concurrent.AggregateCompletionStage
Marks this composed stage as frozen, allowing it to complete when all stages it depends on complete
freeze() - Method in class org.infinispan.util.concurrent.CountDownRunnable
 
freeze() - Method in class org.infinispan.xsite.irac.IracClearResponseCollector
 
freeze() - Method in class org.infinispan.xsite.irac.IracResponseCollector
 
freezeModifications() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
freezeModifications() - Method in interface org.infinispan.transaction.xa.CacheTransaction
Prevent new modifications after prepare or commit started.
friendlyCacheModeString() - Method in enum org.infinispan.configuration.cache.CacheMode
 
from(byte[]) - Static method in class org.infinispan.commons.util.IntSets
 
from(byte[]) - Static method in class org.infinispan.commons.util.SmallIntSet
Deprecated.
 
from(int) - Static method in enum org.infinispan.persistence.sql.AbstractSchemaJdbcStore.ProtostreamFieldType
 
from(InputStream) - Static method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
from(InputStream) - Static method in class org.infinispan.commons.util.Version
 
from(Reader) - Static method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
from(Class<?>) - Method in interface org.infinispan.query.dsl.QueryFactory
Deprecated.
since 10.1. See deprecation note on QueryBuilder.
from(String) - Static method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
from(String) - Method in interface org.infinispan.query.dsl.QueryFactory
Deprecated.
since 10.1. See deprecation note on QueryBuilder.
from(PrimitiveIterator.OfInt) - Static method in class org.infinispan.commons.util.IntSets
Returns an IntSet based on the ints in the iterator.
from(Properties) - Method in class org.infinispan.counter.api.PropertyFormatter
 
from(Set<Integer>) - Static method in class org.infinispan.commons.util.IntSets
Returns an IntSet based on the provided Set.
from(Set<Integer>) - Static method in class org.infinispan.commons.util.SmallIntSet
Deprecated.
Either converts the given set to an IntSet if it is one or creates a new IntSet and copies the contents
from(DataFormat) - Method in class org.infinispan.client.hotrod.DataFormat.Builder
 
from(RemoteCacheManager) - Static method in class org.infinispan.client.hotrod.multimap.RemoteMultimapCacheManagerFactory
 
from(MetaParams) - Static method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
 
from(Param<?>...) - Static method in class org.infinispan.functional.impl.Params
 
from(EmbeddedCacheManager) - Static method in class org.infinispan.lock.EmbeddedClusteredLockManagerFactory
 
from(EmbeddedCacheManager) - Static method in class org.infinispan.multimap.api.embedded.EmbeddedMultimapCacheManagerFactory
 
fromBackupConfiguration(BackupConfiguration) - Static method in class org.infinispan.xsite.irac.IracXSiteBackup
 
fromBackupConfiguration(BackupConfiguration) - Static method in interface org.infinispan.xsite.statetransfer.XSiteStateProviderState
Factory for XSiteStateProviderState instances.
fromCacheLoader(MarshallableEntry<?, ?>) - Static method in class org.infinispan.xsite.statetransfer.XSiteState
 
fromCode(byte) - Static method in enum org.infinispan.server.hotrod.OperationStatus
 
fromCollection(Collection<WriteCommand>) - Static method in class org.infinispan.transaction.impl.ModificationList
 
fromConfiguration(BackupConfiguration) - Static method in class org.infinispan.xsite.statetransfer.RemoteSiteStatus
 
fromConfiguration(TransactionConfiguration, boolean) - Static method in enum org.infinispan.configuration.parsing.CacheParser.TransactionMode
 
fromConfiguration(EntryMergePolicy) - Static method in enum org.infinispan.conflict.MergePolicy
 
fromDatabaseType(DatabaseType, String) - Static method in interface org.infinispan.persistence.jdbc.common.SqlManager
 
fromDatabaseType(DatabaseType, String, boolean) - Static method in interface org.infinispan.persistence.jdbc.common.SqlManager
 
fromDataContainer(InternalCacheEntry<?, ?>) - Static method in class org.infinispan.xsite.statetransfer.XSiteState
 
fromDocumentIdentifier(String, IdentifierBridgeFromDocumentIdentifierContext) - Method in class org.infinispan.query.impl.KeyTransformationHandlerIdentifierBridge
 
fromDocumentReference(DocumentReference) - Method in class org.infinispan.search.mapper.session.impl.InfinispanSearchSession
 
fromEvent(CacheEntryEvent<K, V>) - Static method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
fromExtension(String) - Static method in class org.infinispan.commons.dataconversion.MediaType
 
fromFlagsBitSet(long) - Static method in class org.infinispan.functional.impl.Params
 
fromId(byte) - Static method in class org.infinispan.xsite.commands.remote.Ids
 
fromInstance(XSiteEntryMergePolicy<K, V>) - Static method in enum org.infinispan.xsite.spi.XSiteMergePolicy
 
fromJGroupsAddress(Address) - Static method in class org.infinispan.remoting.transport.jgroups.JGroupsAddressCache
 
fromJson(String) - Static method in class org.infinispan.persistence.remote.upgrade.SerializationUtils
 
fromJson(String) - Static method in class org.infinispan.query.remote.json.JsonQueryRequest
 
fromMediaType(String) - Static method in class org.infinispan.rest.operations.mediatypes.Charset
Creates Charset based on MediaType as string.
fromMemory(long) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
Create an entry from the off-heap pointer
fromMemory(long) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
Assumes the address doesn't contain the linked pointer at the beginning
fromMultipleRuntimeExceptions(List<RuntimeException>) - Static method in exception class org.infinispan.commons.CacheConfigurationException
 
fromNamespaceURI(String) - Static method in class org.infinispan.configuration.parsing.Schema
 
fromNewTypeFunction - Variable in class org.infinispan.util.WriteableCacheCollectionMapper
 
fromPersistentState(ScopedPersistentState) - Method in interface org.infinispan.distribution.ch.ConsistentHashFactory
Deprecated.
Recreates a ConsistentHash from a previously stored persistent state.
fromPersistentState(ScopedPersistentState) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
 
fromPersistentState(ScopedPersistentState) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory
 
fromPersistentState(ScopedPersistentState) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory
 
fromPersistentState(ScopedPersistentState) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory
 
fromPersistentState(ScopedPersistentState) - Method in class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory
 
fromProperties(TypedProperties, String) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
 
fromRequestOpCode(byte) - Static method in enum org.infinispan.server.hotrod.HotRodOperation
 
fromResponseOpCode(byte) - Static method in enum org.infinispan.server.hotrod.HotRodOperation
 
fromStorage(Object) - Method in interface org.infinispan.commons.dataconversion.Encoder
Deprecated.
Convert from storage format to the read/write format.
fromStorage(Object) - Method in class org.infinispan.commons.dataconversion.IdentityEncoder
Deprecated.
 
fromStorage(Object) - Method in class org.infinispan.commons.dataconversion.MarshallerEncoder
Deprecated.
 
fromStorage(Object) - Method in class org.infinispan.commons.dataconversion.UTF8Encoder
Deprecated.
 
fromStorage(Object) - Method in class org.infinispan.encoding.DataConversion
 
fromStorage(Object, Encoder, Wrapper) - Static method in class org.infinispan.commons.dataconversion.EncodingUtils
Deprecated.
Decode object from storage format.
fromStream(byte, byte) - Method in class org.infinispan.commands.RemoteCommandsFactory
Creates an un-initialized command.
fromStream(byte, byte, ByteString) - Method in class org.infinispan.commands.RemoteCommandsFactory
Resolve an CacheRpcCommand from the stream.
fromStream(byte, byte, ByteString) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
fromString(Class, String) - Static method in class org.infinispan.commons.util.Util
 
fromString(String) - Static method in enum org.infinispan.commons.api.CacheContainerAdmin.AdminFlag
 
fromString(String) - Method in class org.infinispan.commons.configuration.attributes.Attribute
 
fromString(String) - Static method in class org.infinispan.commons.dataconversion.MediaType
 
fromString(String) - Static method in interface org.infinispan.commons.maven.Artifact
 
fromString(String) - Static method in class org.infinispan.commons.maven.MavenArtifact
Parse a string and produce artifact coordinates from it.
fromString(String) - Static method in enum org.infinispan.conflict.MergePolicy
 
fromString(String) - Static method in class org.infinispan.container.versioning.irac.TopologyIracVersion
 
fromString(String) - Method in class org.infinispan.query.impl.DefaultTransformer
 
fromString(String) - Method in interface org.infinispan.query.Transformer
Transforms a String into an Object.
fromString(String) - Static method in enum org.infinispan.server.core.BackupManager.Resources.Type
 
fromString(String) - Static method in enum org.infinispan.server.hotrod.configuration.Policy
 
fromString(String) - Static method in enum org.infinispan.server.hotrod.configuration.QOP
 
fromString(String) - Static method in enum org.infinispan.server.hotrod.configuration.Strength
 
fromString(String) - Static method in class org.infinispan.topology.PersistentUUID
 
fromString(String) - Static method in class org.infinispan.util.ByteString
 
fromString(String) - Static method in enum org.infinispan.xsite.spi.XSiteMergePolicy
 
fromTimeUnit(TimeUnit) - Static method in enum org.infinispan.server.hotrod.TimeUnitValue
 
FULL - Enum constant in enum org.infinispan.rest.ResponseWriter
 
FULL_XA - Enum constant in enum org.infinispan.client.hotrod.configuration.TransactionMode
The cache is enlisted asXAResource with recovery support.
FULL_XA - Enum constant in enum org.infinispan.configuration.cache.TransactionMode
 
FULL_XA - Enum constant in enum org.infinispan.configuration.parsing.CacheParser.TransactionMode
 
function(Converter<? super K, ? super V, C>) - Static method in class org.infinispan.filter.CacheFilters
Creates a new Function using the provided converter as a basis for the operation.
FUNCTION_MAPPER - Static variable in interface org.infinispan.commons.marshall.Ids
 
FunctionalMap<K,V> - Interface in org.infinispan.functional
Top level functional map interface offering common functionality for the read-only, read-write, and write-only operations that can be run against a functional map asynchronously.
FunctionalMap.ReadOnlyMap<K,V> - Interface in org.infinispan.functional
Exposes read-only operations that can be executed against the functional map.
FunctionalMap.ReadWriteMap<K,V> - Interface in org.infinispan.functional
Exposes read-write operations that can be executed against the functional map.
FunctionalMap.WriteOnlyMap<K,V> - Interface in org.infinispan.functional
Exposes write-only operations that can be executed against the functional map.
FunctionalMapImpl<K,V> - Class in org.infinispan.functional.impl
Functional map implementation.
FunctionalNotifier<K,V> - Interface in org.infinispan.functional.impl
Listener notifier.
FunctionalNotifierImpl<K,V> - Class in org.infinispan.functional.impl
 
FunctionalNotifierImpl() - Constructor for class org.infinispan.functional.impl.FunctionalNotifierImpl
 
FunctionMapper - Class in org.infinispan.cache.impl
 
FunctionMapper(Function, DataConversion, DataConversion) - Constructor for class org.infinispan.cache.impl.FunctionMapper
 
FunctionMapper.Externalizer - Class in org.infinispan.cache.impl
 
FunctionTimerMetricInfo<T> - Class in org.infinispan.commons.stat
Represents a duration metric.
FunctionTimerMetricInfo(String, String, Map<String, String>, BiConsumer<T, TimerTracker>) - Constructor for class org.infinispan.commons.stat.FunctionTimerMetricInfo
 

G

GATHER - Enum constant in enum org.infinispan.functional.Param.StatisticsMode
Statistics from this command are recorded
GaugeMetricInfo<T> - Class in org.infinispan.commons.stat
Represents a gauge metric.
GaugeMetricInfo(String, String, Map<String, String>, Function<T, Number>) - Constructor for class org.infinispan.commons.stat.GaugeMetricInfo
 
gauges() - Method in class org.infinispan.configuration.global.GlobalMetricsConfiguration
Are gauges enabled?
gauges() - Method in class org.infinispan.configuration.global.GlobalMetricsConfigurationBuilder
Are gauges enabled?
gauges(boolean) - Method in class org.infinispan.configuration.global.GlobalMetricsConfigurationBuilder
Enables or disables gauges.
GAUGES - Enum constant in enum org.infinispan.configuration.parsing.Attribute
 
GAUGES - Static variable in class org.infinispan.configuration.global.GlobalMetricsConfiguration
 
generateAddress() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
generateAddress(String) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
generateId(Address) - Static method in class org.infinispan.commands.CommandInvocationId
 
generateIdFrom(CommandInvocationId) - Static method in class org.infinispan.commands.CommandInvocationId
 
generateMetadataWithCurrentVersion(int) - Method in class org.infinispan.container.versioning.irac.DefaultIracVersionGenerator
 
generateMetadataWithCurrentVersion(int) - Method in interface org.infinispan.container.versioning.irac.IracVersionGenerator
Generate a new IracMetadata for a given segment.
generateMetadataWithCurrentVersion(int) - Method in class org.infinispan.container.versioning.irac.NoOpIracVersionGenerator
 
generateNew() - Method in class org.infinispan.container.versioning.NumericVersionGenerator
 
generateNew() - Method in class org.infinispan.container.versioning.SimpleClusteredVersionGenerator
 
generateNew() - Method in interface org.infinispan.container.versioning.VersionGenerator
Generates a new entry version
generateNewMetadata(int) - Method in class org.infinispan.container.versioning.irac.DefaultIracVersionGenerator
 
generateNewMetadata(int) - Method in interface org.infinispan.container.versioning.irac.IracVersionGenerator
Generates a new IracMetadata for a given segment.
generateNewMetadata(int) - Method in class org.infinispan.container.versioning.irac.NoOpIracVersionGenerator
 
generateNewMetadata(int, IracEntryVersion) - Method in class org.infinispan.container.versioning.irac.DefaultIracVersionGenerator
 
generateNewMetadata(int, IracEntryVersion) - Method in interface org.infinispan.container.versioning.irac.IracVersionGenerator
Same as IracVersionGenerator.generateNewMetadata(int) but it makes sure the new version is higher than versionSeen.
generateNewMetadata(int, IracEntryVersion) - Method in class org.infinispan.container.versioning.irac.NoOpIracVersionGenerator
 
GENERIC_JBOSS_MARSHALLING_CLASS - Static variable in class org.infinispan.commons.util.Util
 
GENERIC_MARSHALLER - Static variable in interface org.infinispan.commons.dataconversion.EncoderIds
Deprecated, for removal: This API element is subject to removal in a future version.
Since 11.0, will be removed in 14.0. Set the storage media type and use transcoding instead.
GenericJBossMarshaller - Class in org.infinispan.jboss.marshalling.commons
A marshaller that makes use of JBoss Marshalling to serialize and deserialize objects.
GenericJBossMarshaller() - Constructor for class org.infinispan.jboss.marshalling.commons.GenericJBossMarshaller
 
GenericJBossMarshaller(ClassLoader) - Constructor for class org.infinispan.jboss.marshalling.commons.GenericJBossMarshaller
 
GenericJBossMarshaller(ClassLoader, ClassAllowList) - Constructor for class org.infinispan.jboss.marshalling.commons.GenericJBossMarshaller
 
GenericJBossMarshaller(ClassAllowList) - Constructor for class org.infinispan.jboss.marshalling.commons.GenericJBossMarshaller
 
GenericJbossMarshallerEncoder - Class in org.infinispan.jboss.marshalling.dataconversion
Deprecated, for removal: This API element is subject to removal in a future version.
Since 11.0, will be removed in 14.0. Set the storage media type and use transcoding instead.
GenericJbossMarshallerEncoder(ClassLoader) - Constructor for class org.infinispan.jboss.marshalling.dataconversion.GenericJbossMarshallerEncoder
Deprecated.
 
GenericJbossMarshallerEncoder(GenericJBossMarshaller) - Constructor for class org.infinispan.jboss.marshalling.dataconversion.GenericJbossMarshallerEncoder
Deprecated.
 
GenericTransactionManagerLookup - Class in org.infinispan.client.hotrod.transaction.lookup
A TransactionManagerLookup implementation that attempts to locate a TransactionManager.
GenericTransactionManagerLookup - Class in org.infinispan.transaction.lookup
A transaction manager lookup class that attempts to locate a TransactionManager.
GenericTransactionManagerLookup() - Constructor for class org.infinispan.transaction.lookup.GenericTransactionManagerLookup
 
genericTypeModel(Class<T>) - Method in class org.infinispan.search.mapper.model.impl.InfinispanBootstrapIntrospector
 
get() - Method in class org.infinispan.commons.configuration.attributes.Attribute
 
get() - Method in class org.infinispan.commons.util.ArrayCollector
 
get() - Method in class org.infinispan.commons.util.ByRef.Boolean
 
get() - Method in class org.infinispan.commons.util.ByRef
 
get() - Method in class org.infinispan.commons.util.ByRef.Integer
 
get() - Method in class org.infinispan.commons.util.ByRef.Long
 
get() - Method in class org.infinispan.commons.util.InstanceSupplier
 
get() - Method in interface org.infinispan.commons.util.WeakValueHashMap.ValueRef
Get underlying value.
get() - Method in interface org.infinispan.functional.EntryView.ReadEntryView
Returns a non-null value if the key has a value associated with it or throws NoSuchElementException if no value is associated with the entry.
get() - Method in class org.infinispan.functional.impl.CounterConfigurationMetaParam
 
get() - Method in interface org.infinispan.functional.MetaParam
Returns the value of the meta parameter.
get() - Method in class org.infinispan.functional.MetaParam.MetaBoolean
 
get() - Method in class org.infinispan.functional.MetaParam.MetaEntryVersion
 
get() - Method in class org.infinispan.functional.MetaParam.MetaLong
 
get() - Method in enum org.infinispan.functional.Param.ExecutionMode
 
get() - Method in interface org.infinispan.functional.Param
Parameter's value.
get() - Method in enum org.infinispan.functional.Param.LockingMode
 
get() - Method in enum org.infinispan.functional.Param.PersistenceMode
 
get() - Method in enum org.infinispan.functional.Param.ReplicationMode
 
get() - Method in enum org.infinispan.functional.Param.StatisticsMode
 
get() - Method in class org.infinispan.interceptors.ExceptionSyncInvocationStage
 
get() - Method in class org.infinispan.interceptors.InvocationStage
Wait for the invocation to complete and return its value.
get() - Method in class org.infinispan.interceptors.SyncInvocationStage
 
get(int) - Method in class org.infinispan.commons.util.ForwardingList
 
get(int) - Method in class org.infinispan.commons.util.ImmutableListCopy
 
get(int) - Method in class org.infinispan.commons.util.ImmutableListCopy.ImmutableSubList
 
get(int) - Method in interface org.infinispan.commons.util.Util.ByteGetter
 
get(int) - Method in class org.infinispan.functional.impl.Params
Retrieve a param given its identifier.
get(int, Object) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
get(int, Object) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
get(int, Object) - Method in interface org.infinispan.container.impl.InternalDataContainer
Deprecated, for removal: This API element is subject to removal in a future version.
since 10.1
get(int, Object) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
get(int, Object) - Method in class org.infinispan.persistence.sifs.TemporaryTable
 
get(int, Object) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
Deprecated.
Fetches an entry from the storage given a segment to optimize this lookup based on.
get(int, Object) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
get(ByteBuf, Channel) - Method in class org.infinispan.server.memcached.MemcachedDecoder
 
get(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
get(Object) - Method in class org.infinispan.cache.impl.CacheImpl
 
get(Object) - Method in class org.infinispan.cache.impl.DecoratedCache
 
get(Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
get(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
get(Object) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
get(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
get(Object) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
 
get(Object) - Method in class org.infinispan.commons.util.ArrayMap
 
get(Object) - Method in class org.infinispan.commons.util.FastCopyHashMap
 
get(Object) - Method in class org.infinispan.commons.util.HopscotchHashMap
 
get(Object) - Method in class org.infinispan.commons.util.WeakValueHashMap
 
get(Object) - Method in interface org.infinispan.container.DataContainer
Deprecated, for removal: This API element is subject to removal in a future version.
since 10.1 - Please use DataContainer.peek(Object) instead.
get(Object) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
 
get(Object) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
get(Object) - Method in interface org.infinispan.container.impl.InternalDataContainer
Deprecated, for removal: This API element is subject to removal in a future version.
since 10.1
get(Object) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
get(Object) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
 
get(Object) - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
 
get(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
get(Object) - Method in class org.infinispan.spring.common.provider.SpringCache
 
get(Object, Class<T>) - Method in class org.infinispan.spring.common.provider.SpringCache
 
get(Object, Callable<T>) - Method in class org.infinispan.spring.common.provider.SpringCache
 
get(String) - Method in interface org.infinispan.client.hotrod.multimap.MultimapCacheManager
Retrieves a named multimap cache from the system.
get(String) - Method in interface org.infinispan.lock.api.ClusteredLockManager
Get’s a ClusteredLock by it’s name.
get(String) - Method in interface org.infinispan.multimap.api.embedded.MultimapCacheManager
Retrieves a named multimap cache from the system.
get(String, boolean) - Method in interface org.infinispan.client.hotrod.multimap.MultimapCacheManager
Retrieves a named multimap cache from the system.
get(String, boolean) - Method in class org.infinispan.client.hotrod.multimap.RemoteMultimapCacheManager
 
get(String, boolean) - Method in interface org.infinispan.multimap.api.embedded.MultimapCacheManager
Retrieves a named multimap cache from the system.
get(String, boolean) - Method in class org.infinispan.multimap.impl.EmbeddedMultimapCacheManager
 
get(String, Class<T>, boolean) - Method in class org.infinispan.factories.impl.WireContext
 
get(AtomicLongFieldUpdater<T>) - Method in class org.infinispan.commons.util.concurrent.StripedCounters
 
get(K) - Method in class org.infinispan.client.hotrod.impl.StreamingRemoteCacheImpl
 
get(K) - Method in interface org.infinispan.client.hotrod.near.NearCache
 
get(K) - Method in class org.infinispan.client.hotrod.near.NearCacheService
 
get(K) - Method in interface org.infinispan.client.hotrod.StreamingRemoteCache
Retrieves the value of the specified key as an InputStream.
get(K) - Method in interface org.infinispan.multimap.api.BasicMultimapCache
Returns a view collection of the values associated with key in this multimap cache, if any.
get(K) - Method in class org.infinispan.multimap.impl.EmbeddedMultimapCache
 
get(AdvancedCache<K, V>) - Static method in class org.infinispan.conflict.ConflictManagerFactory
 
GET - Enum constant in enum org.infinispan.rest.framework.Method
 
GET - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
GET_ALL - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
GET_ALL_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
GET_FUNCTION - Static variable in interface org.infinispan.multimap.impl.ExternalizerIds
 
GET_MULTIMAP - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
GET_MULTIMAP_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
GET_MULTIMAP_WITH_METADATA - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
GET_MULTIMAP_WITH_METADATA_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
GET_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
GET_STREAM - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
GET_STREAM_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
GET_WITH_METADATA - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
GET_WITH_METADATA - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
GET_WITH_VERSION - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
 
GET_WITH_VERSION - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
 
getAbortRate() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAbsoluteFile() - Method in class org.infinispan.io.GridFile
Deprecated.
 
getAbsolutePath() - Method in class org.infinispan.io.GridFile
Deprecated.
 
getAcceptHeader() - Method in interface org.infinispan.rest.framework.RestRequest
 
getAcceptHeader() - Method in class org.infinispan.rest.NettyRestRequest
 
getAccessibleCacheNames() - Method in class org.infinispan.manager.DefaultCacheManager
 
getAccessibleCacheNames() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Similar to BasicCacheContainer.getCacheNames() but filters out caches that are not accessible by the current user
getAccessibleCacheNames() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getACL(Subject) - Method in class org.infinispan.security.impl.Authorizer
 
getACL(Subject, AuthorizationConfiguration) - Method in class org.infinispan.security.impl.Authorizer
 
getAction() - Method in class org.infinispan.rest.framework.impl.InvocationImpl
 
getAction() - Method in interface org.infinispan.rest.framework.Invocation
Returns the associated action (request parameter) or null.
getAction() - Method in interface org.infinispan.rest.framework.RestRequest
 
getAction() - Method in class org.infinispan.rest.NettyRestRequest
 
getActions() - Method in class org.infinispan.security.CachePermission
 
getActivationCount() - Method in interface org.infinispan.eviction.impl.ActivationManager
Get number of activations executed.
getActivationCount() - Method in class org.infinispan.eviction.impl.ActivationManagerImpl
 
getActivationCount() - Method in class org.infinispan.eviction.impl.ActivationManagerStub
 
getActivations() - Method in class org.infinispan.eviction.impl.ActivationManagerImpl
 
getActivations() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getActivations() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getActiveConnectionCount() - Method in interface org.infinispan.client.hotrod.jmx.RemoteCacheManagerMXBean
Returns the number of active connections
getActiveConnectionCount() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
getActiveCount() - Method in class org.infinispan.executors.ManageableExecutorService
 
getActual() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticLockManager
 
getActual() - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
 
getActualMembers() - Method in class org.infinispan.topology.CacheTopology
 
getActualNumOwners() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
getActualStore() - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
 
getAddress() - Method in class org.infinispan.commands.CommandInvocationId
 
getAddress() - Method in class org.infinispan.container.entries.RemoteMetadata
 
getAddress() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticRpcManager
 
getAddress() - Method in class org.infinispan.manager.DefaultCacheManager
Warning: the address may be null before the first clustered cache starts and after all the clustered caches have been stopped.
getAddress() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Warning: the address may be null before the first clustered cache starts and after all the clustered caches have been stopped.
getAddress() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getAddress() - Method in interface org.infinispan.remoting.rpc.RpcManager
Returns the address associated with this RpcManager or null if not part of the cluster.
getAddress() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getAddress() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
getAddress() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getAddress() - Method in interface org.infinispan.remoting.transport.Transport
Retrieves the current cache instance's network address
getAddress() - Method in class org.infinispan.server.hotrod.HotRodServer
 
getAddress() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
getAddress(PersistentUUID) - Method in interface org.infinispan.topology.PersistentUUIDManager
Retrieves the Address of a node given its PersistentUUID
getAddress(PersistentUUID) - Method in class org.infinispan.topology.PersistentUUIDManagerImpl
 
getAddress2KeysMapping() - Method in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
 
getAddressCache() - Method in class org.infinispan.server.hotrod.HotRodServer
 
getAddresses() - Method in class org.infinispan.client.hotrod.impl.HotRodURI
 
getAdminFlags() - Method in interface org.infinispan.rest.framework.RestRequest
 
getAdminFlags() - Method in class org.infinispan.rest.NettyRestRequest
 
getAdvancedCache() - Method in interface org.infinispan.Cache
 
getAdvancedCache() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getAdvancedCache() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getAdvancedCache() - Method in class org.infinispan.cache.impl.CacheImpl
 
getAdvancedCache() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getAdvancedCache() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getAffectedKeys() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
getAffectedKeys() - Method in interface org.infinispan.context.impl.TxInvocationContext
Returns the set of keys that are affected by this transaction.
getAffectedKeys() - Method in class org.infinispan.persistence.support.BatchModification
 
getAffectedKeys() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getAffinitySegmentId() - Method in interface org.infinispan.distribution.ch.AffinityTaggedKey
This numeric id is used exclusively for storage affinity in Infinispan.
getAll(Set<?>) - Method in interface org.infinispan.AdvancedCache
Gets a collection of entries, returning them as Map of the values associated with the set of keys requested.
getAll(Set<?>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getAll(Set<?>) - Method in class org.infinispan.cache.impl.CacheImpl
 
getAll(Set<?>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
getAll(Set<?>) - Method in class org.infinispan.cache.impl.EncoderCache
 
getAll(Set<?>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getAll(Set<?>) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
getAll(Set<?>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getAll(Set<? extends K>) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
getAll(Set<? extends K>) - Method in interface org.infinispan.client.hotrod.RemoteCache
Retrieves all of the entries for the provided keys.
getAllAsync(Set<?>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getAllAsync(Set<?>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getAllAsync(Set<?>) - Method in class org.infinispan.cache.impl.CacheImpl
 
getAllAsync(Set<?>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
getAllAsync(Set<?>) - Method in class org.infinispan.cache.impl.EncoderCache
 
getAllAsync(Set<?>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getAllAsync(Set<?>) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
getAllAsync(Set<?>) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getAllAsync(Set<?>) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
getAllAsync(Set<?>) - Method in interface org.infinispan.commons.api.AsyncCache
TODO This should be in AdvancedCache with getAll
getAllAsync(Set<?>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getAllCacheEntries(Set<?>) - Method in interface org.infinispan.AdvancedCache
Gets a collection of entries from the AdvancedCache, returning them as Map of the cache entries associated with the set of keys requested.
getAllCacheEntries(Set<?>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getAllCacheEntries(Set<?>) - Method in class org.infinispan.cache.impl.CacheImpl
 
getAllCacheEntries(Set<?>) - Method in class org.infinispan.cache.impl.DecoratedCache
 
getAllCacheEntries(Set<?>) - Method in class org.infinispan.cache.impl.EncoderCache
 
getAllCacheEntries(Set<?>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getAllCacheEntries(Set<?>) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
getAllCacheEntries(Set<?>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getAllCacheEntries(Set<?>, long, InvocationContext) - Method in class org.infinispan.cache.impl.CacheImpl
 
getAllFields(Class<?>, Class<? extends Annotation>) - Static method in class org.infinispan.commons.util.ReflectionUtil
 
getAllMethods(Class<?>, Class<? extends Annotation>) - Static method in class org.infinispan.commons.util.ReflectionUtil
Returns a set of Methods that contain the given method annotation.
getAllMethodsShallow(Class<?>, Class<? extends Annotation>) - Static method in class org.infinispan.commons.util.ReflectionUtil
Returns a set of Methods that contain the given method annotation.
getAllModifications() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getAllModifications() - Method in class org.infinispan.transaction.impl.ModificationList
 
getAllModifications() - Method in interface org.infinispan.transaction.xa.CacheTransaction
Returns all the modifications visible within the current transaction, including those using Flag#CACHE_MODE_LOCAL.
getAllocatedAmount() - Method in interface org.infinispan.container.offheap.OffHeapMemoryAllocator
 
getAllocatedAmount() - Method in class org.infinispan.container.offheap.UnpooledOffHeapMemoryAllocator
 
getAllowedMethodAnnotations(Listener) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
getAllowedMethodAnnotations(Listener) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
getAllowedMethodAnnotations(Listener) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
 
getAllowedRole() - Method in interface org.infinispan.tasks.Task
An optional role, for which the task is accessible.
getAllResponse(HotRodHeader, HotRodServer, Channel, Map<byte[], byte[]>) - Method in class org.infinispan.server.hotrod.Encoder4x
 
getAllResponse(HotRodHeader, HotRodServer, Channel, Map<byte[], byte[]>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
 
getAllRoles() - Method in class org.infinispan.security.mappers.ClusterPermissionMapper
 
getAllRoles() - Method in interface org.infinispan.security.RolePermissionMapper
 
getAllServers() - Method in class org.infinispan.client.hotrod.impl.TopologyInfo
 
getAllSites() - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getAllVersions(K) - Method in interface org.infinispan.conflict.ConflictManager
Get all CacheEntry's that exists for a given key.
getAlpnConfiguration() - Method in class org.infinispan.rest.RestChannelInitializer
 
getAlpnConfiguration() - Method in class org.infinispan.server.core.transport.NettyChannelInitializer
 
getAnalyzer() - Method in class org.infinispan.search.mapper.mapping.metamodel.ValueFieldMetamodel
 
getAndAdd(long) - Method in class org.infinispan.commons.util.ByRef.Long
 
getAndPutAll(Map<? extends K, ? extends V>) - Method in interface org.infinispan.AdvancedCache
Executes an equivalent of Map.putAll(Map), returning previous values of the modified entries.
getAndPutAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getAndPutAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.CacheImpl
 
getAndPutAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.EncoderCache
 
getAndPutAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
getAndPutAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getAndPutInternal(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getAndPutInternal(K, V, Metadata) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
getAndReplaceInternal(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getAndReplaceInternal(K, V, Metadata) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
getAnnotatedFields(Class<?>, Class<? extends Annotation>) - Static method in class org.infinispan.commons.util.ReflectionUtil
 
getAnnotation() - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
 
getAnnotation() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
getAnnotation() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
getAnnotation(Class<?>, Class<T>) - Static method in class org.infinispan.commons.util.ReflectionUtil
Inspects the class passed in for the class level annotation specified.
getApproximateEntries() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getApproximateEntries() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getApproximateEntries() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getApproximateEntries() - Method in class org.infinispan.stats.impl.StatsCollector
 
getApproximateEntries() - Method in class org.infinispan.stats.impl.StatsImpl
 
getApproximateEntries() - Method in interface org.infinispan.stats.Stats
Returns the approximate number of entries in this cache that exist in memory or persistent storage.
getApproximateEntriesInMemory() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getApproximateEntriesInMemory() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getApproximateEntriesInMemory() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getApproximateEntriesInMemory() - Method in class org.infinispan.stats.impl.StatsCollector
 
getApproximateEntriesInMemory() - Method in class org.infinispan.stats.impl.StatsImpl
 
getApproximateEntriesInMemory() - Method in interface org.infinispan.stats.Stats
The same as Stats.getApproximateEntries(), however passivated entries are not included.
getApproximateEntriesUnique() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getApproximateEntriesUnique() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getApproximateEntriesUnique() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getApproximateEntriesUnique() - Method in class org.infinispan.stats.impl.StatsCollector
 
getApproximateEntriesUnique() - Method in class org.infinispan.stats.impl.StatsImpl
 
getApproximateEntriesUnique() - Method in interface org.infinispan.stats.Stats
The same as Stats.getApproximateEntries(), however only entries owned as primary are counted.
getArguments() - Method in class org.infinispan.commons.jdkspecific.ProcessInfo
 
getArgumentType() - Method in class org.infinispan.search.mapper.mapping.metamodel.ValueFieldMetamodel
 
getArray() - Method in class org.infinispan.commons.dataconversion.internal.JsonArrayCollector
 
getAsInputStreamFromClassLoader(String, ClassLoader) - Method in class org.infinispan.commons.util.AbstractFileLookup
 
getAsInputStreamFromClassLoader(String, ClassLoader) - Method in class org.infinispan.commons.util.FileLookupFactory.DefaultFileLookup
 
getAsURLFromClassLoader(String, ClassLoader) - Method in class org.infinispan.commons.util.AbstractFileLookup
 
getAsURLFromClassLoader(String, ClassLoader) - Method in class org.infinispan.commons.util.FileLookupFactory.DefaultFileLookup
 
getAsURLsFromClassLoader(String, ClassLoader) - Method in class org.infinispan.commons.util.AbstractFileLookup
 
getAsURLsFromClassLoader(String, ClassLoader) - Method in class org.infinispan.commons.util.FileLookupFactory.DefaultFileLookup
 
getAsync(Object) - Method in class org.infinispan.client.hotrod.impl.InvalidatedNearRemoteCache
 
getAsync(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getAsync(K) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getAsync(K) - Method in class org.infinispan.cache.impl.CacheImpl
 
getAsync(K) - Method in class org.infinispan.cache.impl.DecoratedCache
 
getAsync(K) - Method in class org.infinispan.cache.impl.EncoderCache
 
getAsync(K) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getAsync(K) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
getAsync(K) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
getAsync(K) - Method in interface org.infinispan.commons.api.AsyncCache
Asynchronous version of Map.get(Object) that allows user code to retrieve the value associated with a key at a later stage, hence allowing multiple parallel get requests to be sent.
getAsync(K) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getAsyncExecutorFactory() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getAsyncExecutorService() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
getAsyncInterceptorChain() - Method in interface org.infinispan.AdvancedCache
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, will be removed without a replacement
getAsyncInterceptorChain() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, will be removed without a replacement
getAsyncInterceptorChain() - Method in class org.infinispan.cache.impl.CacheImpl
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, will be removed without a replacement
getAsyncInterceptorChain() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, will be removed without a replacement
getAsyncInterceptorChain() - Method in class org.infinispan.security.impl.SecureCacheImpl
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, will be removed without a replacement
getAttribute(int) - Method in class org.infinispan.server.core.dataconversion.xml.MXParserReader
 
getAttribute(String) - Method in class org.infinispan.jmx.ResourceDMBean
 
getAttribute(String) - Method in class org.infinispan.server.core.dataconversion.xml.MXParserReader
 
getAttribute(String) - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository.InfinispanSession
 
getAttribute(ExtendedStatistic) - Method in class org.infinispan.extendedstats.CacheStatisticCollector
 
getAttribute(ExtendedStatistic) - Method in class org.infinispan.extendedstats.CacheStatisticManager
 
getAttribute(ExtendedStatistic) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAttributeCount() - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
getAttributeCount() - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationReader
 
getAttributeCount() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
getAttributeCount() - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationReader
 
getAttributeCount() - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returns the number of attributes of the current start tag, or -1 if the current event type is not START_TAG
getAttributeCount() - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader
 
getAttributeCount() - Method in class org.infinispan.server.core.dataconversion.xml.MXParserReader
 
getAttributeDefinition() - Method in class org.infinispan.commons.configuration.attributes.Attribute
 
getAttributeName(int) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationReader
 
getAttributeName(int) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
getAttributeName(int) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
getAttributeName(int) - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returns the local name of the specified attribute if namespaces are enabled or just attribute name if namespaces are disabled.
getAttributeName(int) - Method in class org.infinispan.server.core.dataconversion.xml.MXParserReader
 
getAttributeName(int, NamingStrategy) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
getAttributeName(int, NamingStrategy) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationReader
 
getAttributeName(int, NamingStrategy) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationReader
 
getAttributeName(int, NamingStrategy) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader
 
getAttributeNames() - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository.InfinispanSession
 
getAttributeNamespace(int) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
getAttributeNamespace(int) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationReader
 
getAttributeNamespace(int) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
getAttributeNamespace(int) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationReader
 
getAttributeNamespace(int) - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returns the namespace URI of the attribute with the given index (starts from 0).
getAttributeNamespace(int) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader
 
getAttributePrefix(int) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
getAttributePrefix(int) - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returns the prefix of the specified attribute Returns null if the element has no prefix.
getAttributes() - Method in class org.infinispan.factories.impl.MBeanMetadata
 
getAttributes(String[]) - Method in class org.infinispan.jmx.ResourceDMBean
 
getAttributeType(int) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
getAttributeType(int) - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returns the type of the specified attribute If parser is non-validating it MUST return CDATA.
getAttributeValue(int) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
getAttributeValue(int) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationReader
 
getAttributeValue(int) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
getAttributeValue(int) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationReader
 
getAttributeValue(int) - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returns the given attributes value.
getAttributeValue(int) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader
 
getAttributeValue(Enum<?>) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
getAttributeValue(Enum<?>, NamingStrategy) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
getAttributeValue(String) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationReader
 
getAttributeValue(String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
getAttributeValue(String, String) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
getAttributeValue(String, String) - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returns the attributes value identified by namespace URI and namespace localName.
getAttributeValue(String, NamingStrategy) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
getAttributeValue(String, NamingStrategy) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationReader
 
getAttributeValue(String, NamingStrategy) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationReader
 
getAttributeValue(String, NamingStrategy) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader
 
getAuthorizationHeader() - Method in interface org.infinispan.rest.framework.RestRequest
 
getAuthorizationHeader() - Method in class org.infinispan.rest.NettyRestRequest
 
getAuthorizationID() - Method in class org.infinispan.server.core.security.SubjectSaslServer
 
getAuthorizationManager() - Method in interface org.infinispan.AdvancedCache
Retrieves the AuthorizationManager if the cache has security enabled.
getAuthorizationManager() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getAuthorizationManager() - Method in class org.infinispan.cache.impl.CacheImpl
 
getAuthorizationManager() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getAuthorizationManager() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getAuthorizationPermission() - Method in class org.infinispan.security.CachePermission
 
getAuthPassword() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getAuthRealm() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getAuthToken() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getAuthUsername() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getAvailability() - Method in interface org.infinispan.AdvancedCache
Returns the cache's availability.
getAvailability() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getAvailability() - Method in class org.infinispan.cache.impl.CacheImpl
 
getAvailability() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getAvailability() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getAvailabilityMode() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getAvailabilityMode() - Method in interface org.infinispan.notifications.cachelistener.event.PartitionStatusChangedEvent
The mode the current cluster is in.
getAvailabilityMode() - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
 
getAvailabilityMode() - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
getAvailabilityMode() - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
 
getAvailabilityMode() - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
getAvailabilityMode() - Method in class org.infinispan.topology.CacheStatusResponse
 
getAvailabilityMode() - Method in class org.infinispan.topology.ClusterCacheStatus
 
getAvailableExtendedStatistics() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAverage(long) - Method in class org.infinispan.commons.stat.DefaultSimpleStat
 
getAverage(long) - Method in interface org.infinispan.commons.stat.SimpleStat
 
getAverageQueueTimeNanos() - Method in class org.infinispan.util.concurrent.ActionSequencer
 
getAverageReadTime() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getAverageReadTime() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getAverageReadTime() - Method in class org.infinispan.stats.impl.StatsCollector
 
getAverageReadTime() - Method in class org.infinispan.stats.impl.StatsImpl
 
getAverageReadTime() - Method in interface org.infinispan.stats.Stats
 
getAverageReadTimeNanos() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getAverageReadTimeNanos() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getAverageReadTimeNanos() - Method in class org.infinispan.stats.impl.StatsCollector
 
getAverageReadTimeNanos() - Method in class org.infinispan.stats.impl.StatsImpl
 
getAverageReadTimeNanos() - Method in interface org.infinispan.stats.Stats
 
getAverageRemoteReadTime() - Method in class org.infinispan.client.hotrod.impl.ClientStatistics
 
getAverageRemoteReadTime() - Method in interface org.infinispan.client.hotrod.jmx.RemoteCacheClientStatisticsMXBean
Returns the average read time, in milliseconds, for a remote cache.
getAverageRemoteRemovesTime() - Method in class org.infinispan.client.hotrod.impl.ClientStatistics
 
getAverageRemoteRemovesTime() - Method in interface org.infinispan.client.hotrod.jmx.RemoteCacheClientStatisticsMXBean
Returns the average time, in milliseconds, for remove operations in a remote cache.
getAverageRemoteStoreTime() - Method in class org.infinispan.client.hotrod.impl.ClientStatistics
 
getAverageRemoteStoreTime() - Method in interface org.infinispan.client.hotrod.jmx.RemoteCacheClientStatisticsMXBean
Returns the average store time, in milliseconds, for a remote cache.
getAverageRemoveTime() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getAverageRemoveTime() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getAverageRemoveTime() - Method in class org.infinispan.stats.impl.StatsCollector
 
getAverageRemoveTime() - Method in class org.infinispan.stats.impl.StatsImpl
 
getAverageRemoveTime() - Method in interface org.infinispan.stats.Stats
Deprecated, for removal: This API element is subject to removal in a future version.
Since 14.0, please use Stats.getAverageWriteTimeNanos() instead.
getAverageRemoveTimeNanos() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getAverageRemoveTimeNanos() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getAverageRemoveTimeNanos() - Method in class org.infinispan.stats.impl.StatsCollector
 
getAverageRemoveTimeNanos() - Method in class org.infinispan.stats.impl.StatsImpl
 
getAverageRemoveTimeNanos() - Method in interface org.infinispan.stats.Stats
 
getAverageReplicationTime() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getAverageRunningTimeNanos() - Method in class org.infinispan.util.concurrent.ActionSequencer
 
getAverageWriteTime() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getAverageWriteTime() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getAverageWriteTime() - Method in class org.infinispan.stats.impl.StatsCollector
 
getAverageWriteTime() - Method in class org.infinispan.stats.impl.StatsImpl
 
getAverageWriteTime() - Method in interface org.infinispan.stats.Stats
Deprecated, for removal: This API element is subject to removal in a future version.
Since 14.0, please use Stats.getAverageReadTimeNanos() instead.
getAverageWriteTimeNanos() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getAverageWriteTimeNanos() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getAverageWriteTimeNanos() - Method in class org.infinispan.stats.impl.StatsCollector
 
getAverageWriteTimeNanos() - Method in class org.infinispan.stats.impl.StatsImpl
 
getAverageWriteTimeNanos() - Method in interface org.infinispan.stats.Stats
 
getAverageXSiteReplicationTime() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getAverageXSiteReplicationTimeTo(String) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getAvgAbortedWriteTxDuration() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgClusteredGetCommandSize() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgCommitCommandSize() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgCommitRtt() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgCommitTime() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgCompleteNotificationAsync() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgGetsPerROTransaction() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgGetsPerWrTransaction() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgLocalCommitTime() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgLocalGetTime() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgLocalLockHoldTime() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgLocalPrepareTime() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgLocalRollbackTime() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgLockHoldTime() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgLockWaitingTime() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgNumNodesCommit() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgNumNodesCompleteNotification() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgNumNodesPrepare() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgNumNodesRemoteGet() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgNumNodesRollback() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgNumOfLockLocalTx() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgNumOfLockRemoteTx() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgNumOfLockSuccessLocalTx() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgPrepareCommandSize() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgPrepareRtt() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgPutsPerWrTransaction() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgReadOnlyTxDuration() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgRemoteCommitTime() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgRemoteGetRtt() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgRemoteGetsPerROTransaction() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgRemoteGetsPerWrTransaction() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgRemoteLockHoldTime() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgRemotePrepareTime() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgRemotePutsPerWrTransaction() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgRemoteRollbackTime() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgRequestSentDuration(long, TimeUnit) - Method in class org.infinispan.xsite.metrics.DefaultXSiteMetricsCollector
 
getAvgRequestSentDuration(long, TimeUnit) - Method in class org.infinispan.xsite.metrics.NoOpXSiteMetricsCollector
 
getAvgRequestSentDuration(long, TimeUnit) - Method in interface org.infinispan.xsite.metrics.XSiteMetricsCollector
 
getAvgRequestSentDuration(String, long, TimeUnit) - Method in class org.infinispan.xsite.metrics.DefaultXSiteMetricsCollector
 
getAvgRequestSentDuration(String, long, TimeUnit) - Method in class org.infinispan.xsite.metrics.NoOpXSiteMetricsCollector
 
getAvgRequestSentDuration(String, long, TimeUnit) - Method in interface org.infinispan.xsite.metrics.XSiteMetricsCollector
 
getAvgResponseTime() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgRollbackRtt() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgRollbackTime() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgTxArrivalRate() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getAvgWriteTxDuration() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getBackup() - Method in class org.infinispan.xsite.statetransfer.RemoteSiteStatus
 
getBackupLocation(String) - Method in class org.infinispan.server.core.backup.BackupManagerImpl
 
getBackupLocation(String) - Method in interface org.infinispan.server.core.BackupManager
Returns the Path of a backup file if it is complete.
getBackupLockedKeys() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getBackupManager() - Method in interface org.infinispan.server.core.ServerManagement
 
getBackupNames() - Method in class org.infinispan.server.core.backup.BackupManagerImpl
 
getBackupNames() - Method in interface org.infinispan.server.core.BackupManager
 
getBackupOwners(int) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
getBackupReceiver() - Method in class org.infinispan.factories.ComponentRegistry
 
getBackupSender() - Method in class org.infinispan.factories.ComponentRegistry
 
getBackupStatus(String) - Method in class org.infinispan.server.core.backup.BackupManagerImpl
 
getBackupStatus(String) - Method in interface org.infinispan.server.core.BackupManager
Return the current BackupManager.Status of a Backup request.
getBatchContainer() - Method in interface org.infinispan.AdvancedCache
Returns the component in charge of batching cache operations.
getBatchContainer() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getBatchContainer() - Method in class org.infinispan.cache.impl.CacheImpl
 
getBatchContainer() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getBatchContainer() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getBatchSize() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getBatchTransaction() - Method in class org.infinispan.batch.BatchContainer
 
getBestVersion(int) - Static method in enum org.infinispan.client.hotrod.ProtocolVersion
 
getBiasManager() - Method in class org.infinispan.factories.ComponentRegistry
 
getBlockingFuture(int) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
getBlockingFuture(int) - Method in interface org.infinispan.scattered.ScatteredVersionManager
 
getBlockingManager() - Method in class org.infinispan.factories.ComponentRegistry
 
getBlockingManager() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getBlockingManager() - Method in interface org.infinispan.persistence.spi.InitializationContext
Returns a manager that is designed to execute tasks that might block.
getBlockingManager() - Method in class org.infinispan.persistence.support.DelegatingInitializationContext
 
getBlockingManager() - Method in class org.infinispan.server.core.AbstractProtocolServer
 
getBloomFilterBits() - Method in class org.infinispan.client.hotrod.near.NearCacheService
 
getBloomListenerAddress() - Method in class org.infinispan.client.hotrod.impl.InvalidatedNearRemoteCache
 
getBooleanProperty(String, boolean) - Method in class org.infinispan.commons.util.TypedProperties
 
getBooleanProperty(String, boolean, boolean) - Method in class org.infinispan.commons.util.TypedProperties
 
getBranchQualifier() - Method in class org.infinispan.commons.tx.XidImpl
 
getBranchQualifierAsByteBuffer() - Method in class org.infinispan.commons.tx.XidImpl
 
getBrandName() - Static method in class org.infinispan.commons.util.Version
 
getBrandName() - Static method in class org.infinispan.Version
Deprecated.
 
getBrandVersion() - Static method in class org.infinispan.commons.util.Version
 
getBuf() - Method in interface org.infinispan.commons.io.ByteBuffer
Returns the underlying buffer.
getBuf() - Method in class org.infinispan.commons.io.ByteBufferImpl
 
getBufferPools() - Method in class org.infinispan.commons.util.JVMMemoryInfoInfo
 
getBufferSizePredictor(Class<?>) - Method in class org.infinispan.commons.marshall.MarshallableTypeHints
Get the serialized form size predictor for a particular type.
getBufferSizePredictor(Object) - Method in class org.infinispan.client.hotrod.marshall.BytesOnlyMarshaller
 
getBufferSizePredictor(Object) - Method in class org.infinispan.commons.marshall.AbstractMarshaller
 
getBufferSizePredictor(Object) - Method in class org.infinispan.commons.marshall.MarshallableTypeHints
 
getBufferSizePredictor(Object) - Method in interface org.infinispan.commons.marshall.Marshaller
Returns a marshalled payload size predictor for a particular type.
getBufferSizePredictor(Object) - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
getBufferSizePredictor(Object) - Method in class org.infinispan.persistence.remote.wrapper.HotRodEntryMarshaller
Deprecated.
 
getBuilder() - Method in class org.infinispan.commons.io.StringBuilderWriter
 
getBuilder() - Method in class org.infinispan.configuration.cache.AbstractCustomInterceptorsConfigurationChildBuilder
 
getBuilder() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationChildBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.AbstractPersistenceConfigurationChildBuilder
 
getBuilder() - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
getBuilder() - Method in class org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.remote.configuration.AbstractSecurityConfigurationChildBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.AbstractTransportConfigurationChildBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.BackupForBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.security.impl.CreatePermissionConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.CustomStoreConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.IndexReaderConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder.StringTableManipulationConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.jdbc.common.configuration.ManagedConnectionFactoryConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.remote.configuration.MechanismConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.MemoryStorageConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.QueryConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.SecurityConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.parsing.SFSToSIFSConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.StatisticsConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.persistence.remote.configuration.TrustStoreConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
 
getBuilder() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
 
getBuilder(MetaParamsInternalMetadata) - Static method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
 
getBuilder(PrivateMetadata) - Static method in class org.infinispan.metadata.impl.PrivateMetadata
Returns a PrivateMetadata.Builder with the metadata stored by metadata.
getByte(int) - Method in class org.infinispan.commons.marshall.WrappedByteArray
 
getByte(int) - Method in interface org.infinispan.commons.marshall.WrappedBytes
Retrieves the byte given an offset.
getByteBufferFactory() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getByteBufferFactory() - Method in interface org.infinispan.persistence.spi.InitializationContext
To be used for building ByteBuffer objects.
getByteBufferFactory() - Method in class org.infinispan.persistence.support.DelegatingInitializationContext
 
getBytes() - Method in class org.infinispan.commons.marshall.WrappedByteArray
 
getBytes() - Method in interface org.infinispan.commons.marshall.WrappedBytes
The backing array if there is one otherwise null is returned.
getBytes() - Method in class org.infinispan.persistence.sifs.EntryMetadata
 
getCache() - Method in interface org.infinispan.client.hotrod.RemoteCacheContainer
 
getCache() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
Retrieves the default cache from the remote server.
getCache() - Method in interface org.infinispan.commons.api.BasicCacheContainer
Retrieves the default cache associated with this cache container.
getCache() - Method in class org.infinispan.factories.ComponentRegistry
 
getCache() - Method in interface org.infinispan.manager.CacheContainer
 
getCache() - Method in class org.infinispan.manager.DefaultCacheManager
Retrieves the default cache associated with this cache manager.
getCache() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Retrieves the default cache associated with this cache container.
getCache() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getCache() - Method in class org.infinispan.multimap.impl.EmbeddedMultimapCache
 
getCache() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
getCache() - Method in interface org.infinispan.notifications.cachelistener.event.Event
 
getCache() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getCache() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getCache() - Method in interface org.infinispan.persistence.spi.InitializationContext
 
getCache() - Method in class org.infinispan.persistence.support.DelegatingInitializationContext
 
getCache() - Method in class org.infinispan.server.core.CacheInfo
 
getCache() - Method in class org.infinispan.server.memcached.MemcachedServer
Returns the cache being used by the Memcached server
getCache() - Method in class org.infinispan.tasks.TaskContext
The default cache.
getCache(boolean) - Method in interface org.infinispan.client.hotrod.RemoteCacheContainer
Deprecated, for removal: This API element is subject to removal in a future version.
since 11.0. Use ConfigurationBuilder.remoteCache(String) to configure the cache and then RemoteCacheContainer.getCache(String) to obtain it.
getCache(String) - Method in interface org.infinispan.client.hotrod.RemoteCacheContainer
 
getCache(String) - Method in class org.infinispan.client.hotrod.RemoteCacheManager
Retrieves a named cache from the remote server if the cache has been defined, otherwise if the cache name is undefined, it will return null.
getCache(String) - Method in interface org.infinispan.commons.api.BasicCacheContainer
Retrieves a cache by name.
getCache(String) - Method in interface org.infinispan.manager.CacheContainer
 
getCache(String) - Method in class org.infinispan.manager.DefaultCacheManager
Retrieves a named cache from the system.
getCache(String) - Method in interface org.infinispan.manager.EmbeddedCacheManager
Retrieves a cache by name.
getCache(String) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getCache(String) - Method in class org.infinispan.spring.embedded.provider.SpringEmbeddedCacheManager
 
getCache(String) - Method in class org.infinispan.spring.remote.provider.SpringRemoteCacheManager
 
getCache(String, boolean) - Method in interface org.infinispan.client.hotrod.RemoteCacheContainer
Deprecated, for removal: This API element is subject to removal in a future version.
since 11.0. Use ConfigurationBuilder.remoteCache(String) to configure the cache and then RemoteCacheContainer.getCache(String) to obtain it.
getCache(String, boolean) - Method in class org.infinispan.manager.DefaultCacheManager
 
getCache(String, boolean) - Method in interface org.infinispan.manager.EmbeddedCacheManager
Similar to EmbeddedCacheManager.getCache(String), except if has the option to not create the cache if it is not already running.
getCache(String, boolean) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getCache(String, boolean, TransactionManager) - Method in interface org.infinispan.client.hotrod.RemoteCacheContainer
Deprecated, for removal: This API element is subject to removal in a future version.
since 11.0. Use ConfigurationBuilder.remoteCache(String) to configure the cache and then RemoteCacheContainer.getCache(String) to obtain it.
getCache(String, boolean, TransactionMode) - Method in interface org.infinispan.client.hotrod.RemoteCacheContainer
Deprecated, for removal: This API element is subject to removal in a future version.
since 11.0. Use ConfigurationBuilder.remoteCache(String) to configure the cache and then RemoteCacheContainer.getCache(String) to obtain it.
getCache(String, boolean, TransactionMode, TransactionManager) - Method in interface org.infinispan.client.hotrod.RemoteCacheContainer
Deprecated, for removal: This API element is subject to removal in a future version.
since 11.0. Use ConfigurationBuilder.remoteCache(String) to configure the cache and then RemoteCacheContainer.getCache(String) to obtain it.
getCache(String, boolean, TransactionMode, TransactionManager) - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
getCache(String, TransactionManager) - Method in interface org.infinispan.client.hotrod.RemoteCacheContainer
Deprecated, for removal: This API element is subject to removal in a future version.
since 11.0. Use ConfigurationBuilder.remoteCache(String) to configure the cache and then RemoteCacheContainer.getCache(String) to obtain it.
getCache(String, TransactionMode) - Method in interface org.infinispan.client.hotrod.RemoteCacheContainer
Deprecated, for removal: This API element is subject to removal in a future version.
since 11.0. Use ConfigurationBuilder.remoteCache(String) to configure the cache and then RemoteCacheContainer.getCache(String) to obtain it.
getCache(String, TransactionMode, TransactionManager) - Method in interface org.infinispan.client.hotrod.RemoteCacheContainer
Deprecated, for removal: This API element is subject to removal in a future version.
since 11.0. Use ConfigurationBuilder.remoteCache(String) to configure the cache and then RemoteCacheContainer.getCache(String) to obtain it.
getCache(String, TransactionMode, TransactionManager) - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
getCache(KeyValuePair<MediaType, MediaType>, Subject) - Method in class org.infinispan.server.core.CacheInfo
 
GetCacheAction - Class in org.infinispan.security.actions
GetCacheAction.
GetCacheAction(EmbeddedCacheManager, String) - Constructor for class org.infinispan.security.actions.GetCacheAction
 
GetCacheAuthorizationManagerAction - Class in org.infinispan.security.actions
GetCacheAuthorizationManagerAction.
GetCacheAuthorizationManagerAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetCacheAuthorizationManagerAction
 
getCacheAvailability() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getCacheAvailability() - Method in class org.infinispan.cache.impl.CacheImpl
 
getCacheAvailability(String) - Method in interface org.infinispan.topology.LocalTopologyManager
Retrieves the availability state of a cache.
getCacheAvailability(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
GetCacheAvailabilityAction - Class in org.infinispan.security.actions
GetCacheAvailabilityAction.
GetCacheAvailabilityAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetCacheAvailabilityAction
 
getCacheByteString() - Method in class org.infinispan.factories.ComponentRegistry
 
GetCacheComponentRegistryAction - Class in org.infinispan.security.actions
GetCacheComponentRegistryAction.
GetCacheComponentRegistryAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetCacheComponentRegistryAction
 
getCacheConfiguration() - Method in interface org.infinispan.Cache
 
getCacheConfiguration() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getCacheConfiguration() - Method in class org.infinispan.cache.impl.CacheImpl
 
getCacheConfiguration() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getCacheConfiguration() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getCacheConfiguration(String) - Method in class org.infinispan.manager.DefaultCacheManager
 
getCacheConfiguration(String) - Method in interface org.infinispan.manager.EmbeddedCacheManager
Returns the configuration for the given cache.
getCacheConfiguration(String) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
GetCacheConfigurationAction - Class in org.infinispan.security.actions
GetCacheConfigurationAction.
GetCacheConfigurationAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetCacheConfigurationAction
 
GetCacheConfigurationFromManagerAction - Class in org.infinispan.security.actions
GetCacheManagerConfigurationAction.
GetCacheConfigurationFromManagerAction(EmbeddedCacheManager, String) - Constructor for class org.infinispan.security.actions.GetCacheConfigurationFromManagerAction
 
getCacheConfigurationNames() - Method in class org.infinispan.manager.CacheManagerInfo
 
getCacheConfigurationNames() - Method in class org.infinispan.manager.DefaultCacheManager
 
getCacheConfigurationNames() - Method in interface org.infinispan.manager.EmbeddedCacheManager
This method returns a collection of all cache configuration names.
getCacheConfigurationNames() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getCacheControlHeader() - Method in interface org.infinispan.rest.framework.RestRequest
 
getCacheControlHeader() - Method in class org.infinispan.rest.NettyRestRequest
 
getCacheDataFormat(byte[]) - Method in class org.infinispan.client.hotrod.event.impl.ClientListenerNotifier
 
GetCacheDistributionManagerAction - Class in org.infinispan.security.actions
GetCacheDistributionManagerAction.
GetCacheDistributionManagerAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetCacheDistributionManagerAction
 
getCacheEntry() - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
 
getCacheEntry(Object) - Method in interface org.infinispan.AdvancedCache
Retrieves a CacheEntry corresponding to a specific key.
getCacheEntry(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getCacheEntry(Object) - Method in class org.infinispan.cache.impl.CacheImpl
 
getCacheEntry(Object) - Method in class org.infinispan.cache.impl.DecoratedCache
 
getCacheEntry(Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
getCacheEntry(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getCacheEntry(Object) - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
getCacheEntry(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
GetCacheEntryAction<K,V> - Class in org.infinispan.security.actions
GetCacheEntryAction.
GetCacheEntryAction(AdvancedCache<?, ?>, K) - Constructor for class org.infinispan.security.actions.GetCacheEntryAction
 
getCacheEntryAsync(Object) - Method in interface org.infinispan.AdvancedCache
Retrieves a CacheEntry corresponding to a specific key.
getCacheEntryAsync(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getCacheEntryAsync(Object) - Method in class org.infinispan.cache.impl.CacheImpl
 
getCacheEntryAsync(Object) - Method in class org.infinispan.cache.impl.DecoratedCache
 
getCacheEntryAsync(Object) - Method in class org.infinispan.cache.impl.EncoderCache
 
getCacheEntryAsync(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getCacheEntryAsync(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
GetCacheEntryAsyncAction<K,V> - Class in org.infinispan.security.actions
GetCacheEntryAction.
GetCacheEntryAsyncAction(AdvancedCache<?, ?>, K) - Constructor for class org.infinispan.security.actions.GetCacheEntryAsyncAction
 
getCacheHealth() - Method in interface org.infinispan.health.Health
Returns per cache health.
getCacheHealth() - Method in class org.infinispan.health.impl.HealthImpl
 
getCacheHealth() - Method in interface org.infinispan.health.jmx.HealthJMXExposer
Returns per Cache statuses.
getCacheHealth(Set<String>) - Method in interface org.infinispan.health.Health
Returns per cache health for the provided cache names.
getCacheHealth(Set<String>) - Method in class org.infinispan.health.impl.HealthImpl
 
getCacheInfo(String, byte, long, boolean) - Method in class org.infinispan.server.hotrod.HotRodServer
 
getCacheInfo(WrappedBytes) - Method in class org.infinispan.client.hotrod.impl.TopologyInfo
 
getCacheInfo(HotRodHeader) - Method in class org.infinispan.server.hotrod.HotRodServer
 
GetCacheInterceptorChainAction - Class in org.infinispan.security.actions
GetCacheInterceptorChainAction.
GetCacheInterceptorChainAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetCacheInterceptorChainAction
 
getCacheJoinInfo() - Method in class org.infinispan.topology.CacheStatusResponse
 
getCacheLoaderLoads() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getCacheLoaderLoads() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getCacheLoaderMisses() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getCacheLoaderMisses() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
GetCacheLockManagerAction - Class in org.infinispan.security.actions
GetCacheLockManagerAction.
GetCacheLockManagerAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetCacheLockManagerAction
 
getCacheManager() - Method in interface org.infinispan.Cache
Retrieves the cache manager responsible for creating this cache instance.
getCacheManager() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getCacheManager() - Method in class org.infinispan.cache.impl.CacheImpl
 
getCacheManager() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getCacheManager() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getCacheManager() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.Event
 
getCacheManager() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
getCacheManager() - Method in interface org.infinispan.security.AuthorizationMapperContext
 
getCacheManager() - Method in class org.infinispan.security.impl.AuthorizationMapperContextImpl
 
getCacheManager() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getCacheManager() - Method in class org.infinispan.server.core.AbstractProtocolServer
 
getCacheManager() - Method in interface org.infinispan.server.core.ServerManagement
 
getCacheManager() - Method in class org.infinispan.tasks.TaskContext
CacheManager for this task execution
getCacheManager(String) - Method in interface org.infinispan.server.core.ServerManagement
Deprecated, for removal: This API element is subject to removal in a future version.
Multiple Cache Managers are not supported in the server. Use ServerManagement.getCacheManager() instead.
GetCacheManagerAddress - Class in org.infinispan.security.actions
GetCacheManagerAddress.
GetCacheManagerAddress(EmbeddedCacheManager) - Constructor for class org.infinispan.security.actions.GetCacheManagerAddress
 
GetCacheManagerClusterAvailabilityAction - Class in org.infinispan.security.actions
GetCacheManagerClusterAvailabilityAction.
GetCacheManagerClusterAvailabilityAction(EmbeddedCacheManager) - Constructor for class org.infinispan.security.actions.GetCacheManagerClusterAvailabilityAction
 
GetCacheManagerClusterNameAction - Class in org.infinispan.security.actions
GetCacheManagerClusterNameAction.
GetCacheManagerClusterNameAction(EmbeddedCacheManager) - Constructor for class org.infinispan.security.actions.GetCacheManagerClusterNameAction
 
getCacheManagerConfiguration() - Method in class org.infinispan.manager.DefaultCacheManager
 
getCacheManagerConfiguration() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Returns global configuration for this CacheManager
getCacheManagerConfiguration() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
GetCacheManagerConfigurationAction - Class in org.infinispan.security.actions
GetCacheManagerConfigurationAction.
GetCacheManagerConfigurationAction(EmbeddedCacheManager) - Constructor for class org.infinispan.security.actions.GetCacheManagerConfigurationAction
 
GetCacheManagerCoordinatorAddress - Class in org.infinispan.security.actions
GetCacheManagerCoordinatorAddress.
GetCacheManagerCoordinatorAddress(EmbeddedCacheManager) - Constructor for class org.infinispan.security.actions.GetCacheManagerCoordinatorAddress
 
GetCacheManagerHealthAction - Class in org.infinispan.security.actions
 
GetCacheManagerHealthAction(EmbeddedCacheManager) - Constructor for class org.infinispan.security.actions.GetCacheManagerHealthAction
 
getCacheManagerInfo() - Method in class org.infinispan.manager.DefaultCacheManager
 
getCacheManagerInfo() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getCacheManagerInfo() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
GetCacheManagerIsCoordinatorAction - Class in org.infinispan.security.actions
GetCacheManagerIsCoordinatorAction.
GetCacheManagerIsCoordinatorAction(EmbeddedCacheManager) - Constructor for class org.infinispan.security.actions.GetCacheManagerIsCoordinatorAction
 
getCacheManagerStatus() - Method in class org.infinispan.manager.CacheManagerInfo
 
getCacheManagerStatus() - Method in class org.infinispan.manager.DefaultCacheManager
 
GetCacheManagerStatusAction - Class in org.infinispan.security.actions
GetCacheManagerStatusAction.
GetCacheManagerStatusAction(EmbeddedCacheManager) - Constructor for class org.infinispan.security.actions.GetCacheManagerStatusAction
 
getCacheMarshaller() - Method in class org.infinispan.factories.ComponentRegistry
Deprecated, for removal: This API element is subject to removal in a future version.
getCacheMode() - Method in class org.infinispan.topology.CacheJoinInfo
 
getCacheName() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getCacheName() - Method in class org.infinispan.cache.impl.CacheImpl
Returns the cache name.
getCacheName() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getCacheName() - Method in interface org.infinispan.commands.CommandsFactory
Retrieves the cache name this CommandFactory is set up to construct commands for.
getCacheName() - Method in class org.infinispan.commands.CommandsFactoryImpl
 
getCacheName() - Method in class org.infinispan.factories.ComponentRegistry
 
getCacheName() - Method in interface org.infinispan.health.CacheHealth
Returns Cache name.
getCacheName() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.CacheStartedEvent
 
getCacheName() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.CacheStoppedEvent
 
getCacheName() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
getCacheName() - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
 
getCacheName() - Method in class org.infinispan.server.hotrod.HotRodHeader
 
getCacheName() - Method in class org.infinispan.server.hotrod.tx.table.CacheXid
 
getCacheName() - Method in class org.infinispan.topology.ClusterCacheStatus
 
getCacheName() - Method in class org.infinispan.xsite.events.XSiteEvent
 
getCacheNames() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
getCacheNames() - Method in interface org.infinispan.commons.api.BasicCacheContainer
This method returns a collection of all cache names.
getCacheNames() - Method in class org.infinispan.manager.CacheManagerInfo
 
getCacheNames() - Method in class org.infinispan.manager.DefaultCacheManager
 
getCacheNames() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getCacheNames() - Method in class org.infinispan.spring.embedded.provider.SpringEmbeddedCacheManager
 
getCacheNames() - Method in class org.infinispan.spring.remote.provider.SpringRemoteCacheManager
 
getCacheNotifier() - Method in class org.infinispan.factories.ComponentRegistry
 
GetCacheRpcManagerAction - Class in org.infinispan.security.actions
GetCacheRpcManagerAction.
GetCacheRpcManagerAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetCacheRpcManagerAction
 
getCaches() - Method in class org.infinispan.topology.ManagerStatusResponse
 
getCacheStatisticManager() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getCacheStatus() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
Returns String representation of ComponentStatus enumeration in order to avoid class not found exceptions in JMX tools that don't have access to infinispan classes.
getCacheStatus() - Method in class org.infinispan.cache.impl.CacheImpl
Returns String representation of ComponentStatus enumeration in order to avoid class not found exceptions in JMX tools that don't have access to infinispan classes.
getCacheStatus() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
GetCacheStatusAction - Class in org.infinispan.security.actions
GetCacheStatusAction.
GetCacheStatusAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetCacheStatusAction
 
getCacheTopology() - Method in interface org.infinispan.distribution.DistributionManager
 
getCacheTopology() - Method in class org.infinispan.distribution.impl.DistributionManagerImpl
 
getCacheTopology() - Method in class org.infinispan.topology.CacheStatusResponse
 
getCacheTopology(String) - Method in interface org.infinispan.topology.LocalTopologyManager
 
getCacheTopology(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
getCacheTopologyInfo() - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
getCacheTopologyInfo() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getCacheTopologyInfo() - Method in interface org.infinispan.client.hotrod.RemoteCache
Returns CacheTopologyInfo for this cache.
getCacheTopologyInfo(byte[]) - Method in class org.infinispan.client.hotrod.impl.TopologyInfo
 
getCacheTransaction() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
getCacheTransaction() - Method in interface org.infinispan.context.impl.TxInvocationContext
 
getCallback() - Method in interface org.infinispan.objectfilter.FilterSubscription
The associated callback that is being notified of successful matches.
getCallbackHandler(String, Map<String, String>) - Method in interface org.infinispan.server.core.security.ServerAuthenticationProvider
Deprecated, for removal: This API element is subject to removal in a future version.
This method will no longer be invoked directly. Implement the
invalid reference
#createSaslServer(String, List, String, String, Map, ClassLoader)
method instead.
getCallbackHandler(String, Map<String, String>) - Method in class org.infinispan.server.core.security.simple.SimpleServerAuthenticationProvider
Get a callback handler for the given mechanism name.
getCallerClass(int) - Static method in class org.infinispan.commons.jdkspecific.CallerId
 
getCallerMethodName(int) - Static method in class org.infinispan.commons.jdkspecific.CallerId
 
getCanonicalFile() - Method in class org.infinispan.io.GridFile
Deprecated.
 
getCanonicalPath() - Method in class org.infinispan.io.GridFile
Deprecated.
 
getCapacity() - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
 
getCapacity() - Method in class org.infinispan.extendedstats.topK.StreamSummaryContainer
 
getCapacityFactor() - Method in class org.infinispan.topology.CacheJoinInfo
 
getCapacityFactor(Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
getCapacityFactor(Address) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
getCapacityFactors() - Method in interface org.infinispan.distribution.ch.ConsistentHash
The capacity factor of each member.
getCapacityFactors() - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
getCapacityFactors() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
getCapacityFactors() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
getCapacityFactors() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
getCapacityFactors() - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
 
getCapacityFactors() - Method in class org.infinispan.topology.ClusterCacheStatus
 
getChannel() - Method in class org.infinispan.client.hotrod.counter.operation.AddListenerOperation
 
getChannel() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getChannelFactory() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
This method is not a part of the public API.
getChannelMatcher() - Method in class org.infinispan.rest.RestServer
 
getChannelMatcher() - Method in interface org.infinispan.server.core.ProtocolServer
Returns a ChannelMatcher which matches channels which belong to this protocol server
getChannelMatcher() - Method in class org.infinispan.server.hotrod.HotRodServer
 
getChannelMatcher() - Method in class org.infinispan.server.memcached.MemcachedServer
 
getCharset() - Method in class org.infinispan.commons.dataconversion.MediaType
 
getChecksum() - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
 
getChecksum() - Method in interface org.infinispan.globalstate.ScopedPersistentState
Returns the checksum of the properties excluding those prefixed with @
getChildNames() - Method in class org.infinispan.distribution.topologyaware.TopologyInfo.Location
 
getChunkSize() - Method in class org.infinispan.io.GridFile
Deprecated.
Guaranteed to be a power of two
getChunkSize() - Method in class org.infinispan.io.GridFile.Metadata
Deprecated.
 
getClassAllowList() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
getClassAllowList() - Method in class org.infinispan.manager.DefaultCacheManager
 
getClassAllowList() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getClassAllowList() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getClasses() - Method in class org.infinispan.configuration.global.AllowListConfiguration
 
getClasses() - Method in class org.infinispan.configuration.global.WhiteListConfiguration
Deprecated.
 
getClassForName(String, ClassLoader) - Static method in class org.infinispan.commons.util.ReflectionUtil
 
GetClassInstanceAction<T> - Class in org.infinispan.security.actions
GetClassInstanceAction.
GetClassInstanceAction(Class<T>) - Constructor for class org.infinispan.security.actions.GetClassInstanceAction
 
getClassLoader() - Method in interface org.infinispan.AdvancedCache
Returns the cache loader associated associated with this cache.
getClassLoader() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getClassLoader() - Method in class org.infinispan.cache.impl.CacheImpl
 
getClassLoader() - Method in class org.infinispan.cache.impl.DecoratedCache
 
getClassLoader() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getClassLoader() - Method in class org.infinispan.commons.configuration.ClassAllowList
 
getClassLoader() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
getClassLoader() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
getClassLoader() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
getClassLoader() - Method in class org.infinispan.factories.ComponentRegistry
 
getClassLoader() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getClassLoader() - Method in class org.infinispan.jboss.marshalling.commons.DefaultContextClassResolver
 
getClassLoader() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
getClassLoader() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getClassLoaders(ClassLoader) - Static method in class org.infinispan.commons.util.Util
 
getClassType() - Method in class org.infinispan.commons.dataconversion.MediaType
 
getClassWhiteList() - Method in class org.infinispan.client.hotrod.configuration.Configuration
Deprecated, for removal: This API element is subject to removal in a future version.
Use Configuration.getClassAllowList() instead. To be removed in 14.0.
getClassWhiteList() - Method in class org.infinispan.manager.DefaultCacheManager
 
getClassWhiteList() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Deprecated, for removal: This API element is subject to removal in a future version.
getClassWhiteList() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getClientAddress() - Method in class org.infinispan.server.hotrod.tx.table.PerCacheTxTable
 
getClientCounterNotificationManager() - Method in class org.infinispan.server.hotrod.HotRodServer
 
getClientIntel() - Method in class org.infinispan.server.hotrod.HotRodHeader
 
getClientIntelligence() - Method in class org.infinispan.client.hotrod.configuration.ClusterConfiguration
 
getClientIntelligence() - Method in class org.infinispan.client.hotrod.impl.ClientTopology
 
getClientIntelligence() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getClientListenerRegistry() - Method in class org.infinispan.server.hotrod.HotRodServer
 
getCluster() - Method in class org.infinispan.client.hotrod.configuration.ClusterConfiguration
 
getCluster() - Method in class org.infinispan.client.hotrod.impl.TopologyInfo
 
getCluster() - Method in class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.RemoteSite
 
getClusterAvailability() - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
getClusterCacheNotifier() - Method in class org.infinispan.factories.ComponentRegistry
 
getClusteredSearchStatistics(Cache<?, ?>) - Static method in class org.infinispan.query.Search
Returns aggregated search statistics for all nodes in the cluster.
getClusteredVersion() - Method in class org.infinispan.metadata.EmbeddedMetadata
 
getClusteredVersion() - Method in class org.infinispan.metadata.impl.PrivateMetadata
 
GetClusterExecutorAction - Class in org.infinispan.security.actions
GetClusterExecutorAction.
GetClusterExecutorAction(Cache<?, ?>) - Constructor for class org.infinispan.security.actions.GetClusterExecutorAction
 
GetClusterExecutorAction(EmbeddedCacheManager) - Constructor for class org.infinispan.security.actions.GetClusterExecutorAction
 
getClusterHealth() - Method in interface org.infinispan.health.Health
Returns Cluster health.
getClusterHealth() - Method in class org.infinispan.health.impl.HealthImpl
 
getClusterHealth() - Method in interface org.infinispan.health.jmx.HealthJMXExposer
Returns cluster health status.
getClusteringBuilder() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
 
getClusteringBuilder() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
 
getClusteringBuilder() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
 
getClusteringBuilder() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
 
getClusteringBuilder() - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
 
getClusterMembers() - Method in class org.infinispan.manager.CacheManagerInfo
 
getClusterMembers() - Method in class org.infinispan.manager.DefaultCacheManager
 
getClusterMembersPhysicalAddresses() - Method in class org.infinispan.manager.CacheManagerInfo
 
getClusterMembersPhysicalAddresses() - Method in class org.infinispan.manager.DefaultCacheManager
 
getClusterName() - Method in class org.infinispan.client.hotrod.configuration.ClusterConfiguration
 
getClusterName() - Method in class org.infinispan.client.hotrod.configuration.ClusterConfigurationBuilder
 
getClusterName() - Method in interface org.infinispan.health.ClusterHealth
Returns the name of the cluster.
getClusterName() - Method in interface org.infinispan.health.jmx.HealthJMXExposer
Returns cluster name.
getClusterName() - Method in class org.infinispan.manager.CacheManagerInfo
 
getClusterName() - Method in class org.infinispan.manager.DefaultCacheManager
getClusterName() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getClusterName() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getClusterPublisherManager() - Method in class org.infinispan.factories.ComponentRegistry
 
getClusterSize() - Method in class org.infinispan.manager.CacheManagerInfo
 
getClusterSize() - Method in class org.infinispan.manager.DefaultCacheManager
 
getClusterStatus() - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateTransferManager
 
getClusterStatus() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
 
getClusterStatus() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
getClusterTopologyManager() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getCode() - Method in class org.infinispan.client.hotrod.impl.VersionedOperationResponse
 
getCode() - Method in enum org.infinispan.server.hotrod.OperationStatus
 
getCode() - Method in enum org.infinispan.server.hotrod.TimeUnitValue
 
getCodec() - Method in enum org.infinispan.client.hotrod.ProtocolVersion
 
getCodename() - Static method in class org.infinispan.commons.util.Version
 
getCodename() - Static method in class org.infinispan.Version
Deprecated.
 
getCollection() - Method in interface org.infinispan.client.hotrod.multimap.MetadataCollection
Collection of values with metadata
getCollocatedKey(K) - Method in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
 
getCollocatedKey(K) - Method in interface org.infinispan.affinity.KeyAffinityService
Returns a key that will be distributed on the same node as the supplied key.
getColumn() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
getColumn() - Method in exception class org.infinispan.commons.dataconversion.internal.Json.MalformedJsonException
 
getColumnNumber() - Method in class org.infinispan.commons.configuration.io.Location
 
getColumnNumber() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
getColumnNumber() - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returns the current column number, starting from 0.
getColumnNumber() - Method in exception class org.infinispan.commons.configuration.io.xml.XmlPullParserException
 
getCombine() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
getCommand() - Method in class org.infinispan.notifications.cachelistener.EventWrapper
 
getCommand() - Method in class org.infinispan.remoting.inboundhandler.action.ActionState
 
getCommandAckCollector() - Method in class org.infinispan.factories.ComponentRegistry
 
getCommandId() - Method in interface org.infinispan.commands.ReplicableCommand
Used by marshallers to convert this command into an id for streaming.
getCommandId() - Method in class org.infinispan.expiration.impl.TouchCommand
 
getCommandId() - Method in class org.infinispan.manager.impl.ReplicableManagerFunctionCommand
 
getCommandId() - Method in class org.infinispan.manager.impl.ReplicableRunnableCommand
 
getCommandId() - Method in class org.infinispan.notifications.cachelistener.cluster.MultiClusterEventCommand
 
getCommandId() - Method in class org.infinispan.server.hotrod.command.tx.ForwardCommitCommand
 
getCommandId() - Method in class org.infinispan.server.hotrod.command.tx.ForwardRollbackCommand
 
getCommandId() - Method in class org.infinispan.topology.HeartBeatCommand
 
getCommandId() - Method in class org.infinispan.xsite.commands.remote.IracClearKeysRequest
 
getCommandId() - Method in class org.infinispan.xsite.commands.remote.IracPutManyRequest
 
getCommandId() - Method in class org.infinispan.xsite.commands.remote.IracTombstoneCheckRequest
 
getCommandId() - Method in class org.infinispan.xsite.commands.remote.IracTouchKeyRequest
 
getCommandId() - Method in class org.infinispan.xsite.commands.remote.XSiteRemoteEventCommand
 
getCommandId() - Method in interface org.infinispan.xsite.commands.remote.XSiteRequest
Used by marshallers to convert this command into an id for streaming.
getCommandId() - Method in class org.infinispan.xsite.commands.remote.XSiteStatePushRequest
 
getCommandId() - Method in class org.infinispan.xsite.commands.remote.XSiteStateTransferControlRequest
 
getCommandId() - Method in class org.infinispan.xsite.commands.XSiteAmendOfflineStatusCommand
 
getCommandId() - Method in class org.infinispan.xsite.commands.XSiteAutoTransferStatusCommand
 
getCommandId() - Method in class org.infinispan.xsite.commands.XSiteBringOnlineCommand
 
getCommandId() - Method in class org.infinispan.xsite.commands.XSiteLocalEventCommand
 
getCommandId() - Method in class org.infinispan.xsite.commands.XSiteOfflineStatusCommand
 
getCommandId() - Method in class org.infinispan.xsite.commands.XSiteSetStateTransferModeCommand
 
getCommandId() - Method in class org.infinispan.xsite.commands.XSiteStateTransferCancelSendCommand
 
getCommandId() - Method in class org.infinispan.xsite.commands.XSiteStateTransferClearStatusCommand
 
getCommandId() - Method in class org.infinispan.xsite.commands.XSiteStateTransferFinishReceiveCommand
 
getCommandId() - Method in class org.infinispan.xsite.commands.XSiteStateTransferFinishSendCommand
 
getCommandId() - Method in class org.infinispan.xsite.commands.XSiteStateTransferRestartSendingCommand
 
getCommandId() - Method in class org.infinispan.xsite.commands.XSiteStateTransferStartReceiveCommand
 
getCommandId() - Method in class org.infinispan.xsite.commands.XSiteStateTransferStartSendCommand
 
getCommandId() - Method in class org.infinispan.xsite.commands.XSiteStateTransferStatusRequestCommand
 
getCommandId() - Method in class org.infinispan.xsite.commands.XSiteStatusCommand
 
getCommandId() - Method in class org.infinispan.xsite.commands.XSiteTakeOfflineCommand
 
getCommandId() - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
 
getCommandsFactory() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getLocalComponent(CommandsFactory.class);
getCommandsFactory() - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateProvider
 
getCommandsFactory() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateProvider
getCommandsFactory() - Method in class org.infinispan.xsite.statetransfer.XSiteStateProviderImpl
 
getCommandTopologyId() - Method in class org.infinispan.remoting.inboundhandler.action.ActionState
 
getCommitInterval() - Method in class org.infinispan.configuration.cache.IndexWriterConfiguration
 
getCommitNodes(Collection<Address>, CacheTopology) - Method in class org.infinispan.transaction.impl.LocalTransaction
Calculates the list of nodes to which a commit/rollback needs to be sent based on the nodes to which prepare was sent.
getCommittedViewAsString() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getCommunicationErrors() - Method in class org.infinispan.remoting.transport.AggregateBackupResponse
 
getCommunicationErrors() - Method in interface org.infinispan.remoting.transport.BackupResponse
Returns the list of sites where the backups failed due to a bridge communication error (as opposed to an error caused by Infinispan, e.g.
getCommunicationErrors() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsBackupResponse
 
getComparator() - Method in interface org.infinispan.objectfilter.FilterSubscription
The comparator corresponding to the 'order by' clause, if any.
getComparator() - Method in interface org.infinispan.objectfilter.ObjectFilter
The comparator corresponding to the 'order by' clause, if any.
getCompletedTasks() - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
getCompletedTransactionStatus(GlobalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
 
getComponent(Class<T>) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
Retrieves a component of a specified type from the registry, or null if it cannot be found.
getComponent(Class<T>) - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
Looks up a running component named name in the registry, or registers it if necessary.
getComponent(Class<T>, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
getComponent(String) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
getComponent(String, Class<U>) - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
Looks up a running component named name in the registry, or registers it if necessary.
getComponent(String, Class<U>) - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
 
getComponent(String, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
getComponent(String, String, boolean) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
getComponent(String, String, boolean) - Method in class org.infinispan.factories.ComponentRegistry
 
getComponentName() - Method in class org.infinispan.factories.impl.ComponentAlias
 
getComponentRegistry() - Method in interface org.infinispan.AdvancedCache
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, with no public API replacement
getComponentRegistry() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getComponentRegistry() - Method in class org.infinispan.cache.impl.CacheImpl
 
getComponentRegistry() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getComponentRegistry() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getCompressionLevel() - Method in class org.infinispan.rest.configuration.RestServerConfiguration
 
getConcurrencyLevel() - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
 
getConfiguration() - Method in class org.infinispan.client.hotrod.counter.impl.BaseCounter
 
getConfiguration() - Method in interface org.infinispan.client.hotrod.RemoteCacheContainer
Retrieves the configuration currently in use.
getConfiguration() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
getConfiguration() - Method in interface org.infinispan.counter.api.StrongCounter
 
getConfiguration() - Method in interface org.infinispan.counter.api.SyncStrongCounter
 
getConfiguration() - Method in interface org.infinispan.counter.api.SyncWeakCounter
 
getConfiguration() - Method in interface org.infinispan.counter.api.WeakCounter
 
getConfiguration() - Method in class org.infinispan.counter.impl.SyncStrongCounterAdapter
 
getConfiguration() - Method in class org.infinispan.counter.impl.SyncWeakCounterAdapter
 
getConfiguration() - Method in class org.infinispan.factories.ComponentRegistry
 
getConfiguration() - Method in class org.infinispan.globalstate.impl.CacheState
 
getConfiguration() - Method in class org.infinispan.persistence.file.SingleFileStore
 
getConfiguration() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getConfiguration() - Method in class org.infinispan.persistence.remote.RemoteStore
 
getConfiguration() - Method in interface org.infinispan.persistence.spi.InitializationContext
 
getConfiguration() - Method in class org.infinispan.persistence.support.DelegatingInitializationContext
 
getConfiguration() - Method in class org.infinispan.rest.InvocationHelper
 
getConfiguration() - Method in class org.infinispan.server.core.AbstractProtocolServer
 
getConfiguration() - Method in interface org.infinispan.server.core.ProtocolServer
Returns the configuration used to start this server
getConfiguration(String) - Method in class org.infinispan.client.hotrod.counter.impl.RemoteCounterManager
 
getConfiguration(String) - Method in class org.infinispan.configuration.ConfigurationManager
 
getConfiguration(String) - Method in interface org.infinispan.counter.api.CounterManager
 
getConfiguration(String) - Method in interface org.infinispan.lock.api.ClusteredLockManager
Returns the configuration of a ClusteredLock, if such exists.This method throws ClusteredLockException if the lock is not not defined.
getConfiguration(String) - Method in class org.infinispan.xsite.status.DefaultTakeOfflineManager
 
getConfiguration(String) - Method in class org.infinispan.xsite.status.NoOpTakeOfflineManager
 
getConfiguration(String) - Method in interface org.infinispan.xsite.status.TakeOfflineManager
It returns the current TakeOfflineConfiguration for site siteName.
getConfiguration(String, boolean) - Method in class org.infinispan.configuration.ConfigurationManager
 
getConfigurationAsProperties() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getConfigurationAsProperties() - Method in class org.infinispan.cache.impl.CacheImpl
 
getConfigurationAsProperties() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getConfigurationBuilder(String, String) - Method in class org.infinispan.server.core.admin.embeddedserver.CacheCreateTask
 
getConfigurationEntityName() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ConfigurationChangedEvent
 
getConfigurationEntityName() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
getConfigurationEntityType() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ConfigurationChangedEvent
 
getConfigurationEntityType() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
getConfigurationEventType() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ConfigurationChangedEvent
 
getConfigurationEventType() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
GetConfigurationOperation - Class in org.infinispan.client.hotrod.counter.operation
A counter configuration for CounterManager.getConfiguration(String).
GetConfigurationOperation(ChannelFactory, AtomicReference<ClientTopology>, Configuration, String) - Constructor for class org.infinispan.client.hotrod.counter.operation.GetConfigurationOperation
 
getConfigurations() - Method in class org.infinispan.configuration.serializing.ConfigurationHolder
 
getConfigurator() - Method in interface org.infinispan.configuration.global.StackBuilder
 
getConfigurator() - Method in class org.infinispan.configuration.global.StackConfigurationBuilder
 
getConfigurator() - Method in class org.infinispan.configuration.global.StackFileConfigurationBuilder
 
getConflictManager() - Method in class org.infinispan.factories.ComponentRegistry
 
getConflicts() - Method in interface org.infinispan.conflict.ConflictManager
Returns a stream of conflicts detected in the cluster.
getConnection() - Method in class org.infinispan.persistence.jdbc.common.connectionfactory.ConnectionFactory
Fetches a connection from the factory.
getConnection() - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations.FlowableConnection
 
getConnectionCloser() - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations.FlowableConnection
 
getConnectionCount() - Method in interface org.infinispan.client.hotrod.jmx.RemoteCacheManagerMXBean
Returns the total number of connections
getConnectionCount() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
getConnectionFactory() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
 
getConnectionFactory() - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
getConnectionFactory(Class<? extends ConnectionFactory>) - Static method in class org.infinispan.persistence.jdbc.common.connectionfactory.ConnectionFactory
Constructs a ConnectionFactory based on the supplied class name.
getConnectionPoolExhaustedAction() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getConnectionPoolMaxActive() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getConnectionPoolMaxPendingRequests() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getConnectionPoolMaxWait() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getConnectTimeout() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getConsistentHashAtEnd() - Method in interface org.infinispan.notifications.cachelistener.event.DataRehashedEvent
 
getConsistentHashAtEnd() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getConsistentHashAtEnd() - Method in interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
Deprecated, for removal: This API element is subject to removal in a future version.
getConsistentHashAtStart() - Method in interface org.infinispan.notifications.cachelistener.event.DataRehashedEvent
 
getConsistentHashAtStart() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getConsistentHashAtStart() - Method in interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
Deprecated, for removal: This API element is subject to removal in a future version.
getConsistentHashFactory() - Method in class org.infinispan.client.hotrod.impl.TopologyInfo
 
getConsistentHashFactory() - Method in class org.infinispan.topology.CacheJoinInfo
 
getContentTypeHeader() - Method in interface org.infinispan.rest.framework.RestRequest
 
getContentTypeHeader() - Method in class org.infinispan.rest.NettyRestRequest
 
getContext() - Method in interface org.infinispan.commons.configuration.io.ConfigurationResourceResolver
 
getContext() - Method in class org.infinispan.commons.configuration.io.URLConfigurationResourceResolver
 
getContext() - Method in class org.infinispan.commons.util.SslContextFactory
 
getContext() - Method in class org.infinispan.rest.InvocationHelper
 
getContext() - Method in class org.infinispan.rest.NettyRestRequest
 
getContextInitializers() - Method in class org.infinispan.client.hotrod.configuration.Configuration
 
getContextInitializers() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getContinuousQuery(Cache<K, V>) - Static method in class org.infinispan.query.Search
Obtains the ContinuousQuery object for the cache.
getContinuousQuery(RemoteCache<K, V>) - Static method in class org.infinispan.client.hotrod.Search
 
getConverter() - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
 
getConverter() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
getConverter() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
getConverter() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
getConverter(Object[]) - Method in interface org.infinispan.notifications.cachelistener.filter.CacheEventConverterFactory
Retrieves a cache event converter instance from this factory.
getConverter(Object[]) - Method in class org.infinispan.server.hotrod.event.KeyValueWithPreviousEventConverterFactory
 
getCoordinator() - Method in class org.infinispan.manager.DefaultCacheManager
getCoordinator() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getCoordinator() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getCoordinator() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
getCoordinator() - Method in class org.infinispan.remoting.transport.jgroups.ClusterView
 
getCoordinator() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getCoordinator() - Method in interface org.infinispan.remoting.transport.Transport
 
getCoordinatorAddress() - Method in class org.infinispan.manager.CacheManagerInfo
 
getCoordinatorAddress() - Method in class org.infinispan.manager.DefaultCacheManager
 
getCorsConfigs() - Method in class org.infinispan.rest.RestServer
 
getCorsRules() - Method in class org.infinispan.rest.configuration.RestServerConfiguration
 
getCounterListener() - Method in interface org.infinispan.counter.api.Handle
 
getCounterManager() - Method in class org.infinispan.rest.InvocationHelper
 
getCounterName() - Method in class org.infinispan.client.hotrod.counter.impl.HotRodCounterEvent
 
getCounterNames() - Method in class org.infinispan.client.hotrod.counter.impl.RemoteCounterManager
 
getCounterNames() - Method in interface org.infinispan.counter.api.CounterManager
Returns a Collection of defined counter names.
GetCounterNamesOperation - Class in org.infinispan.client.hotrod.counter.operation
A counter operation for CounterManager.getCounterNames().
GetCounterNamesOperation(ChannelFactory, AtomicReference<ClientTopology>, Configuration) - Constructor for class org.infinispan.client.hotrod.counter.operation.GetCounterNamesOperation
 
getCreated() - Method in class org.infinispan.client.hotrod.impl.MetadataValueImpl
 
getCreated() - Method in class org.infinispan.client.hotrod.impl.VersionedMetadataImpl
 
getCreated() - Method in interface org.infinispan.client.hotrod.Metadata
 
getCreated() - Method in interface org.infinispan.container.entries.CacheEntry
 
getCreated() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
getCreated() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
getCreated() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
getCreated() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
getCreated() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
getCreated() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
 
getCreated() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
getCreated() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
getCreated() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
getCreated() - Method in class org.infinispan.container.entries.MortalCacheValue
 
getCreated() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getCreated() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
getCreated() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
getCreated() - Method in class org.infinispan.persistence.sifs.EntryMetadata
 
getCreated() - Method in class org.infinispan.persistence.sifs.EntryRecord
 
getCreated() - Method in interface org.infinispan.persistence.spi.MarshalledValue
 
getCreatedCacheCount() - Method in class org.infinispan.manager.CacheManagerInfo
 
getCreatedCacheCount() - Method in class org.infinispan.manager.DefaultCacheManager
 
getCreatedHeader() - Method in interface org.infinispan.rest.framework.RestRequest
 
getCreatedHeader() - Method in class org.infinispan.rest.NettyRestRequest
 
getCreationTime() - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository.InfinispanSession
 
getCreationTime() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getCreationTime() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
getCurrentCH() - Method in class org.infinispan.topology.CacheTopology
The current consistent hash.
getCurrentClusterName() - Method in interface org.infinispan.client.hotrod.jmx.RemoteCacheManagerMXBean
Returns the name of the currently active cluster.
getCurrentClusterName() - Method in interface org.infinispan.client.hotrod.RemoteCacheContainer
Returns the name of the currently active cluster.
getCurrentClusterName() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
getCurrentConfigurationBuilder() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
getCurrentDelayMillis() - Method in class org.infinispan.container.versioning.irac.DefaultIracTombstoneManager
 
getCurrentDelayMillis() - Method in interface org.infinispan.container.versioning.irac.IracTombstoneManager
 
getCurrentDelayMillis() - Method in class org.infinispan.container.versioning.irac.NoOpIracTombstoneManager
 
getCurrentNumberOfEntries() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getCurrentNumberOfEntries() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getCurrentNumberOfEntries() - Method in class org.infinispan.stats.impl.StatsCollector
 
getCurrentNumberOfEntries() - Method in class org.infinispan.stats.impl.StatsImpl
 
getCurrentNumberOfEntries() - Method in interface org.infinispan.stats.Stats
Deprecated, for removal: This API element is subject to removal in a future version.
getCurrentNumberOfEntriesInMemory() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getCurrentNumberOfEntriesInMemory() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getCurrentNumberOfEntriesInMemory() - Method in class org.infinispan.stats.impl.StatsCollector
Deprecated, for removal: This API element is subject to removal in a future version.
getCurrentNumberOfEntriesInMemory() - Method in class org.infinispan.stats.impl.StatsImpl
 
getCurrentNumberOfEntriesInMemory() - Method in interface org.infinispan.stats.Stats
Deprecated, for removal: This API element is subject to removal in a future version.
Since 14.0, please use Stats.getApproximateEntriesInMemory() instead.
getCurrentOs() - Static method in enum org.infinispan.commons.util.OS
 
getCurrentStage(Object) - Method in class org.infinispan.util.concurrent.DataOperationOrderer
For testing purposes only
getCurrentStateSending() - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateProvider
 
getCurrentStateSending() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateProvider
 
getCurrentStateSending() - Method in class org.infinispan.xsite.statetransfer.XSiteStateProviderImpl
 
getCurrentTopology() - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
 
getCurrentTopology() - Method in class org.infinispan.topology.ClusterCacheStatus
 
getCustomInterceptorsBuilder() - Method in class org.infinispan.configuration.cache.AbstractCustomInterceptorsConfigurationChildBuilder
Deprecated.
 
getCustomMetrics(GlobalMetricsConfiguration) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getCustomMetrics(GlobalMetricsConfiguration) - Method in class org.infinispan.xsite.status.DefaultTakeOfflineManager
 
getCustomMetrics(GlobalMetricsConfiguration) - Method in interface org.infinispan.xsite.status.TakeOfflineManager
 
getDataContainer() - Method in interface org.infinispan.AdvancedCache
Returns the container where data is stored in the cache.
getDataContainer() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getDataContainer() - Method in class org.infinispan.cache.impl.CacheImpl
 
getDataContainer() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getDataContainer() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getDataFormat() - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
getDataFormat() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getDataFormat() - Method in interface org.infinispan.client.hotrod.RemoteCache
Return the currently DataFormat being used.
getDataMemoryUsed() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getDataMemoryUsed() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getDataMemoryUsed() - Method in class org.infinispan.stats.impl.StatsCollector
 
getDataMemoryUsed() - Method in class org.infinispan.stats.impl.StatsImpl
 
getDataMemoryUsed() - Method in interface org.infinispan.stats.Stats
Provides how much memory the current eviction algorithm estimates is in use for data.
getDataSources() - Method in interface org.infinispan.server.core.ServerManagement
 
getDecoder() - Method in class org.infinispan.rest.RestServer
 
getDecoder() - Method in interface org.infinispan.server.core.ProtocolServer
Gets the decoder for this protocol server.
getDecoder() - Method in class org.infinispan.server.hotrod.HotRodServer
 
getDecoder() - Method in class org.infinispan.server.memcached.MemcachedServer
 
getDecoderResult() - Method in class org.infinispan.rest.ServerSentEvent
 
getDefault() - Static method in enum org.infinispan.client.hotrod.configuration.ClientIntelligence
 
getDefaultCacheConfiguration() - Method in class org.infinispan.manager.DefaultCacheManager
 
getDefaultCacheConfiguration() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getDefaultCacheConfiguration() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getDefaultCluster() - Method in class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.RemoteSites
 
getDefaultConfigurationBuilder() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
getDefaultExecutorFactoryPoolSize() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getDefaultExecutorFactoryThreadNamePrefix() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getDefaultExecutorFactoryThreadNameSuffix() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getDefaultKeepaliveMillis() - Static method in class org.infinispan.factories.KnownComponentNames
 
getDefaultMinThreads(String) - Static method in class org.infinispan.factories.KnownComponentNames
 
getDefaultQueueSize(String) - Static method in class org.infinispan.factories.KnownComponentNames
 
getDefaultStack() - Method in class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.RemoteSites
 
getDefaultThreadPrio(String) - Static method in class org.infinispan.factories.KnownComponentNames
 
getDefaultThreads(String) - Static method in class org.infinispan.factories.KnownComponentNames
 
getDefaultValue() - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
 
getDefinedCacheConfigurationNames() - Method in class org.infinispan.manager.DefaultCacheManager
 
getDefinedCacheCount() - Method in class org.infinispan.manager.DefaultCacheManager
 
getDefinedCacheNames() - Method in class org.infinispan.manager.DefaultCacheManager
 
getDefinedCaches() - Method in class org.infinispan.configuration.ConfigurationManager
 
getDefinedCaches() - Method in class org.infinispan.manager.CacheManagerInfo
 
getDefinedConfigurations() - Method in class org.infinispan.configuration.ConfigurationManager
 
getDelegate() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getDelegate() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
getDelegate() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getDeleteAllSql() - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
 
getDeleteAllSql() - Method in class org.infinispan.persistence.sql.QueriesJdbcStore.QueryTableOperations
 
getDeleteAllSql() - Method in class org.infinispan.persistence.sql.TableJdbcStore.TableTableOperations
 
getDeleteAllStatement() - Method in interface org.infinispan.persistence.jdbc.common.SqlManager
 
getDeleteRowSql() - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
 
getDeleteRowSql() - Method in class org.infinispan.persistence.sql.QueriesJdbcStore.QueryTableOperations
 
getDeleteRowSql() - Method in class org.infinispan.persistence.sql.TableJdbcStore.TableTableOperations
 
getDeleteStatement(List<String>) - Method in interface org.infinispan.persistence.jdbc.common.SqlManager
 
getDependents(T) - Method in class org.infinispan.util.DependencyGraph
Return the dependents
getDepth() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
getDepth() - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returns the current depth of the element.
getDescForKnownTypeIds() - Method in class org.infinispan.server.core.dataconversion.json.SecureTypeIdResolver
Deprecated.
 
getDescription() - Method in class org.infinispan.commons.stat.CounterMetricInfo
 
getDescription() - Method in class org.infinispan.commons.stat.DistributionSummaryMetricInfo
 
getDescription() - Method in class org.infinispan.commons.stat.FunctionTimerMetricInfo
 
getDescription() - Method in class org.infinispan.commons.stat.GaugeMetricInfo
 
getDescription() - Method in class org.infinispan.commons.stat.TimeGaugeMetricInfo
 
getDescription() - Method in class org.infinispan.commons.stat.TimerMetricInfo
 
getDescription() - Method in interface org.infinispan.commons.stat.MetricInfo
 
getDescription() - Method in class org.infinispan.factories.impl.MBeanMetadata.AttributeMetadata
 
getDescription() - Method in class org.infinispan.factories.impl.MBeanMetadata
 
getDescription() - Method in class org.infinispan.factories.impl.MBeanMetadata.OperationMetadata
 
getDescription() - Method in class org.infinispan.factories.impl.MBeanMetadata.OperationParameterMetadata
 
getDetail() - Method in exception class org.infinispan.commons.configuration.io.xml.XmlPullParserException
 
getDistinctLocationsCount(TopologyLevel) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getDistinctLocationsCount(TopologyLevel, Collection<Address>) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getDistribution(Object) - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
getDistributionForSegment(int) - Method in class org.infinispan.distribution.LocalizedCacheTopology
Deprecated, for removal: This API element is subject to removal in a future version.
getDistributionManager() - Method in interface org.infinispan.AdvancedCache
Retrieves a reference to the DistributionManager if the cache is configured to use Distribution.
getDistributionManager() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getDistributionManager() - Method in class org.infinispan.cache.impl.CacheImpl
 
getDistributionManager() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getDistributionManager() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getComponent(DistributionManager.class);
getDistributionManager() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getDomain() - Method in class org.infinispan.jmx.CacheJmxRegistration
Gets the domain name.
getDomain() - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
Gets the domain name.
getElement() - Method in enum org.infinispan.configuration.cache.StorageType
 
getElementText() - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
getElementText() - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationReader
 
getElementText() - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationReader
 
getElementText() - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader
 
GetEmbeddedCacheManagerAction - Class in org.infinispan.security.actions
GetEmbeddedCacheManagerAction.
GetEmbeddedCacheManagerAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetEmbeddedCacheManagerAction
 
getEmbeddedQueryEngine(Cache<?, ?>) - Static method in class org.infinispan.query.impl.ComponentRegistryUtils
 
getEmpty() - Method in interface org.infinispan.persistence.spi.MarshallableEntryFactory
 
getEnclosingProtocolServer() - Method in class org.infinispan.server.core.AbstractProtocolServer
 
getEnclosingProtocolServer() - Method in interface org.infinispan.server.core.ProtocolServer
Returns the enclosing ProtocolServer.
getEncoder() - Method in class org.infinispan.encoding.DataConversion
 
getEncoder() - Method in class org.infinispan.rest.RestServer
 
getEncoder() - Method in interface org.infinispan.server.core.ProtocolServer
Gets the encoder for this protocol server.
getEncoder() - Method in class org.infinispan.server.hotrod.HotRodServer
 
getEncoder() - Method in class org.infinispan.server.memcached.MemcachedServer
 
getEncoder(byte) - Static method in enum org.infinispan.server.hotrod.HotRodVersion
 
getEncoder(Class<? extends Encoder>, short) - Method in interface org.infinispan.marshall.core.EncoderRegistry
Deprecated, for removal: This API element is subject to removal in a future version.
getEncoder(Class<? extends Encoder>, short) - Method in class org.infinispan.marshall.core.EncoderRegistryImpl
 
getEncoderClass() - Method in class org.infinispan.encoding.DataConversion
 
getEncoderRegistry() - Method in class org.infinispan.rest.InvocationHelper
 
getEncoding() - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
 
getEncoding() - Method in class org.infinispan.commons.dataconversion.MediaType
 
getEngine(SSLContext, boolean, boolean) - Static method in class org.infinispan.commons.util.SslContextFactory
 
getEnlistedResources() - Method in class org.infinispan.commons.tx.TransactionImpl
 
getEnlistedSynchronization() - Method in class org.infinispan.commons.tx.TransactionImpl
 
getEntity() - Method in interface org.infinispan.rest.framework.impl.RestResponseBuilder
 
getEntity() - Method in class org.infinispan.rest.framework.impl.SimpleRestResponse.Builder
 
getEntity() - Method in class org.infinispan.rest.framework.impl.SimpleRestResponse
 
getEntity() - Method in interface org.infinispan.rest.framework.RestResponse
 
getEntity() - Method in class org.infinispan.rest.NettyRestResponse.Builder
 
getEntity() - Method in class org.infinispan.rest.NettyRestResponse
 
getEntityName() - Method in class org.infinispan.search.mapper.mapping.metamodel.IndexMetamodel
 
getEntityTypeName() - Method in interface org.infinispan.objectfilter.FilterSubscription
The fully qualified entity type name accepted by this filter.
getEntityTypeName() - Method in interface org.infinispan.objectfilter.ObjectFilter
The fully qualified entity type name accepted by this filter.
getEntries() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntriesEvictedEvent
Retrieves entries being evicted.
getEntries() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getEntries() - Method in class org.infinispan.server.hotrod.iteration.IterableIterationResult
 
getEntry(K) - Method in interface org.infinispan.multimap.api.embedded.MultimapCache
Retrieves a CacheEntry corresponding to a specific key in this multimap cache.
getEntry(K) - Method in class org.infinispan.multimap.impl.EmbeddedMultimapCache
 
getEntryCount() - Method in class org.infinispan.reactive.publisher.impl.PublisherHandler.SegmentResult
 
getEnumProperty(String, Class<T>, T) - Method in class org.infinispan.commons.util.TypedProperties
 
getEnumProperty(String, Class<T>, T, boolean) - Method in class org.infinispan.commons.util.TypedProperties
 
getErroneousAttributes() - Method in exception class org.infinispan.commons.CacheConfigurationException
Deprecated, for removal: This API element is subject to removal in a future version.
getEtagIfMatchHeader() - Method in interface org.infinispan.rest.framework.RestRequest
 
getEtagIfMatchHeader() - Method in class org.infinispan.rest.NettyRestRequest
 
getEtagIfNoneMatchHeader() - Method in interface org.infinispan.rest.framework.RestRequest
 
getEtagIfNoneMatchHeader() - Method in class org.infinispan.rest.NettyRestRequest
 
getEvent() - Method in class org.infinispan.notifications.cachelistener.EventWrapper
 
getEventData() - Method in interface org.infinispan.client.hotrod.event.ClientCacheEntryCustomEvent
Customized event data.
getEventData() - Method in class org.infinispan.client.hotrod.event.impl.CustomEventImpl
 
getEventStream() - Method in class org.infinispan.rest.resources.CacheResourceV2.BaseCacheListener
 
getEventStream() - Method in class org.infinispan.rest.resources.ContainerResource.ConfigurationListener
 
getEventType() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
getEventType() - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returns the type of the current event (START_TAG, END_TAG, TEXT, etc.)
getEventTypes() - Method in interface org.infinispan.objectfilter.FilterSubscription
The event types.
getEvictionManager() - Method in interface org.infinispan.AdvancedCache
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.1, will be removed without a replacement
getEvictionManager() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getEvictionManager() - Method in class org.infinispan.cache.impl.CacheImpl
 
getEvictionManager() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getEvictionManager() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getEvictions() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getEvictions() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getEvictions() - Method in class org.infinispan.stats.impl.StatsCollector
 
getEvictions() - Method in class org.infinispan.stats.impl.StatsImpl
 
getEvictions() - Method in interface org.infinispan.stats.Stats
 
getEvictionSize() - Method in class org.infinispan.cache.impl.CacheConfigurationMBean
 
getExactSizeIfKnown() - Method in class org.infinispan.commons.util.SpliteratorMapper
 
getException() - Method in class org.infinispan.remoting.responses.ExceptionResponse
 
getExecutionMode() - Method in interface org.infinispan.tasks.Task
Whether the task execution should be local - on one node or distributed - on all nodes.
getExecutor() - Method in class org.infinispan.persistence.InitializationContextImpl
Deprecated, for removal: This API element is subject to removal in a future version.
getExecutor() - Method in interface org.infinispan.persistence.spi.InitializationContext
Deprecated, for removal: This API element is subject to removal in a future version.
getExecutor() - Method in class org.infinispan.persistence.support.DelegatingInitializationContext
 
getExecutor() - Method in class org.infinispan.rest.InvocationHelper
 
getExecutor() - Method in class org.infinispan.server.core.AbstractProtocolServer
 
getExecutor() - Method in class org.infinispan.server.hotrod.HotRodDecoder
 
getExecutor() - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateProvider
 
getExecutor() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateProvider
Exposes non-blocking Executor to XSiteStatePushTask.
getExecutor() - Method in class org.infinispan.xsite.statetransfer.XSiteStateProviderImpl
 
getExecutor(Properties) - Method in interface org.infinispan.commons.executors.ExecutorFactory
 
getExecutor(Properties) - Method in class org.infinispan.executors.DefaultExecutorFactory
 
getExecutor(Properties) - Method in class org.infinispan.executors.WithinThreadExecutorFactory
 
getExecutor(Properties, AccessControlContext) - Method in interface org.infinispan.commons.executors.SecurityAwareExecutorFactory
 
getExecutor(Properties, AccessControlContext) - Method in class org.infinispan.executors.DefaultExecutorFactory
 
getExecutorService() - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
 
getExecutorService() - Method in class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
 
getExpectedMembers() - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
The members of the cache.
getExpectedMembers() - Method in class org.infinispan.topology.ClusterCacheStatus
 
getExpectedOwnedSegments(Address) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getExpectedPrimarySegments(Address) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getExpirationManager() - Method in interface org.infinispan.AdvancedCache
 
getExpirationManager() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getExpirationManager() - Method in class org.infinispan.cache.impl.CacheImpl
 
getExpirationManager() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getExpirationManager() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getExpiryTime() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
getExpiryTime() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
getExpiryTime() - Method in interface org.infinispan.container.entries.InternalCacheEntry
Only used with entries that have a lifespan, this determines when an entry is due to expire.
getExpiryTime() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
getExpiryTime() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
getExpiryTime() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
 
getExpiryTime() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
getExpiryTime() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
 
getExpiryTime() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
getExpiryTime() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue
 
getExpiryTime() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
getExpiryTime() - Method in class org.infinispan.container.entries.MortalCacheValue
 
getExpiryTime() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
getExpiryTime() - Method in class org.infinispan.container.entries.TransientCacheValue
 
getExpiryTime() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
getExpiryTime() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
getExternalExternalizer(GlobalMarshaller, Class<?>) - Static method in class org.infinispan.marshall.core.GlobalMarshaller
 
getExternalizer(Class<?>) - Method in class org.infinispan.jboss.marshalling.commons.SerializeWithExtFactory
 
getFactoryClazz() - Method in enum org.infinispan.commons.tx.lookup.LookupNames.TransactionManagerFactory
 
getFactoryName(String) - Method in interface org.infinispan.factories.impl.ModuleMetadataBuilder.ModuleBuilder
 
getFailedBackups() - Method in class org.infinispan.remoting.transport.AggregateBackupResponse
 
getFailedBackups() - Method in interface org.infinispan.remoting.transport.BackupResponse
 
getFailedBackups() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsBackupResponse
 
getFailureHandler() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
 
getFailureHandler() - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
 
getFailurePolicy(String) - Method in class org.infinispan.configuration.cache.SitesConfiguration
 
getFeature(String) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
Unknown properties are always returned as false
getFeature(String) - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returns the current value of the given feature.
getFeatures() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
getField(String, Class<?>) - Static method in class org.infinispan.commons.util.ReflectionUtil
 
getFile(int) - Method in class org.infinispan.persistence.sifs.FileProvider
 
getFile(File, String) - Method in class org.infinispan.io.GridFilesystem
Deprecated.
 
getFile(File, String, int) - Method in class org.infinispan.io.GridFilesystem
Deprecated.
 
getFile(String) - Method in class org.infinispan.io.GridFilesystem
Deprecated.
Returns the file denoted by pathname.
getFile(String, int) - Method in class org.infinispan.io.GridFilesystem
Deprecated.
Returns the file denoted by pathname.
getFile(String, String) - Method in class org.infinispan.io.GridFilesystem
Deprecated.
 
getFile(String, String, int) - Method in class org.infinispan.io.GridFilesystem
Deprecated.
 
getFileErrors(String) - Method in interface org.infinispan.query.remote.client.ProtobufMetadataManagerMBean
Gets the error messages (caused by parsing, linking, etc) associated to a *.proto schema file.
getFileForLog() - Method in class org.infinispan.persistence.sifs.FileProvider
 
getFileId() - Method in class org.infinispan.persistence.sifs.FileProvider.Handle
 
getFileIfOpen(int) - Method in class org.infinispan.persistence.sifs.FileProvider
 
getFileIterator() - Method in class org.infinispan.persistence.sifs.FileProvider
 
getFilenameFromURL(URL) - Static method in class org.infinispan.commons.maven.AbstractArtifact
 
getFileSize() - Method in class org.infinispan.persistence.sifs.FileProvider.Handle
 
getFileSize(int) - Method in class org.infinispan.persistence.sifs.FileProvider
 
getFilesWithErrors() - Method in interface org.infinispan.query.remote.client.ProtobufMetadataManagerMBean
Get the full names of all files with errors.
getFilter() - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
 
getFilter() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
getFilter() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
getFilter() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
getFilter(Object[]) - Method in interface org.infinispan.notifications.cachelistener.filter.CacheEventFilterFactory
Retrieves a cache event filter instance from this factory.
getFilterAnnotations() - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
 
getFilterAnnotations() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
getFilterAnnotations() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
getFilterConverter() - Method in interface org.infinispan.filter.KeyValueFilterConverterFactory
 
getFilterConverter() - Method in interface org.infinispan.filter.ParamKeyValueFilterConverterFactory
 
getFilterConverter(Object[]) - Method in interface org.infinispan.filter.ParamKeyValueFilterConverterFactory
Create an instance of KeyValueFilterConverter
getFilterConverter(Object[]) - Method in interface org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverterFactory
Retrieves a cache event filter and converter instance from this factory.
getFirstException() - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
getFirstResult() - Method in class org.infinispan.query.impl.QueryDefinition
 
getFlag() - Method in class org.infinispan.server.hotrod.HotRodHeader
 
getFlagInt() - Method in enum org.infinispan.client.hotrod.Flag
 
getFlags() - Method in interface org.infinispan.commands.FlagAffectedCommand
 
getFlags() - Method in class org.infinispan.globalstate.impl.CacheState
 
getFlags() - Method in interface org.infinispan.rest.framework.RestRequest
 
getFlags() - Method in class org.infinispan.rest.NettyRestRequest
 
getFlagsBitSet() - Method in class org.infinispan.cache.impl.DecoratedCache
 
getFlagsBitSet() - Method in class org.infinispan.commands.AbstractFlagAffectedCommand
 
getFlagsBitSet() - Method in interface org.infinispan.commands.FlagAffectedCommand
 
getFloatProperty(String) - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
 
getFloatProperty(String) - Method in interface org.infinispan.globalstate.ScopedPersistentState
Retrieves a float state property
getForceReturnValues() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getFormatId() - Method in class org.infinispan.commons.tx.XidImpl
 
getFreeMemoryInKb() - Method in interface org.infinispan.health.HostInfo
Gets free memory in KB.
getFreeMemoryKb() - Method in interface org.infinispan.health.jmx.HealthJMXExposer
Returns the amount of free memory (KB) in the host.
getFreeSpace() - Method in class org.infinispan.io.GridFile
Deprecated.
 
getFullHttpRequest() - Method in class org.infinispan.rest.NettyRestRequest
 
getGauge(T) - Method in class org.infinispan.commons.stat.GaugeMetricInfo
 
getGauge(T) - Method in class org.infinispan.commons.stat.TimeGaugeMetricInfo
 
getGc() - Method in class org.infinispan.commons.util.JVMMemoryInfoInfo
 
getGlobalComponentRegistry() - Method in class org.infinispan.factories.ComponentRegistry
 
getGlobalComponentRegistry() - Method in class org.infinispan.manager.DefaultCacheManager
 
getGlobalComponentRegistry() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, with no public API replacement
getGlobalComponentRegistry() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
GetGlobalComponentRegistryAction - Class in org.infinispan.security.actions
GetGlobalComponentRegistryAction.
GetGlobalComponentRegistryAction(EmbeddedCacheManager) - Constructor for class org.infinispan.security.actions.GetGlobalComponentRegistryAction
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.CachedThreadPoolConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.GlobalJmxConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.GlobalMetricsConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.GlobalStatePathConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.GlobalStorageConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.JGroupsConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.PrincipalRoleMapperConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.RolePermissionMapperConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.ScheduledThreadPoolConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.StackConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.StackFileConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.TemporaryGlobalStatePathConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.ThreadFactoryConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
 
getGlobalConfig() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
getGlobalConfiguration() - Method in class org.infinispan.configuration.ConfigurationManager
 
getGlobalConfiguration() - Method in class org.infinispan.configuration.serializing.ConfigurationHolder
 
getGlobalConfiguration() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getGlobalConfiguration() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getGlobalConfiguration() - Method in interface org.infinispan.persistence.spi.InitializationContext
Returns the global configuration
getGlobalConfiguration() - Method in class org.infinispan.persistence.support.DelegatingInitializationContext
 
getGlobalConfigurationAsProperties() - Method in class org.infinispan.manager.DefaultCacheManager
getGlobalConfigurationBuilder() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
getGlobalTransaction() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
getGlobalTransaction() - Method in interface org.infinispan.context.impl.TxInvocationContext
Returns the id of the transaction associated with the current call.
getGlobalTransaction() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
getGlobalTransaction() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getGlobalTransaction() - Method in interface org.infinispan.notifications.cachelistener.event.TransactionalEvent
 
getGlobalTransaction() - Method in class org.infinispan.server.hotrod.tx.table.TxState
 
getGlobalTransaction() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getGlobalTransaction() - Method in interface org.infinispan.transaction.xa.CacheTransaction
Returns the transaction identifier.
getGlobalTransaction(Transaction) - Method in class org.infinispan.transaction.impl.TransactionTable
 
getGlobalTransaction(Transaction) - Method in interface org.infinispan.transaction.TransactionTable
 
getGlobalTransactionId() - Method in class org.infinispan.commons.tx.XidImpl
 
getGlobalTransactionIdAsByteBuffer() - Method in class org.infinispan.commons.tx.XidImpl
 
getGroup(Object) - Method in interface org.infinispan.distribution.group.impl.GroupManager
Get the group for a given key
getGroup(Object) - Method in class org.infinispan.distribution.group.impl.GroupManagerImpl
 
getGroup(String) - Method in interface org.infinispan.AdvancedCache
It fetches all the keys which belong to the group.
getGroup(String) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getGroup(String) - Method in class org.infinispan.cache.impl.CacheImpl
 
getGroup(String) - Method in class org.infinispan.cache.impl.DecoratedCache
 
getGroup(String) - Method in class org.infinispan.cache.impl.EncoderCache
 
getGroup(String) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getGroup(String) - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getGroupName() - Method in class org.infinispan.jmx.CacheJmxRegistration
Gets the group name.
getGroupName() - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
Gets the group name.
getHash() - Method in class org.infinispan.distribution.ch.impl.HashFunctionPartitioner
 
getHashCode(long) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
Returns the hashCode of the address.
getHashCode(long) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
 
getHeader() - Method in class org.infinispan.persistence.sifs.EntryRecord
 
getHeader() - Method in class org.infinispan.server.hotrod.HotRodDecoder
 
getHeader(String) - Method in interface org.infinispan.rest.framework.impl.RestResponseBuilder
 
getHeader(String) - Method in class org.infinispan.rest.framework.impl.SimpleRestResponse.Builder
 
getHeader(String) - Method in class org.infinispan.rest.NettyRestResponse.Builder
 
getHeaderLength() - Method in class org.infinispan.persistence.sifs.EntryHeader
 
getHealth() - Method in class org.infinispan.manager.DefaultCacheManager
 
getHealth() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Returns an entry point for a Health Check API.
getHealth() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getHealthStatus() - Method in interface org.infinispan.health.ClusterHealth
Returns total cluster health.
getHeap() - Method in class org.infinispan.commons.util.JVMMemoryInfoInfo
 
getHitCountAccuracy() - Method in class org.infinispan.query.remote.json.JsonQueryRequest
 
getHitRatio() - Method in interface org.infinispan.stats.CacheContainerStats
Deprecated.
 
getHitRatio() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getHitRatio() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getHitRatio() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getHitRatio() - Method in class org.infinispan.stats.impl.StatsCollector
 
getHits() - Method in class org.infinispan.query.remote.json.JsonQueryResult
 
getHits() - Method in class org.infinispan.query.remote.json.ProjectedJsonResult
 
getHits() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getHits() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getHits() - Method in class org.infinispan.stats.impl.StatsCollector
 
getHits() - Method in class org.infinispan.stats.impl.StatsImpl
 
getHits() - Method in interface org.infinispan.stats.Stats
 
getHost() - Method in class org.infinispan.server.core.AbstractProtocolServer
 
getHost(InetAddress) - Method in class org.infinispan.server.hotrod.MultiHomedServerAddress
Return the interface address which matches the incoming address
getHost(InetAddress) - Method in interface org.infinispan.server.hotrod.ServerAddress
Returns the mapping for the
getHost(InetAddress) - Method in class org.infinispan.server.hotrod.SingleHomedServerAddress
 
getHostInfo() - Method in interface org.infinispan.health.Health
Gets basic information about the host.
getHostInfo() - Method in class org.infinispan.health.impl.HealthImpl
 
getHostName() - Method in class org.infinispan.server.core.transport.NettyTransport
 
getHostName() - Method in interface org.infinispan.server.core.transport.Transport
 
getHttpStatus() - Method in class org.infinispan.rest.NettyRestResponse.Builder
 
getId() - Method in class org.infinispan.cache.impl.BiFunctionMapper.Externalizer
 
getId() - Method in class org.infinispan.cache.impl.EncoderEntryMapper.Externalizer
 
getId() - Method in class org.infinispan.cache.impl.EncoderKeyMapper.Externalizer
 
getId() - Method in class org.infinispan.cache.impl.EncoderValueMapper.Externalizer
 
getId() - Method in class org.infinispan.cache.impl.FunctionMapper.Externalizer
 
getId() - Method in class org.infinispan.commands.CommandInvocationId
 
getId() - Method in class org.infinispan.commons.hash.MurmurHash3.Externalizer
 
getId() - Method in class org.infinispan.commons.io.ByteBufferImpl.Externalizer
 
getId() - Method in class org.infinispan.commons.marshall.AbstractExternalizer
 
getId() - Method in class org.infinispan.commons.marshall.AdminFlagExternalizer
 
getId() - Method in interface org.infinispan.commons.marshall.AdvancedExternalizer
Deprecated.
Returns an integer that identifies the externalizer type.
getId() - Method in class org.infinispan.commons.marshall.SingletonExternalizer
 
getId() - Method in class org.infinispan.commons.marshall.SuppliedExternalizer
 
getId() - Method in class org.infinispan.commons.marshall.WrappedByteArray.Externalizer
 
getId() - Method in class org.infinispan.commons.util.ImmutableListCopy.Externalizer
 
getId() - Method in class org.infinispan.commons.util.Immutables.ImmutableMapWrapperExternalizer
 
getId() - Method in class org.infinispan.commons.util.Immutables.ImmutableSetWrapperExternalizer
 
getId() - Method in class org.infinispan.container.entries.ImmortalCacheEntry.Externalizer
 
getId() - Method in class org.infinispan.container.entries.ImmortalCacheValue.Externalizer
 
getId() - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheEntry.Externalizer
 
getId() - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue.Externalizer
 
getId() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry.Externalizer
 
getId() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue.Externalizer
 
getId() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry.Externalizer
 
getId() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue.Externalizer
 
getId() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry.Externalizer
 
getId() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue.Externalizer
 
getId() - Method in class org.infinispan.container.entries.MortalCacheEntry.Externalizer
 
getId() - Method in class org.infinispan.container.entries.MortalCacheValue.Externalizer
 
getId() - Method in class org.infinispan.container.entries.RemoteMetadata.Externalizer
 
getId() - Method in class org.infinispan.container.entries.TransientCacheEntry.Externalizer
 
getId() - Method in class org.infinispan.container.entries.TransientCacheValue.Externalizer
 
getId() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry.Externalizer
 
getId() - Method in class org.infinispan.container.entries.TransientMortalCacheValue.Externalizer
 
getId() - Method in class org.infinispan.container.versioning.NumericVersion.Externalizer
 
getId() - Method in class org.infinispan.container.versioning.SimpleClusteredVersion.Externalizer
 
getId() - Method in class org.infinispan.context.Flag.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.impl.TopologyAwareConsistentHashFactory.Externalizer
 
getId() - Method in class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory.Externalizer
 
getId() - Method in class org.infinispan.encoding.DataConversion.Externalizer
 
getId() - Method in class org.infinispan.filter.AcceptAllKeyValueFilter.Externalizer
 
getId() - Method in class org.infinispan.filter.CacheFilters.CacheFiltersExternalizer
 
getId() - Method in class org.infinispan.filter.CompositeKeyValueFilter.Externalizer
 
getId() - Method in class org.infinispan.functional.impl.EntryViews.NoValueReadOnlyViewExternalizer
 
getId() - Method in class org.infinispan.functional.impl.EntryViews.ReadOnlySnapshotViewExternalizer
 
getId() - Method in class org.infinispan.functional.impl.EntryViews.ReadWriteSnapshotViewExternalizer
 
getId() - Method in class org.infinispan.functional.impl.StatsEnvelope.Externalizer
 
getId() - Method in class org.infinispan.globalstate.impl.CacheState.Externalizer
 
getId() - Method in class org.infinispan.globalstate.ScopedState.Externalizer
 
getId() - Method in class org.infinispan.globalstate.ScopeFilter.Externalizer
 
getId() - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.ConstantLambdaExternalizer
 
getId() - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.LambdaWithMetasExternalizer
 
getId() - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.SetValueIfEqualsReturnBooleanExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.ClassExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.CollectionExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.DoubleSummaryStatisticsExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.EnumExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.EnumSetExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.IntSummaryStatisticsExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.LongSummaryStatisticsExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.MapExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.EntryVersionParamExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.LifespanExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.MaxIdleExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.OptionalExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.ThrowableExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.TriangleAckExternalizer
 
getId() - Method in class org.infinispan.marshall.exts.UuidExternalizer
 
getId() - Method in class org.infinispan.metadata.EmbeddedMetadata.Externalizer
 
getId() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl.Externalizer
Deprecated.
 
getId() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent.Externalizer
 
getId() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerRemoveCallable.Externalizer
 
getId() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerReplicateCallable.Externalizer
 
getId() - Method in class org.infinispan.notifications.cachelistener.cluster.RemoteClusterListener
 
getId() - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventConverterAsConverter.Externalizer
 
getId() - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterAsKeyValueFilter.Externalizer
 
getId() - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverterAsKeyValueFilterConverter.Externalizer
 
getId() - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterAsCacheEventFilter.Externalizer
 
getId() - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter.Externalizer
 
getId() - Method in class org.infinispan.partitionhandling.AvailabilityMode.Externalizer
 
getId() - Method in class org.infinispan.persistence.remote.upgrade.MigrationTask.EntryWriterExternalizer
 
getId() - Method in class org.infinispan.query.impl.QueryDefinition.Externalizer
 
getId() - Method in class org.infinispan.reactive.publisher.PublisherReducers.PublisherReducersExternalizer
 
getId() - Method in class org.infinispan.reactive.publisher.PublisherTransformers.PublisherTransformersExternalizer
 
getId() - Method in class org.infinispan.remoting.responses.BiasRevocationResponse.Externalizer
 
getId() - Method in class org.infinispan.remoting.responses.CacheNotFoundResponse.Externalizer
 
getId() - Method in class org.infinispan.remoting.responses.ExceptionResponse.Externalizer
 
getId() - Method in class org.infinispan.remoting.responses.SuccessfulResponse.Externalizer
 
getId() - Method in class org.infinispan.remoting.responses.UnsuccessfulResponse.Externalizer
 
getId() - Method in class org.infinispan.remoting.responses.UnsureResponse.Externalizer
 
getId() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress.Externalizer
 
getId() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress.Externalizer
 
getId() - Method in interface org.infinispan.server.hotrod.iteration.IterationState
 
getId() - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository.InfinispanSession
 
getId() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl.DistributedCacheStatsCallableExternalizer
 
getId() - Method in class org.infinispan.stream.impl.CacheBiConsumers.Externalizer
 
getId() - Method in class org.infinispan.stream.impl.CacheIntermediatePublisher.ReducerExternalizer
 
getId() - Method in class org.infinispan.stream.impl.CacheStreamIntermediateReducer.ReducerExternalizer
 
getId() - Method in class org.infinispan.stream.StreamMarshalling.StreamMarshallingExternalizer
 
getId() - Method in class org.infinispan.topology.CacheJoinInfo.Externalizer
 
getId() - Method in class org.infinispan.topology.CacheStatusResponse.Externalizer
 
getId() - Method in class org.infinispan.topology.CacheTopology.Externalizer
 
getId() - Method in class org.infinispan.topology.ManagerStatusResponse.Externalizer
 
getId() - Method in class org.infinispan.topology.PersistentUUID.Externalizer
 
getId() - Method in class org.infinispan.transaction.xa.GlobalTransaction.Externalizer
 
getId() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
getId() - Method in class org.infinispan.util.IntSetExternalizer
 
getId() - Method in class org.infinispan.util.KeyValuePair.Externalizer
 
getId() - Method in class org.infinispan.xsite.commands.remote.XSiteRequestExternalizer
 
getId() - Method in class org.infinispan.xsite.statetransfer.XSiteState.XSiteStateExternalizer
 
getId(MediaType) - Static method in class org.infinispan.commons.dataconversion.MediaTypeIds
 
getIdentifier() - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
 
getIdentifier() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
getIdentifier() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
getIdentifier() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
getIdleConnectionCount() - Method in interface org.infinispan.client.hotrod.jmx.RemoteCacheManagerMXBean
Returns the number of idle connections
getIdleConnectionCount() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
getIdleTimeout() - Method in class org.infinispan.server.core.transport.NettyTransport
 
getIdleTimeout() - Method in interface org.infinispan.server.core.transport.Transport
 
getIfModifiedSinceHeader() - Method in interface org.infinispan.rest.framework.RestRequest
 
getIfModifiedSinceHeader() - Method in class org.infinispan.rest.NettyRestRequest
 
getIfUnmodifiedSinceHeader() - Method in interface org.infinispan.rest.framework.RestRequest
 
getIfUnmodifiedSinceHeader() - Method in class org.infinispan.rest.NettyRestRequest
 
getIgnoredCaches() - Method in interface org.infinispan.server.core.ServerStateManager
 
getIndex(ExtendedStatistic) - Method in class org.infinispan.extendedstats.container.BaseExtendedStatisticsContainer
 
getIndex(ExtendedStatistic) - Method in class org.infinispan.extendedstats.container.LocalExtendedStatisticsContainer
 
getIndex(ExtendedStatistic) - Method in class org.infinispan.extendedstats.container.RemoteExtendedStatisticsContainer
 
getIndexedClassNames() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getIndexer(AdvancedCache<?, ?>) - Static method in class org.infinispan.query.impl.ComponentRegistryUtils
 
getIndexer(Cache<K, V>) - Static method in class org.infinispan.query.Search
 
getIndexLocation() - Method in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
 
getIndexName() - Method in class org.infinispan.search.mapper.mapping.metamodel.IndexMetamodel
 
getIndexSize(String) - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getInDoubtTransactionInfo() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Same as RecoveryManager.getInDoubtTransactionInfoFromCluster(), but only returns transactions from the local node.
getInDoubtTransactionInfo() - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
getInDoubtTransactionInfoFromCluster() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Returns a Set containing all the in-doubt transactions from the cluster, including the local node.
getInDoubtTransactionInfoFromCluster() - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
getInDoubtTransactions() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Local call that returns a list containing:
getInDoubtTransactions() - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
getInDoubtTransactionsMap() - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
getInitializer() - Method in class org.infinispan.rest.RestServer
 
getInitializer() - Method in interface org.infinispan.server.core.ProtocolServer
Returns a pipeline factory
getInitializer() - Method in class org.infinispan.server.hotrod.HotRodServer
 
getInitializer() - Method in class org.infinispan.server.memcached.MemcachedServer
 
getInitialValue() - Method in class org.infinispan.commons.configuration.attributes.Attribute
 
getInput(File) - Method in class org.infinispan.io.GridFilesystem
Deprecated.
Opens an InputStream for reading from the given file.
getInput(String) - Method in class org.infinispan.io.GridFilesystem
Deprecated.
Opens an InputStream for reading from the file denoted by pathname.
getInputEncoding() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
getInputEncoding() - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returns the input encoding if known, null otherwise.
getInstance() - Static method in class org.infinispan.client.hotrod.transaction.lookup.GenericTransactionManagerLookup
 
getInstance() - Static method in class org.infinispan.client.hotrod.transaction.lookup.RemoteTransactionManagerLookup
 
getInstance() - Static method in class org.infinispan.client.hotrod.transaction.manager.RemoteTransactionManager
 
getInstance() - Static method in class org.infinispan.commons.hash.MurmurHash3
 
getInstance() - Static method in class org.infinispan.commons.jdkspecific.ProcessInfo
 
getInstance() - Static method in class org.infinispan.commons.util.concurrent.BlockingRejectedExecutionHandler
 
getInstance() - Static method in class org.infinispan.commons.util.concurrent.LifecycleRejectedExecutionHandler
 
getInstance() - Static method in class org.infinispan.commons.util.concurrent.NonBlockingRejectedExecutionHandler
 
getInstance() - Static method in class org.infinispan.commons.util.NullValue
 
getInstance() - Static method in class org.infinispan.container.entries.ClearCacheEntry
 
getInstance() - Static method in class org.infinispan.container.entries.NullCacheEntry
 
getInstance() - Static method in class org.infinispan.container.versioning.irac.NoOpIracTombstoneManager
 
getInstance() - Static method in class org.infinispan.container.versioning.irac.NoOpIracVersionGenerator
 
getInstance() - Static method in class org.infinispan.counter.api.PropertyFormatter
 
getInstance() - Static method in class org.infinispan.distribution.ch.impl.SingleSegmentKeyPartitioner
 
getInstance() - Static method in class org.infinispan.filter.AcceptAllKeyValueFilter
 
getInstance() - Method in interface org.infinispan.objectfilter.ObjectFilter.FilterResult
Returns the matched object.
getInstance() - Static method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
getInstance() - Method in class org.infinispan.query.remote.client.FilterResult
Returns the matched object.
getInstance() - Static method in class org.infinispan.spring.common.session.PrincipalNameResolver
 
getInstance() - Static method in class org.infinispan.transaction.tm.BatchModeTransactionManager
 
getInstance() - Static method in class org.infinispan.transaction.tm.EmbeddedTransactionManager
 
getInstance() - Static method in class org.infinispan.util.concurrent.locks.impl.NoOpPendingLockManager
 
getInstance() - Static method in exception class org.infinispan.xsite.irac.DiscardUpdateException
 
getInstance() - Static method in class org.infinispan.xsite.metrics.NoOpXSiteMetricsCollector
 
getInstance() - Static method in class org.infinispan.xsite.spi.AlwaysRemoveXSiteEntryMergePolicy
 
getInstance() - Static method in class org.infinispan.xsite.spi.DefaultXSiteEntryMergePolicy
 
getInstance() - Static method in class org.infinispan.xsite.spi.PreferNonNullXSiteEntryMergePolicy
 
getInstance() - Static method in class org.infinispan.xsite.spi.PreferNullXSiteEntryMergePolicy
 
getInstance() - Method in enum org.infinispan.xsite.spi.XSiteMergePolicy
 
getInstance() - Static method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateProvider
 
getInstance() - Static method in class org.infinispan.xsite.status.NoOpTakeOfflineManager
 
getInstance() - Static method in class org.infinispan.xsite.status.OfflineSiteStatus
 
getInstance() - Static method in class org.infinispan.xsite.status.OnlineSiteStatus
 
getInstance(Class<T>) - Static method in class org.infinispan.commons.util.Util
Instantiates a class by first attempting a static factory method named getInstance() on the class and then falling back to an empty constructor.
getInstance(String, ClassLoader) - Static method in class org.infinispan.commons.util.Util
Instantiates a class based on the class name provided.
getInstance(ComponentRegistry, Configuration) - Static method in class org.infinispan.factories.InterceptorChainFactory
Deprecated, for removal: This API element is subject to removal in a future version.
Since 9.4, not used.
getInstanceStrict(Class<T>) - Static method in class org.infinispan.commons.util.Util
Similar to Util.getInstance(Class) except that exceptions are propagated to the caller.
getInstanceStrict(String, ClassLoader) - Static method in class org.infinispan.commons.util.Util
Similar to Util.getInstance(String, ClassLoader) except that exceptions are propagated to the caller.
getInstanceSupplier(String, ClassLoader) - Static method in class org.infinispan.commons.util.Util
 
getInstantiationMode() - Method in interface org.infinispan.tasks.Task
Whether tasks should reuse a single instance or create a new instance per execution.
getIntAccessibly(Field, Object) - Static method in class org.infinispan.commons.util.ReflectionUtil
 
getIntegration() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
 
getInteralExternalizer(GlobalMarshaller, Class<?>) - Static method in class org.infinispan.marshall.core.GlobalMarshaller
 
getInterceptorChain() - Method in class org.infinispan.factories.ComponentRegistry
 
getInterceptors() - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
 
getInterceptors() - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
 
getInternalCacheNames() - Method in class org.infinispan.registry.impl.InternalCacheRegistryImpl
 
getInternalDataContainer() - Method in class org.infinispan.factories.ComponentRegistry
 
getInternalEntryFactory() - Method in class org.infinispan.factories.ComponentRegistry
 
getInternalId() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
getInternalId() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfo
 
getInternalMarshaller() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getComponent(StreamingMarshaller.class, INTERNAL_MARSHALLER);
getInternalMetadata() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
getInternalMetadata() - Method in interface org.infinispan.container.entries.CacheEntry
 
getInternalMetadata() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
getInternalMetadata() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
getInternalMetadata() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getInternalMetadata() - Method in class org.infinispan.persistence.sifs.EntryRecord
 
getInternalMetadata() - Method in interface org.infinispan.persistence.spi.MarshallableEntry
 
getInternalMetadataBytes() - Method in interface org.infinispan.persistence.spi.MarshallableEntry
 
getInternalMetadataBytes() - Method in interface org.infinispan.persistence.spi.MarshalledValue
 
getIntProperty(String) - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
 
getIntProperty(String) - Method in interface org.infinispan.globalstate.ScopedPersistentState
Retrieves an integer state property
getIntProperty(String, int) - Method in class org.infinispan.commons.util.TypedProperties
 
getIntProperty(String, int, boolean) - Method in class org.infinispan.commons.util.TypedProperties
 
getIntSet() - Method in class org.infinispan.commons.util.BloomFilter
 
getIntStatistic(String) - Method in class org.infinispan.client.hotrod.impl.ServerStatisticsImpl
 
getIntStatistic(String) - Method in interface org.infinispan.client.hotrod.ServerStatistics
 
getInvalidations() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getInvalidations() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getInvocation() - Method in class org.infinispan.rest.framework.impl.LookupResultImpl
 
getInvocation() - Method in interface org.infinispan.rest.framework.LookupResult
Returns the invocation to carry out a RestRequest
getInvocationContext(boolean, int) - Method in class org.infinispan.functional.impl.ReadOnlyMapImpl
 
getInvocationContext(boolean, int) - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
 
getInvocationContext(boolean, int) - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
getInvocationContextFactory() - Method in class org.infinispan.factories.ComponentRegistry
 
getInvocationHelper() - Method in class org.infinispan.rest.RestServer
 
getInvocations() - Method in interface org.infinispan.rest.framework.ResourceHandler
Return the Invocations handled by this ResourceHandler.
getInvocations() - Method in class org.infinispan.rest.resources.CacheResourceV2
 
getInvocations() - Method in class org.infinispan.rest.resources.ClusterResource
 
getInvocations() - Method in class org.infinispan.rest.resources.ContainerResource
 
getInvocations() - Method in class org.infinispan.rest.resources.CounterResource
 
getInvocations() - Method in class org.infinispan.rest.resources.LoggingResource
 
getInvocations() - Method in class org.infinispan.rest.resources.MetricsResource
 
getInvocations() - Method in class org.infinispan.rest.resources.ProtobufResource
 
getInvocations() - Method in class org.infinispan.rest.resources.RedirectResource
 
getInvocations() - Method in class org.infinispan.rest.resources.SearchAdminResource
 
getInvocations() - Method in class org.infinispan.rest.resources.SecurityResource
 
getInvocations() - Method in class org.infinispan.rest.resources.ServerResource
 
getInvocations() - Method in class org.infinispan.rest.resources.StaticContentResource
 
getInvocations() - Method in class org.infinispan.rest.resources.TasksResource
 
getInvocations() - Method in class org.infinispan.rest.resources.XSiteResource
 
getIracManager() - Method in class org.infinispan.factories.ComponentRegistry
 
getIracManager() - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateProvider
 
getIracManager() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateProvider
getIracManager() - Method in class org.infinispan.xsite.statetransfer.XSiteStateProviderImpl
 
getIracMetadata(int) - Method in class org.infinispan.remoting.responses.PrepareResponse
 
getIracMetadata(Object) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
getIracMetadata(Object) - Method in class org.infinispan.transaction.impl.LocalTransaction
 
getIracTombstoneManager() - Method in class org.infinispan.factories.ComponentRegistry
 
getIracVersionFromCacheEntry(CacheEntry<?, ?>) - Static method in class org.infinispan.util.IracUtils
 
getIracVersionGenerator() - Method in class org.infinispan.factories.ComponentRegistry
 
getIterationManager() - Method in class org.infinispan.server.hotrod.HotRodServer
 
getJavaCharset() - Method in class org.infinispan.rest.operations.mediatypes.Charset
Creates Java Charset from this object.
getJavaClass() - Method in class org.infinispan.commons.dataconversion.MediaType$___Marshaller_f2fc301543ca54d0326b5d8ce3b7199226a678253252e7ac46f1fad54bd90568
 
getJavaClass() - Method in class org.infinispan.commons.marshall.WrappedByteArray$___Marshaller_dd5f1f82b70f419159a02b94c2ffa39a035efa36bc3f94e3bec8f1fb78d5e078
 
getJavaClass() - Method in class org.infinispan.commons.util.KeyValueWithPrevious$___Marshaller_9145896a24b67e12a03ab245b027743214e8f0a00cff4e94594e6701c8f07ff1
 
getJavaClass() - Method in class org.infinispan.commons.util.NullValue$___Marshaller_a83283d4dbbe8b8520f457699d99f19344b973d04786829de1e22c08915e6e56
 
getJavaClass() - Method in class org.infinispan.container.entries.RemoteMetadata$___Marshaller_4cb4a1b59ce257eb4994240cafc1894764116cb17c3875df246d2943dcbdce0d
 
getJavaClass() - Method in class org.infinispan.container.versioning.irac.IracEntryVersion$___Marshaller_1d33e9a17b1520460201f2d05b09e88a3eb2df8efbb49f8a10103069f8b573d5
 
getJavaClass() - Method in class org.infinispan.container.versioning.irac.MapEntry$___Marshaller_37a121f54771729f5bc90dae7b319161c44a1e9491f8af866c7aba312bf9651e
 
getJavaClass() - Method in class org.infinispan.container.versioning.irac.TopologyIracVersion$___Marshaller_14f804c9dae1c80820c4a124ae0decae2266c24993f77973d0fee34d7db215d2
 
getJavaClass() - Method in class org.infinispan.container.versioning.NumericVersion$___Marshaller_54e14f07f0b2d32fc02dc14b15442c6b41ee1d50304f1e61ddb56d9feb6975b1
 
getJavaClass() - Method in class org.infinispan.container.versioning.SimpleClusteredVersion$___Marshaller_f7402494821fa8e2ee025bf7d4a4b60322db5a0eb2018b6aa5836c002c8e07b7
 
getJavaClass() - Method in class org.infinispan.counter.api.CounterConfiguration$___Marshaller_200ccbe7f9bd55cd3d0f90bae5ea29adc0a29590c936038020329c50ede7e29f
 
getJavaClass() - Method in class org.infinispan.counter.api.CounterState$___Marshaller_93aa5d27c0d57954ec79247b055254b02d5c87a64e0764e392772b387eb7542d
 
getJavaClass() - Method in class org.infinispan.counter.api.CounterType$___Marshaller_4dd4ef0972bf79fd96da56b8ce9348d84b1c42596acd7df3abf86c5e467887f5
 
getJavaClass() - Method in class org.infinispan.counter.api.Storage$___Marshaller_ed04a8616efd062a7c88e9e578efa97c99224ac3211dd20ca76376455f84a9ae
 
getJavaClass() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata$___Marshaller_d639102389197d7d9d67594c1f4f7cd51d35bdb2ed77d89d90c58b8d63ad3ab0
 
getJavaClass() - Method in class org.infinispan.metadata.EmbeddedExpirableMetadata$___Marshaller_57542ccf09e811f3460251c589ca05aed449dbbc1765661fa3851dddaac8dd71
 
getJavaClass() - Method in class org.infinispan.metadata.EmbeddedLifespanExpirableMetadata$___Marshaller_8da6d90d1f279b201c958e38c4b73ab7f2712dc1dc20b32c21334eacdfc6fd4b
 
getJavaClass() - Method in class org.infinispan.metadata.EmbeddedMaxIdleExpirableMetadata$___Marshaller_6887b83200c53e83a8233e38450ed44c3191b4968b578e16a63c12add76959ed
 
getJavaClass() - Method in class org.infinispan.metadata.EmbeddedMetadata$___Marshaller_d44c815cc3de96e45a01e06b569541e480035dc14f5499e3f3edc3fa7c6fe67
 
getJavaClass() - Method in class org.infinispan.metadata.impl.IracMetadata$___Marshaller_cf0a6ded5e9e5b145ea5821d40d9659677d03a5df3e405762cc053e3bbb15e64
 
getJavaClass() - Method in class org.infinispan.metadata.impl.PrivateMetadata$___Marshaller_2707b1b527c228e45215e24669c8ab752e6a1689fb6e3510d925b1e899b8ee06
 
getJavaClass() - Method in class org.infinispan.multimap.impl.Bucket$___Marshaller_686dc55729a31972fef7d4722c2e90e0421789a20c8a9d4176be1714ac94d28c
 
getJavaClass() - Method in class org.infinispan.persistence.rocksdb.ExpiryBucket$___Marshaller_c1bbd47a4aa119c6b21703d5030cb689b65205a24de2638d9c9f2ce1f3a222f6
 
getJavaClass() - Method in class org.infinispan.persistence.rocksdb.MetadataImpl$___Marshaller_b44737a8b6b24b0cd6de162703366becf9e68a2ce287544774acbaaa7268814
 
getJavaClass() - Method in class org.infinispan.query.impl.KnownClassKey$___Marshaller_b1b9e11dd7f2c702e88c180bbc686b798fa5794bc27ae13347aacd2e4a465e3d
 
getJavaClass() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress$___Marshaller_fff84712bca7d00f611bdc3fd76a067b0a3a1f4981a7d3aad1c9257d9a5d7324
 
getJavaClass() - Method in class org.infinispan.rest.distribution.CacheDistributionInfo$___Marshaller_d29d2c8791a59bb0952e36da57e31d3d06e79a149845ac44d334bd095efcb62c
 
getJavaClass() - Method in class org.infinispan.rest.distribution.CacheDistributionRunnable$___Marshaller_45f1040aff503b6010c6b926057475925f0a64804eab6e8f0d6f4ba5ddce3a36
 
getJavaClass() - Method in class org.infinispan.rest.distribution.NodeDistributionInfo$___Marshaller_50bcddd047df75d5979a51292e9db600cc21f4e1e18d6fe36b39e9a26196ea0e
 
getJavaClass() - Method in class org.infinispan.security.AuthorizationPermission$___Marshaller_e4a67ef18a1f2ebc30b0d1e396f24e2098535911da768fa734361c9903b14240
 
getJavaClass() - Method in class org.infinispan.security.impl.CacheRoleImpl$___Marshaller_8ebe2292503551beeebd9f0cc1e432a19521b4115fff99f8859a58acb74d6d74
 
getJavaClass() - Method in class org.infinispan.security.impl.SubjectAdapter$___Marshaller_75e0224333a6eeeafc364cef114fe68e65410956aa87814e98e0722f4d8a588d
 
getJavaClass() - Method in class org.infinispan.security.mappers.RoleSet$___Marshaller_2fda1a742ac008d38f1c852650748615da7cca98a60afaa87bb162ebc6157665
 
getJavaClass() - Method in class org.infinispan.server.core.backup.resources.CacheBackupEntry$___Marshaller_b2d0dee2aac68dcec862a9e304f7e24daf8a89e2925ed0f1902a4f7e597df134
 
getJavaClass() - Method in class org.infinispan.server.core.backup.resources.CounterBackupEntry$___Marshaller_2af248d5cc134577501d751e859e0021aca6b7f47edf43acc378580b56297af6
 
getJavaClass() - Method in class org.infinispan.server.memcached.MemcachedMetadata$___Marshaller_582bc1c0173638c6bfeeee0149c471f14236f1b1d719f55da181f90c415f8bf1
 
getJavaClass() - Method in class org.infinispan.spring.common.session.MapSessionProtoAdapter.SessionAttributeRawMarshaller
 
getJavaClass() - Method in class org.infinispan.spring.common.session.MapSessionProtoAdapter$___Marshaller_71442e7b0d28786c1f10a1743da12fcd08d64dc0b8a798e5658e855284c87eee
 
getJavaClass() - Method in class org.infinispan.spring.common.session.SessionAttribute$___Marshaller_5dcef48338013ff033aa3ebdfe72b959048a23f1ab1b4e671508996ffee0358b
 
getJavaClass() - Method in class org.infinispan.spring.common.session.SessionUpdateRemappingFunctionProtoAdapter$___Marshaller_9c0544bb624c0af23e5a5e11e8120017e963b2cee452968f8524051818abdb2b
 
getJavaClass() - Method in class org.infinispan.util.ByteString$___Marshaller_8e599c0fc1e9a512b7cdb7c05fb5529744ecac265708e69fd30c5e989237252a
 
getJavaClassName() - Method in class org.infinispan.search.mapper.mapping.metamodel.IndexMetamodel
 
getJBossMarshaller(ClassLoader, ClassAllowList) - Static method in class org.infinispan.commons.util.Util
 
getJGroupsAddress() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
 
getJGroupsChannel(Properties) - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelLookup
Deprecated.
Retrieves a JGroups channel.
getJmxDomain() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getJmxName() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getJmxObjectName() - Method in class org.infinispan.factories.impl.MBeanMetadata
 
getJndiLookup() - Method in enum org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
 
getJoiners() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
getJoiners() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.SitesViewChangedEvent
 
getJoinInfo() - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
 
getJoinInfo() - Method in class org.infinispan.topology.ClusterCacheStatus
 
getKeepAliveTime() - Method in class org.infinispan.executors.ManageableExecutorService
 
getKey() - Method in class org.infinispan.affinity.impl.RndKeyGenerator
 
getKey() - Method in interface org.infinispan.affinity.KeyGenerator
 
getKey() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntryChange
 
getKey() - Method in interface org.infinispan.client.hotrod.event.ClientCacheEntryCreatedEvent
Created cache entry's key.
getKey() - Method in interface org.infinispan.client.hotrod.event.ClientCacheEntryExpiredEvent
Created cache entry's key.
getKey() - Method in interface org.infinispan.client.hotrod.event.ClientCacheEntryModifiedEvent
Modifiedcache entry's key.
getKey() - Method in interface org.infinispan.client.hotrod.event.ClientCacheEntryRemovedEvent
Created cache entry's key.
getKey() - Method in class org.infinispan.client.hotrod.event.impl.CreatedEventImpl
 
getKey() - Method in class org.infinispan.client.hotrod.event.impl.ExpiredEventImpl
 
getKey() - Method in class org.infinispan.client.hotrod.event.impl.ModifiedEventImpl
 
getKey() - Method in class org.infinispan.client.hotrod.event.impl.RemovedEventImpl
 
getKey() - Method in interface org.infinispan.commands.DataCommand
 
getKey() - Method in class org.infinispan.commons.util.AbstractMap.SimpleEntry
 
getKey() - Method in class org.infinispan.commons.util.KeyValueWithPrevious
 
getKey() - Method in class org.infinispan.commons.util.SegmentAwareKey
 
getKey() - Method in class org.infinispan.commons.util.SimpleImmutableEntry
 
getKey() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
getKey() - Method in interface org.infinispan.container.entries.CacheEntry
Retrieves the key to this entry
getKey() - Method in class org.infinispan.container.entries.ClearCacheEntry
 
getKey() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
getKey() - Method in class org.infinispan.container.entries.NullCacheEntry
 
getKey() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getKey() - Method in class org.infinispan.container.versioning.irac.IracTombstoneInfo
 
getKey() - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
 
getKey() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
getKey() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryEvent
 
getKey() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getKey() - Method in class org.infinispan.notifications.cachelistener.EventWrapper
 
getKey() - Method in interface org.infinispan.objectfilter.ObjectFilter.FilterResult
Returns the key of the matched object.
getKey() - Method in class org.infinispan.persistence.modifications.Remove
 
getKey() - Method in class org.infinispan.persistence.modifications.Store
 
getKey() - Method in class org.infinispan.persistence.sifs.EntryRecord
 
getKey() - Method in interface org.infinispan.persistence.spi.MarshallableEntry
Returns the same key as MarshallableEntry.getKeyBytes(), but unmarshalled.
getKey() - Method in exception class org.infinispan.transaction.WriteSkewException
 
getKey() - Method in class org.infinispan.util.KeyValuePair
 
getKey() - Method in interface org.infinispan.xsite.irac.IracManagerKeyInfo
 
getKey() - Method in class org.infinispan.xsite.irac.IracManagerKeyInfoImpl
 
getKey(long) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
Returns the key of the address.
getKey(long) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
 
getKeyAlias() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getKeyBytes() - Method in interface org.infinispan.persistence.spi.MarshallableEntry
Returns the key in serialized format.
getKeyDataConversion() - Method in interface org.infinispan.AdvancedCache
 
getKeyDataConversion() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getKeyDataConversion() - Method in class org.infinispan.cache.impl.BiFunctionMapper
 
getKeyDataConversion() - Method in class org.infinispan.cache.impl.CacheImpl
 
getKeyDataConversion() - Method in class org.infinispan.cache.impl.EncoderCache
 
getKeyDataConversion() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getKeyDataConversion() - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
 
getKeyDataConversion() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
getKeyDataConversion() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
getKeyDataConversion() - Method in class org.infinispan.notifications.cachelistener.ListenerHolder
 
getKeyDataConversion() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getKeyForAddress(Address) - Method in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
 
getKeyForAddress(Address) - Method in interface org.infinispan.affinity.KeyAffinityService
Returns a key that will be distributed on the cluster node identified by address.
getKeyLockOwner() - Method in interface org.infinispan.util.concurrent.locks.RemoteLockCommand
It returns the lock owner of the key.
getKeyManagerFactory() - Method in class org.infinispan.commons.util.SslContextFactory
 
getKeyMapper() - Method in class org.infinispan.persistence.support.AbstractSegmentedAdvancedLoadWriteStore
 
getKeyMapper() - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
 
getKeyMapping(String) - Method in class org.infinispan.persistence.keymappers.DefaultTwoWayKey2StringMapper
 
getKeyMapping(String) - Method in interface org.infinispan.persistence.keymappers.TwoWayKey2StringMapper
Maps a String back to its original key
getKeyMapping(String) - Method in class org.infinispan.persistence.keymappers.WrappedByteArrayOrPrimitiveMapper
 
getKeyMediaType() - Method in class org.infinispan.server.hotrod.HotRodHeader
 
getKeyPartitioner() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getKeyPartitioner() - Method in interface org.infinispan.persistence.spi.InitializationContext
The configured partitioner that can be used to determine which segment a given key belongs to.
getKeyPartitioner() - Method in class org.infinispan.persistence.support.DelegatingInitializationContext
 
getKeyPartitioner(Cache<?, ?>) - Static method in class org.infinispan.query.impl.ComponentRegistryUtils
 
getKeySizeEstimate() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
Deprecated, for removal: This API element is subject to removal in a future version.
Since 12.0, does nothing and will be removed in 15.0
getKeysToLock() - Method in interface org.infinispan.util.concurrent.locks.RemoteLockCommand
It returns a Collection with the keys to be lock.
getKeyStorageMediaType() - Method in class org.infinispan.encoding.impl.StorageConfigurationManager
 
getKeyStoreFileName() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getKeysToRemove() - Method in class org.infinispan.persistence.support.BatchModification
 
getKeyStorePassword() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getKeyStoreType() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getKeyTransformationHandler(Cache<?, ?>) - Static method in class org.infinispan.query.impl.ComponentRegistryUtils
 
getKeyType() - Method in class org.infinispan.client.hotrod.DataFormat
 
getKeyType() - Method in interface org.infinispan.client.hotrod.marshall.MediaTypeMarshaller
The decided type for the key.
getKeyType() - Method in interface org.infinispan.distribution.group.Grouper
 
getKeyWrapper() - Method in class org.infinispan.encoding.impl.StorageConfigurationManager
 
getKlass() - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
 
getKPercentile(int) - Method in class org.infinispan.extendedstats.percentiles.ReservoirSampler
 
getLargestPoolSize() - Method in class org.infinispan.executors.ManageableExecutorService
 
getLastAccessedTime() - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository.InfinispanSession
 
getLastResetTime() - Method in class org.infinispan.extendedstats.container.StatisticsSnapshot
 
getLastStableTopology() - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
getLastStableTopology() - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
Deprecated.
getLastStableTopology() - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
getLastUsed() - Method in class org.infinispan.client.hotrod.impl.MetadataValueImpl
 
getLastUsed() - Method in class org.infinispan.client.hotrod.impl.VersionedMetadataImpl
 
getLastUsed() - Method in interface org.infinispan.client.hotrod.Metadata
 
getLastUsed() - Method in interface org.infinispan.container.entries.CacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
getLastUsed() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
getLastUsed() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
 
getLastUsed() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue
 
getLastUsed() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.TransientCacheValue
 
getLastUsed() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
getLastUsed() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
getLastUsed() - Method in class org.infinispan.persistence.sifs.EntryMetadata
 
getLastUsed() - Method in class org.infinispan.persistence.sifs.EntryRecord
 
getLastUsed() - Method in interface org.infinispan.persistence.spi.MarshalledValue
 
getLastUsedHeader() - Method in interface org.infinispan.rest.framework.RestRequest
 
getLastUsedHeader() - Method in class org.infinispan.rest.NettyRestRequest
 
getLazy(String, Class<U>, boolean) - Method in class org.infinispan.factories.impl.WireContext
 
getLeastSignificantBits() - Method in class org.infinispan.topology.PersistentUUID
 
getLeavers() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
getLeavers() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.SitesViewChangedEvent
 
getLegacyQueryStatistics() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getLength() - Method in interface org.infinispan.commons.io.ByteBuffer
Length bytes, starting from offset, within the underlying byte[] (as returned by ByteBuffer.getBuf() are owned by this buffer instance.
getLength() - Method in class org.infinispan.commons.io.ByteBufferImpl
 
getLength() - Method in class org.infinispan.commons.marshall.WrappedByteArray
 
getLength() - Method in interface org.infinispan.commons.marshall.WrappedBytes
The length of the underlying wrapped bytes.
getLength() - Method in class org.infinispan.io.GridFile.Metadata
Deprecated.
 
getLifespan() - Method in class org.infinispan.client.hotrod.impl.MetadataValueImpl
 
getLifespan() - Method in class org.infinispan.client.hotrod.impl.VersionedMetadataImpl
 
getLifespan() - Method in interface org.infinispan.client.hotrod.Metadata
 
getLifespan() - Method in interface org.infinispan.container.entries.CacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.ClearCacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
getLifespan() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
getLifespan() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
 
getLifespan() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.MortalCacheValue
 
getLifespan() - Method in class org.infinispan.container.entries.NullCacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getLifespan() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
getLifespan() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
getLine() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
getLineNumber() - Method in class org.infinispan.commons.configuration.io.Location
 
getLineNumber() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
getLineNumber() - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returns the current line number, starting from 1.
getLineNumber() - Method in exception class org.infinispan.commons.configuration.io.xml.XmlPullParserException
 
getList() - Method in class org.infinispan.persistence.modifications.ModificationsList
 
getListAttributeValue(int) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
Get the value of an attribute as a space-delimited string list.
getListAttributeValue(int) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationReader
 
getListAttributeValue(String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
 
getListener() - Method in class org.infinispan.notifications.cachelistener.ListenerHolder
 
getListenerCollectionForAnnotation(Class<? extends Annotation>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
getListenerCollectionForAnnotation(Class<? extends Annotation>) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
 
getListenerId() - Method in class org.infinispan.client.hotrod.counter.impl.HotRodCounterEvent
 
getListenerId() - Method in class org.infinispan.client.hotrod.event.impl.AbstractClientEvent
 
getListenerId() - Method in class org.infinispan.client.hotrod.near.NearCacheService
 
getListeners() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
Deprecated, for removal: This API element is subject to removal in a future version.
getListeners() - Method in class org.infinispan.cache.impl.CacheImpl
Deprecated, for removal: This API element is subject to removal in a future version.
getListeners() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
Deprecated, for removal: This API element is subject to removal in a future version.
getListeners() - Method in class org.infinispan.client.hotrod.event.impl.ContinuousQueryImpl
 
getListeners() - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
getListeners() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
Deprecated, for removal: This API element is subject to removal in a future version.
getListeners() - Method in interface org.infinispan.client.hotrod.RemoteCache
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, with no replacement
getListeners() - Method in class org.infinispan.manager.DefaultCacheManager
Deprecated, for removal: This API element is subject to removal in a future version.
getListeners() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
Deprecated, for removal: This API element is subject to removal in a future version.
getListeners() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
 
getListeners() - Method in interface org.infinispan.notifications.Listenable
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.0, with no replacement
getListeners() - Method in interface org.infinispan.query.api.continuous.ContinuousQuery
Get the list of currently registered listeners.
getListeners() - Method in class org.infinispan.security.impl.SecureCacheImpl
Deprecated, for removal: This API element is subject to removal in a future version.
getListeners(String) - Method in class org.infinispan.client.hotrod.event.impl.ClientListenerNotifier
 
getLocal(ExtendedStatistic) - Method in class org.infinispan.extendedstats.container.StatisticsSnapshot
 
getLocalActiveTransactions() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getLocalAddress() - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
getLocalAddress() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
getLocalAddress() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
 
getLocalClusterPublisherManager() - Method in class org.infinispan.factories.ComponentRegistry
 
getLocalComponent(Class<T>) - Method in class org.infinispan.factories.ComponentRegistry
 
getLocalComponent(String, String, boolean) - Method in class org.infinispan.factories.ComponentRegistry
 
getLocalExecutionTimeWithoutLock() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getLocalGlobalTransaction() - Method in class org.infinispan.transaction.impl.TransactionTable
 
getLocalGlobalTransaction() - Method in interface org.infinispan.transaction.TransactionTable
 
getLocalIndex() - Method in enum org.infinispan.extendedstats.container.ExtendedStatistic
 
getLocalIndex(ExtendedStatistic) - Static method in class org.infinispan.extendedstats.container.ConcurrentGlobalContainer
 
getLocalName() - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationReader
 
getLocalName() - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
getLocalName() - Method in enum org.infinispan.configuration.parsing.Attribute
Get the local name of this element.
getLocalName() - Method in enum org.infinispan.configuration.parsing.Element
Get the local name of this element.
getLocalName() - Method in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
Get the local name of this element.
getLocalName() - Method in enum org.infinispan.persistence.jdbc.common.configuration.Element
Get the local name of this element.
getLocalName() - Method in enum org.infinispan.persistence.remote.configuration.Attribute
Get the local name of this element.
getLocalName() - Method in enum org.infinispan.persistence.remote.configuration.Element
Get the local name of this element.
getLocalName() - Method in enum org.infinispan.persistence.rocksdb.configuration.Attribute
Get the local name of this element.
getLocalName() - Method in enum org.infinispan.persistence.rocksdb.configuration.Element
Get the local name of this element.
getLocalName(NamingStrategy) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
getLocalName(NamingStrategy) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationReader
 
getLocalName(NamingStrategy) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationReader
 
getLocalName(NamingStrategy) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader
 
getLocalPreparedXids() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
 
getLocalPrimarySegments() - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
getLocalPublisherManager() - Method in class org.infinispan.factories.ComponentRegistry
 
getLocalQueryStatistics(Cache<?, ?>) - Static method in class org.infinispan.query.impl.ComponentRegistryUtils
 
getLocalReadSegments() - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
getLocalRepository() - Method in class org.infinispan.commons.maven.MavenSettings
 
getLocalSite() - Method in class org.infinispan.manager.CacheManagerInfo
 
getLocalStatMaps() - Static method in interface org.infinispan.stats.ContainerStats
 
getLocalStatsSize() - Static method in enum org.infinispan.extendedstats.container.ExtendedStatistic
 
getLocalTopGets() - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
 
getLocalTopologyManager() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getLocalTopPuts() - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
 
getLocalTransaction() - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
getLocalTransaction(Transaction) - Method in class org.infinispan.transaction.impl.TransactionTable
 
getLocalTransaction(XidImpl) - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
getLocalTransaction(GlobalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
Looks up a LocalTransaction given a GlobalTransaction.
getLocalTransactions() - Method in class org.infinispan.transaction.impl.TransactionTable
 
getLocalTx(XidImpl) - Method in class org.infinispan.server.hotrod.tx.table.PerCacheTxTable
 
getLocalTxCount() - Method in class org.infinispan.transaction.impl.TransactionTable
 
getLocalTxCount() - Method in class org.infinispan.transaction.xa.XaTransactionTable
 
getLocalTxThatFailedToComplete() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
 
getLocalWriteSegments() - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
getLocalWriteSegmentsCount() - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
getLocation() - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
getLocation() - Method in exception class org.infinispan.commons.configuration.io.ConfigurationReaderException
 
getLocation() - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationReader
 
getLocation() - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationReader
 
getLocation() - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader
 
getLocation() - Method in class org.infinispan.configuration.global.GlobalStatePathConfiguration
 
getLocation() - Method in class org.infinispan.configuration.global.GlobalStatePathConfigurationBuilder
 
getLocation() - Method in class org.infinispan.configuration.global.TemporaryGlobalStatePathConfiguration
 
getLocation(GlobalConfiguration, String) - Static method in class org.infinispan.persistence.PersistenceUtil
 
getLocationId(TopologyLevel, Address) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getLock(Object) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticLockManager
 
getLock(Object) - Method in class org.infinispan.extendedstats.wrappers.TopKeyLockManager
 
getLock(Object) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
 
getLock(Object) - Method in interface org.infinispan.util.concurrent.locks.impl.LockContainer
 
getLock(Object) - Method in class org.infinispan.util.concurrent.locks.impl.PerKeyLockContainer
 
getLock(Object) - Method in class org.infinispan.util.concurrent.locks.impl.StripedLockContainer
 
getLock(Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
 
getLockedKeys() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
getLockedKeys() - Method in class org.infinispan.context.impl.ClearInvocationContext
 
getLockedKeys() - Method in class org.infinispan.context.impl.ImmutableContext
 
getLockedKeys() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
getLockedKeys() - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
 
getLockedKeys() - Method in interface org.infinispan.context.InvocationContext
Returns the set of keys that are locked for writing.
getLockedKeys() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getLockedKeys() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
getLockManager() - Method in interface org.infinispan.AdvancedCache
Returns the component that deals with all aspects of acquiring and releasing locks for cache entries.
getLockManager() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getLockManager() - Method in class org.infinispan.cache.impl.CacheImpl
 
getLockManager() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getLockManager() - Method in class org.infinispan.factories.ComponentRegistry
 
getLockManager() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getLockOwner() - Method in class org.infinispan.cache.impl.DecoratedCache
 
getLockOwner() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
getLockOwner() - Method in class org.infinispan.context.impl.ClearInvocationContext
 
getLockOwner() - Method in class org.infinispan.context.impl.ImmutableContext
 
getLockOwner() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
getLockOwner() - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
 
getLockOwner() - Method in interface org.infinispan.context.InvocationContext
Returns the in behalf of which locks will be acquired.
getLockOwner() - Method in class org.infinispan.util.concurrent.locks.impl.InfinispanLock
 
getLockWithOffset(int) - Method in class org.infinispan.container.offheap.StripedLock
Retrieves the given lock at a provided offset.
getLog() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
getLog() - Method in class org.infinispan.factories.ComponentRegistry
 
getLog() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getLog() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
 
getLog() - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
 
getLog() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
 
getLog() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
getLog() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getLog() - Method in interface org.infinispan.remoting.transport.Transport
 
getLog() - Method in class org.infinispan.stream.impl.AbstractCacheStream
 
getLog() - Method in class org.infinispan.stream.impl.DistributedCacheStream
 
getLog() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
 
getLog() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
 
getLog() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
 
getLog() - Method in interface org.infinispan.util.logging.LogSupplier
 
getLog(Class<?>) - Static method in class org.infinispan.client.hotrod.logging.LogFactory
 
getLog(Class<?>) - Static method in class org.infinispan.commons.logging.BasicLogFactory
 
getLog(Class<?>) - Static method in class org.infinispan.commons.logging.LogFactory
 
getLog(Class<?>) - Static method in class org.infinispan.util.logging.LogFactory
 
getLog(Class<?>, Class<T>) - Static method in class org.infinispan.client.hotrod.logging.LogFactory
 
getLog(Class<?>, Class<T>) - Static method in class org.infinispan.commons.logging.BasicLogFactory
 
getLog(Class<?>, Class<T>) - Static method in class org.infinispan.commons.logging.LogFactory
 
getLog(Class<?>, Class<T>) - Static method in class org.infinispan.util.logging.LogFactory
 
getLog(String, Class<T>) - Static method in class org.infinispan.util.logging.LogFactory
 
getLogger() - Method in class org.infinispan.rest.RestRequestHandler
 
getLogger(String) - Static method in class org.infinispan.util.logging.LogFactory
 
getLoggingLocale() - Method in class org.infinispan.rest.logging.Messages_$bundle
 
getLoggingLocale() - Method in class org.infinispan.scripting.logging.Messages_$bundle
 
getLoggingLocale() - Method in class org.infinispan.search.mapper.log.impl.InfinispanEventContextMessages_$bundle
 
getLoginConfiguration(ProtocolServer) - Method in interface org.infinispan.server.core.ServerManagement
 
getLongProperty(String, long) - Method in class org.infinispan.commons.util.TypedProperties
 
getLongProperty(String, long, boolean) - Method in class org.infinispan.commons.util.TypedProperties
 
getLookedUpEntries() - Method in interface org.infinispan.context.EntryLookup
Retrieves a map of entries looked up within the current scope.
getLookedUpEntries() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
getLookedUpEntries() - Method in class org.infinispan.context.impl.ClearInvocationContext
 
getLookedUpEntries() - Method in class org.infinispan.context.impl.ImmutableContext
 
getLookedUpEntries() - Method in class org.infinispan.context.impl.NonTxInvocationContext
 
getLookedUpEntries() - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
 
getLookedUpEntries() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getLookedUpEntries() - Method in class org.infinispan.transaction.impl.LocalTransaction
 
getLookedUpEntries() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
getMachine() - Method in class org.infinispan.distribution.topologyaware.TopologyInfo.Node
 
getMachineId() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
 
getMachineId() - Method in interface org.infinispan.remoting.transport.TopologyAwareAddress
 
getMachineIndex(Address) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getMachineNodes(String, String, String) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getMajor() - Method in interface org.infinispan.commons.configuration.io.ConfigurationSchemaVersion
 
getMajor() - Static method in class org.infinispan.commons.util.Version
 
getMajor() - Method in class org.infinispan.configuration.parsing.Schema
 
getMajor() - Static method in class org.infinispan.Version
Deprecated.
 
getMajorMinor() - Static method in class org.infinispan.commons.util.Version
 
getMajorMinor() - Static method in class org.infinispan.Version
Deprecated.
 
getMapForSegment(int) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
getMapForSegment(int) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
 
getMapForSegment(int) - Method in class org.infinispan.container.impl.DefaultDataContainer
 
getMapForSegment(int) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
getMapForSegment(int) - Method in class org.infinispan.container.impl.L1SegmentedDataContainer
 
getMapForSegment(int) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
getMapItem(Enum<?>) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationReader
 
getMapItem(Enum<?>) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
getMapItem(String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
getMapItem(String) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationReader
 
getMapItem(String) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationReader
 
getMapItem(String) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader
 
getMappingSession() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
 
getMappingSession() - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
 
getMapSize() - Method in class org.infinispan.util.concurrent.ActionSequencer
 
getMapThatContainsKey(byte[]) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
 
getMapThatContainsKey(byte[]) - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
getMarshallableEntries() - Method in class org.infinispan.persistence.support.BatchModification
 
getMarshallableEntryFactory() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getMarshallableEntryFactory() - Method in interface org.infinispan.persistence.spi.InitializationContext
Should be used to build all MarshallableEntry objects.
getMarshallableEntryFactory() - Method in class org.infinispan.persistence.support.DelegatingInitializationContext
 
getMarshalledValue() - Method in interface org.infinispan.persistence.spi.MarshallableEntry
 
getMarshaller() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getMarshaller() - Method in interface org.infinispan.client.hotrod.RemoteCacheContainer
 
getMarshaller() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
getMarshaller() - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
 
getMarshaller() - Method in class org.infinispan.server.hotrod.HotRodServer
 
getMarshaller() - Method in class org.infinispan.tasks.TaskContext
Marshaller for this task execution
getMarshaller(Class<? extends Marshaller>) - Method in class org.infinispan.client.hotrod.impl.MarshallerRegistry
 
getMarshaller(MediaType) - Method in class org.infinispan.client.hotrod.impl.MarshallerRegistry
 
getMarshallerRegistry() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
getMarshallVersion() - Static method in class org.infinispan.commons.util.Version
 
getMarshallVersion() - Static method in class org.infinispan.Version
Deprecated.
 
getMask() - Method in enum org.infinispan.security.AuthorizationPermission
 
getMask() - Method in class org.infinispan.security.impl.CacheRoleImpl
 
getMask() - Method in class org.infinispan.security.impl.SubjectACL
 
getMask() - Method in interface org.infinispan.security.Role
Returns a pre-computed access mask which contains the permissions specified by this role
getMax(long) - Method in class org.infinispan.commons.stat.DefaultSimpleStat
 
getMax(long) - Method in interface org.infinispan.commons.stat.SimpleStat
 
getMaxBufferedEntries() - Method in class org.infinispan.configuration.cache.IndexWriterConfiguration
 
getMaxDoublingSize() - Method in class org.infinispan.commons.io.ExposedByteArrayOutputStream
Deprecated.
Gets the highest internal buffer size after which if more capacity is needed the buffer will grow in 25% increments rather than 100%.
getMaxDoublingSize() - Method in class org.infinispan.commons.io.LazyByteArrayOutputStream
Gets the highest internal buffer size after which if more capacity is needed the buffer will grow in 25% increments rather than 100%.
getMaxDoublingSize() - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
Deprecated.
Gets the highest internal buffer size after which if more capacity is needed the buffer will grow in 25% increments rather than 100%.
getMaxIdle() - Method in class org.infinispan.client.hotrod.impl.MetadataValueImpl
 
getMaxIdle() - Method in class org.infinispan.client.hotrod.impl.VersionedMetadataImpl
 
getMaxIdle() - Method in interface org.infinispan.client.hotrod.Metadata
 
getMaxIdle() - Method in interface org.infinispan.container.entries.CacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.ClearCacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
getMaxIdle() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
getMaxIdle() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
 
getMaxIdle() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue
 
getMaxIdle() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.NullCacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.TransientCacheValue
 
getMaxIdle() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
getMaxIdle() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
 
getMaxIdleTimeSecondsHeader() - Method in interface org.infinispan.rest.framework.RestRequest
 
getMaxIdleTimeSecondsHeader() - Method in class org.infinispan.rest.NettyRestRequest
 
getMaximumPoolSize() - Method in class org.infinispan.executors.ManageableExecutorService
 
getMaximumXSiteReplicationTime() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getMaximumXSiteReplicationTimeTo(String) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getMaxInactiveInterval() - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository.InfinispanSession
 
getMaxNumberOfKeys() - Method in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
 
getMaxRequestSentDuration(long, TimeUnit) - Method in class org.infinispan.xsite.metrics.DefaultXSiteMetricsCollector
 
getMaxRequestSentDuration(long, TimeUnit) - Method in class org.infinispan.xsite.metrics.NoOpXSiteMetricsCollector
 
getMaxRequestSentDuration(long, TimeUnit) - Method in interface org.infinispan.xsite.metrics.XSiteMetricsCollector
 
getMaxRequestSentDuration(String, long, TimeUnit) - Method in class org.infinispan.xsite.metrics.DefaultXSiteMetricsCollector
 
getMaxRequestSentDuration(String, long, TimeUnit) - Method in class org.infinispan.xsite.metrics.NoOpXSiteMetricsCollector
 
getMaxRequestSentDuration(String, long, TimeUnit) - Method in interface org.infinispan.xsite.metrics.XSiteMetricsCollector
 
getMaxResults() - Method in interface org.infinispan.query.dsl.Query
 
getMaxResults() - Method in class org.infinispan.query.impl.QueryDefinition
 
getMaxResults() - Method in class org.infinispan.query.remote.json.JsonQueryRequest
 
getMaxRetries() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getMBeanInfo() - Method in class org.infinispan.jmx.ResourceDMBean
 
getMBeanMetadata(String) - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
 
getMBeanMetadata(String) - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
 
getMBeanServer() - Method in interface org.infinispan.commons.jmx.MBeanServerLookup
 
getMBeanServer() - Method in class org.infinispan.jmx.CacheJmxRegistration
Gets the MBean server.
getMBeanServer() - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
Gets the MBean server.
getMBeanServer(Properties) - Method in interface org.infinispan.commons.jmx.MBeanServerLookup
Retrieves an MBeanServer instance.
getMBeanServer(Properties) - Method in class org.infinispan.commons.jmx.PlatformMBeanServerLookup
 
getMechanism() - Method in class org.infinispan.server.core.dataconversion.json.SecureTypeIdResolver
Deprecated.
 
getMechanismName() - Method in class org.infinispan.server.core.security.SubjectSaslServer
 
getMechanismNames(Map<String, ?>) - Method in class org.infinispan.server.core.security.external.ExternalSaslServerFactory
 
getMediaType(Short) - Static method in class org.infinispan.commons.dataconversion.MediaTypeIds
 
getMediaType(String) - Static method in class org.infinispan.commons.dataconversion.MediaTypeResolver
 
getMembers() - Method in interface org.infinispan.distribution.ch.ConsistentHash
Should return the addresses of the nodes used to create this consistent hash.
getMembers() - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
 
getMembers() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
getMembers() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
getMembers() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
getMembers() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticRpcManager
 
getMembers() - Method in class org.infinispan.manager.DefaultCacheManager
getMembers() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getMembers() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getMembers() - Method in interface org.infinispan.remoting.rpc.RpcManager
Returns members of a cluster scoped to the cache owning this RpcManager.
getMembers() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getMembers() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
getMembers() - Method in class org.infinispan.remoting.transport.jgroups.ClusterView
 
getMembers() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getMembers() - Method in interface org.infinispan.remoting.transport.Transport
Returns a list of members in the current cluster view.
getMembers() - Method in class org.infinispan.topology.CacheTopology
 
getMembersAtEnd() - Method in interface org.infinispan.notifications.cachelistener.event.DataRehashedEvent
 
getMembersAtEnd() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getMembersAtStart() - Method in interface org.infinispan.notifications.cachelistener.event.DataRehashedEvent
 
getMembersAtStart() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getMembersPersistentUUIDs() - Method in class org.infinispan.topology.CacheTopology
 
getMembersPhysicalAddresses() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
getMembersPhysicalAddresses() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getMembersPhysicalAddresses() - Method in interface org.infinispan.remoting.transport.Transport
Returns physical addresses of members in the current cluster view.
getMembersSet() - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
getMembersSet() - Method in class org.infinispan.remoting.transport.jgroups.ClusterView
 
getMemoryAddressOffset(int) - Method in class org.infinispan.container.offheap.MemoryAddressHash
 
getMemoryAddressOffsetNoTraceIfAbsent(int) - Method in class org.infinispan.container.offheap.MemoryAddressHash
 
getMemoryAvailable() - Method in interface org.infinispan.stats.ContainerStats
 
getMemoryAvailable() - Method in class org.infinispan.stats.impl.ClusterContainerStatsImpl
 
getMemoryAvailable() - Method in class org.infinispan.stats.impl.LocalContainerStatsImpl
 
getMemoryMax() - Method in interface org.infinispan.stats.ContainerStats
 
getMemoryMax() - Method in class org.infinispan.stats.impl.ClusterContainerStatsImpl
 
getMemoryMax() - Method in class org.infinispan.stats.impl.LocalContainerStatsImpl
 
getMemoryPools() - Method in class org.infinispan.commons.util.JVMMemoryInfoInfo
 
getMemoryTotal() - Method in interface org.infinispan.stats.ContainerStats
 
getMemoryTotal() - Method in class org.infinispan.stats.impl.ClusterContainerStatsImpl
 
getMemoryTotal() - Method in class org.infinispan.stats.impl.LocalContainerStatsImpl
 
getMemoryUsed() - Method in interface org.infinispan.stats.ContainerStats
 
getMemoryUsed() - Method in class org.infinispan.stats.impl.ClusterContainerStatsImpl
 
getMemoryUsed() - Method in class org.infinispan.stats.impl.LocalContainerStatsImpl
 
getMessageId() - Method in class org.infinispan.server.hotrod.HotRodHeader
 
getMetadata() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.ValueAndMetadata
 
getMetadata() - Method in interface org.infinispan.commands.MetadataAwareCommand
Get metadata of this command.
getMetadata() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
getMetadata() - Method in class org.infinispan.container.entries.ClearCacheEntry
 
getMetadata() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
getMetadata() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
 
getMetadata() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
getMetadata() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
getMetadata() - Method in interface org.infinispan.container.entries.metadata.MetadataAware
Get metadata of this cache entry.
getMetadata() - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheEntry
 
getMetadata() - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue
 
getMetadata() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
 
getMetadata() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
 
getMetadata() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
 
getMetadata() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
 
getMetadata() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
 
getMetadata() - Method in class org.infinispan.container.entries.MortalCacheEntry
 
getMetadata() - Method in class org.infinispan.container.entries.NullCacheEntry
 
getMetadata() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getMetadata() - Method in class org.infinispan.container.entries.TransientCacheEntry
 
getMetadata() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
 
getMetadata() - Method in class org.infinispan.container.versioning.irac.IracTombstoneInfo
 
getMetadata() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
getMetadata() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryEvent
Retrieves the metadata associated with the entry.
getMetadata() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getMetadata() - Method in class org.infinispan.persistence.sifs.EntryRecord
 
getMetadata() - Method in interface org.infinispan.persistence.spi.MarshallableEntry
 
getMetadata() - Method in class org.infinispan.xsite.spi.SiteEntry
 
getMetadataBytes() - Method in interface org.infinispan.persistence.spi.MarshallableEntry
 
getMetadataBytes() - Method in interface org.infinispan.persistence.spi.MarshalledValue
 
getMethod() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
getMethodName() - Method in class org.infinispan.factories.impl.MBeanMetadata.OperationMetadata
 
getMethodParameters() - Method in class org.infinispan.factories.impl.MBeanMetadata.OperationMetadata
 
getMetricsRegistry() - Method in class org.infinispan.rest.InvocationHelper
 
getMin(long) - Method in class org.infinispan.commons.stat.DefaultSimpleStat
 
getMin(long) - Method in interface org.infinispan.commons.stat.SimpleStat
 
getMinimumXSiteReplicationTime() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getMinimumXSiteReplicationTimeTo(String) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getMinor() - Method in interface org.infinispan.commons.configuration.io.ConfigurationSchemaVersion
 
getMinor() - Static method in class org.infinispan.commons.util.Version
 
getMinor() - Method in class org.infinispan.configuration.parsing.Schema
 
getMinRequestSentDuration(long, TimeUnit) - Method in class org.infinispan.xsite.metrics.DefaultXSiteMetricsCollector
 
getMinRequestSentDuration(long, TimeUnit) - Method in class org.infinispan.xsite.metrics.NoOpXSiteMetricsCollector
 
getMinRequestSentDuration(long, TimeUnit) - Method in interface org.infinispan.xsite.metrics.XSiteMetricsCollector
 
getMinRequestSentDuration(String, long, TimeUnit) - Method in class org.infinispan.xsite.metrics.DefaultXSiteMetricsCollector
 
getMinRequestSentDuration(String, long, TimeUnit) - Method in class org.infinispan.xsite.metrics.NoOpXSiteMetricsCollector
 
getMinRequestSentDuration(String, long, TimeUnit) - Method in interface org.infinispan.xsite.metrics.XSiteMetricsCollector
 
getMinTopologyId() - Method in class org.infinispan.transaction.impl.TransactionTable
 
getMisses() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getMisses() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getMisses() - Method in class org.infinispan.stats.impl.StatsCollector
 
getMisses() - Method in class org.infinispan.stats.impl.StatsImpl
 
getMisses() - Method in interface org.infinispan.stats.Stats
 
getMixedCaches() - Method in class org.infinispan.xsite.status.ContainerMixedSiteStatus
 
getMode() - Method in enum org.infinispan.configuration.cache.TransactionMode
 
getMode() - Method in enum org.infinispan.configuration.parsing.CacheParser.TransactionMode
 
getModifications() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
 
getModifications() - Method in interface org.infinispan.context.impl.TxInvocationContext
Returns the modifications performed in the scope of the current transaction.
getModifications() - Method in class org.infinispan.server.hotrod.tx.table.TxState
 
getModifications() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getModifications() - Method in class org.infinispan.transaction.impl.ModificationList
Returns a snapshot of this list.
getModifications() - Method in interface org.infinispan.transaction.xa.CacheTransaction
Returns the modifications visible within the current transaction.
getModificationTime() - Method in class org.infinispan.io.GridFile.Metadata
Deprecated.
 
getModuleCommandFactory() - Method in class org.infinispan.query.impl.QueryModuleCommandExtensions
 
getModuleCommandFactory() - Method in class org.infinispan.server.hotrod.command.HotRodModuleCommandExtensions
 
getModuleLifecycle(Class<T>) - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getModuleName() - Method in interface org.infinispan.factories.impl.ModuleMetadataBuilder
 
getModuleProperties() - Method in class org.infinispan.factories.GlobalComponentRegistry
Deprecated, for removal: This API element is subject to removal in a future version.
getModuleSlot() - Static method in class org.infinispan.commons.util.Version
 
getModuleSlot() - Static method in class org.infinispan.Version
Deprecated.
 
getMostSignificantBits() - Method in class org.infinispan.topology.PersistentUUID
 
getName() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getName() - Method in class org.infinispan.cache.impl.CacheImpl
 
getName() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getName() - Method in class org.infinispan.client.hotrod.counter.impl.BaseCounter
 
getName() - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
getName() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getName() - Method in interface org.infinispan.commons.api.BasicCache
Retrieves the name of the cache
getName() - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
 
getName() - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationReader
 
getName() - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter.Tag
 
getName() - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
getName() - Method in class org.infinispan.commons.configuration.io.Location
 
getName() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
getName() - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
For START_TAG or END_TAG events, the (local) name of the current element is returned when namespaces are enabled.
getName() - Method in class org.infinispan.commons.jdkspecific.ProcessInfo
 
getName() - Method in class org.infinispan.commons.stat.CounterMetricInfo
 
getName() - Method in class org.infinispan.commons.stat.DistributionSummaryMetricInfo
 
getName() - Method in class org.infinispan.commons.stat.FunctionTimerMetricInfo
 
getName() - Method in class org.infinispan.commons.stat.GaugeMetricInfo
 
getName() - Method in class org.infinispan.commons.stat.TimeGaugeMetricInfo
 
getName() - Method in class org.infinispan.commons.stat.TimerMetricInfo
 
getName() - Method in interface org.infinispan.commons.stat.MetricInfo
 
getName() - Method in interface org.infinispan.counter.api.StrongCounter
 
getName() - Method in interface org.infinispan.counter.api.SyncStrongCounter
 
getName() - Method in interface org.infinispan.counter.api.SyncWeakCounter
 
getName() - Method in interface org.infinispan.counter.api.WeakCounter
 
getName() - Method in class org.infinispan.counter.impl.SyncStrongCounterAdapter
 
getName() - Method in class org.infinispan.counter.impl.SyncWeakCounterAdapter
 
getName() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
getName() - Method in class org.infinispan.factories.ComponentRegistry
 
getName() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getName() - Method in interface org.infinispan.factories.impl.ComponentRef
 
getName() - Method in class org.infinispan.factories.impl.MBeanMetadata.AttributeMetadata
 
getName() - Method in class org.infinispan.factories.impl.MBeanMetadata.OperationParameterMetadata
 
getName() - Method in class org.infinispan.factories.threads.DefaultThreadFactory
 
getName() - Method in interface org.infinispan.functional.FunctionalMap
Functional map's name.
getName() - Method in class org.infinispan.functional.impl.ReadOnlyMapImpl
 
getName() - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
 
getName() - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
getName() - Method in class org.infinispan.functional.impl.FunctionalMapImpl
 
getName() - Method in class org.infinispan.globalstate.ScopedState
 
getName() - Method in class org.infinispan.io.GridFile
Deprecated.
 
getName() - Method in class org.infinispan.manager.CacheManagerInfo
 
getName() - Method in class org.infinispan.manager.DefaultCacheManager
 
getName() - Method in class org.infinispan.persistence.remote.upgrade.HotRodTargetMigrator
 
getName() - Method in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.Parameter
 
getName() - Method in class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator
 
getName() - Method in class org.infinispan.remoting.transport.jgroups.FileJGroupsChannelConfigurator
 
getName() - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelConfigurator
 
getName() - Method in class org.infinispan.remoting.transport.jgroups.NamedSocketFactory
 
getName() - Method in class org.infinispan.rest.framework.impl.InvocationImpl
 
getName() - Method in interface org.infinispan.rest.framework.Invocation
The user friendly name of the invocation
getName() - Method in class org.infinispan.security.impl.CacheRoleImpl
 
getName() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getName() - Method in class org.infinispan.security.impl.SubjectAdapter.SimplePrincipal
 
getName() - Method in interface org.infinispan.security.Role
Returns the name of this role
getName() - Method in class org.infinispan.server.core.AbstractProtocolServer
 
getName() - Method in class org.infinispan.server.core.admin.AdminOperationsHandler
 
getName() - Method in class org.infinispan.server.core.admin.AdminServerTask
 
getName() - Method in interface org.infinispan.server.core.ProtocolServer
Returns the name of this server
getName() - Method in class org.infinispan.server.core.security.InetAddressPrincipal
 
getName() - Method in class org.infinispan.server.core.security.simple.SimpleGroupPrincipal
 
getName() - Method in class org.infinispan.server.core.security.simple.SimpleUserPrincipal
 
getName() - Method in class org.infinispan.spring.common.provider.SpringCache
 
getName() - Method in class org.infinispan.spring.common.session.MapSessionProtoAdapter.SessionAttribute
 
getName() - Method in interface org.infinispan.tasks.Task
Provides a name for the task.
getName() - Method in interface org.infinispan.upgrade.TargetMigrator
Returns the name of this migrator
getNamedComponentRegistries() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getNamedComponentRegistry(String) - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getNamedComponentRegistry(ByteString) - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getNamedConfigurationBuilders() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
getNamedParameters() - Method in class org.infinispan.query.impl.QueryDefinition
 
getNamespace() - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
getNamespace() - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationReader
 
getNamespace() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
getNamespace() - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationReader
 
getNamespace() - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returns the namespace URI of the current element.
getNamespace() - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader
 
getNamespace(String) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
getNamespace(String) - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returns the URI corresponding to the given prefix, depending on current state of the parser.
getNamespaceAnnotations(Class<?>) - Static method in class org.infinispan.configuration.parsing.ParseUtils
 
getNamespaceCount(int) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
getNamespaceCount(int) - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returns the numbers of elements in the namespace stack for the given depth.
getNamespacePrefix(int) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
getNamespacePrefix(int) - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returns the namespace prefixe for the given position in the namespace stack.
getNamespaces() - Method in class org.infinispan.configuration.parsing.CacheParser
 
getNamespaces() - Method in interface org.infinispan.configuration.parsing.ConfigurationParser
 
getNamespaces() - Method in class org.infinispan.configuration.parsing.Parser
 
getNamespaces() - Method in class org.infinispan.counter.configuration.CounterConfigurationParser
 
getNamespaces() - Method in class org.infinispan.counter.configuration.CounterParser
 
getNamespaces() - Method in class org.infinispan.lock.configuration.ClusteredLockConfigurationParser
 
getNamespaces() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStoreConfigurationParser
 
getNamespaces() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationParser
 
getNamespaces() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationParser
 
getNamespaces() - Method in class org.infinispan.persistence.sql.configuration.SqlStoreConfigurationParser
 
getNamespaceUri(int) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
getNamespaceUri(int) - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returns the namespace URI for the given position in the namespace stack If the position is out of range, an exception is thrown.
getNamingStrategy() - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationReader
 
getNamingStrategy() - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
getNativeCache() - Method in class org.infinispan.spring.common.provider.SpringCache
 
getNativeCacheManager() - Method in class org.infinispan.spring.embedded.provider.SpringEmbeddedCacheManager
Return the org.infinispan.manager.EmbeddedCacheManager that backs this CacheManager.
getNativeCacheManager() - Method in class org.infinispan.spring.remote.provider.SpringRemoteCacheManager
Return the org.infinispan.client.hotrod.RemoteCacheManager that backs this SpringRemoteCacheManager.
getNearCacheHits() - Method in class org.infinispan.client.hotrod.impl.ClientStatistics
 
getNearCacheHits() - Method in interface org.infinispan.client.hotrod.jmx.RemoteCacheClientStatisticsMXBean
Returns the number of near-cache hits.
getNearCacheInvalidations() - Method in class org.infinispan.client.hotrod.impl.ClientStatistics
 
getNearCacheInvalidations() - Method in interface org.infinispan.client.hotrod.jmx.RemoteCacheClientStatisticsMXBean
Returns the number of near-cache invalidations.
getNearCacheMaxEntries() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getNearCacheMisses() - Method in class org.infinispan.client.hotrod.impl.ClientStatistics
 
getNearCacheMisses() - Method in interface org.infinispan.client.hotrod.jmx.RemoteCacheClientStatisticsMXBean
Returns the number of near-cache misses.
getNearCacheMode() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getNearCacheNamePattern() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
Deprecated, for removal: This API element is subject to removal in a future version.
getNearCacheSize() - Method in class org.infinispan.client.hotrod.impl.ClientStatistics
 
getNearCacheSize() - Method in interface org.infinispan.client.hotrod.jmx.RemoteCacheClientStatisticsMXBean
Returns the number of entries currently stored in the near-cache.
getNegotiatedProperty(String) - Method in class org.infinispan.server.core.security.SubjectSaslServer
 
getNewBufferSize(int, int) - Method in class org.infinispan.commons.io.ExposedByteArrayOutputStream
Deprecated.
Gets the number of bytes to which the internal buffer should be resized.
getNewBufferSize(int, int) - Method in class org.infinispan.commons.io.LazyByteArrayOutputStream
Gets the number of bytes to which the internal buffer should be resized.
getNewBufferSize(int, int) - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
Deprecated.
Gets the number of bytes to which the internal buffer should be resized.
getNewMembers() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
getNewMembers() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
Gets the current list of members.
getNewState() - Method in class org.infinispan.client.hotrod.counter.impl.HotRodCounterEvent
 
getNewState() - Method in interface org.infinispan.counter.api.CounterEvent
 
getNewTopologyId() - Method in interface org.infinispan.notifications.cachelistener.event.DataRehashedEvent
 
getNewTopologyId() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getNewTopologyId() - Method in interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
 
getNewValue() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntryChange
 
getNewValue() - Method in class org.infinispan.client.hotrod.counter.impl.HotRodCounterEvent
 
getNewValue() - Method in interface org.infinispan.counter.api.CounterEvent
 
getNewValue() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
getNewValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryModifiedEvent
Retrieves the new value of the entry being modified.
getNewValue() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getNext() - Method in class org.infinispan.commons.util.AbstractIterator
Method to implement to provide an iterator implementation.
getNext() - Method in class org.infinispan.commons.util.ConcatIterator
 
getNext() - Method in class org.infinispan.commons.util.FilterIterator
 
getNext() - Method in class org.infinispan.container.impl.AbstractInternalDataContainer.EntryIterator
 
getNext() - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations.ResultSetEntryIterator
 
getNext(long) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
Returns the address to the next linked pointer if there is one for this bucket or 0 if there isn't one
getNext(long) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
 
getNext(String) - Method in class org.infinispan.reactive.publisher.impl.PublisherHandler
Retrieves the next response for the same request id that was configured on the command when invoking PublisherHandler.register(InitialPublisherCommand).
getNextFromIterator() - Method in class org.infinispan.commons.util.RemovableIterator
 
getNLocalTopGets(int) - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
 
getNLocalTopPuts(int) - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
 
getNodeAddress() - Method in class org.infinispan.manager.CacheManagerInfo
 
getNodeAddress() - Method in class org.infinispan.manager.DefaultCacheManager
 
getNodeName() - Method in class org.infinispan.manager.CacheManagerInfo
 
getNodeNames() - Method in interface org.infinispan.health.ClusterHealth
Returns node names.
getNonBlockingExecutor() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getNonBlockingExecutor() - Method in interface org.infinispan.persistence.spi.InitializationContext
Returns an executor for non-blocking tasks.
getNonBlockingExecutor() - Method in class org.infinispan.persistence.support.DelegatingInitializationContext
 
getNonBlockingManager() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getNonBlockingManager() - Method in interface org.infinispan.persistence.spi.InitializationContext
Returns a manager that is designed to help with non blocking operations.
getNonBlockingManager() - Method in class org.infinispan.persistence.support.DelegatingInitializationContext
 
getNonHeap() - Method in class org.infinispan.commons.util.JVMMemoryInfoInfo
 
getNormalizedHash(Object, Hash) - Static method in class org.infinispan.commons.util.Util
Applies the given hash function to the hash code of a given object, and then normalizes it to ensure a positive value is always returned.
getNormalizer() - Method in class org.infinispan.search.mapper.mapping.metamodel.ValueFieldMetamodel
 
getNRemoteTopGets(int) - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
 
getNRemoteTopPuts(int) - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
 
getNTopContendedKeys(int) - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
 
getNTopLockedKeys(int) - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
 
getNTopLockFailedKeys(int) - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
 
getNTopWriteSkewFailedKeys(int) - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
 
getNumAbortedTxDueDeadlock() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getNumAbortedTxDueTimeout() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getNumberIOThreads() - Method in class org.infinispan.server.core.transport.NettyTransport
 
getNumberIOThreads() - Method in interface org.infinispan.server.core.transport.Transport
 
getNumberOfCacheConfigurations() - Method in class org.infinispan.manager.DefaultCacheManager
 
getNumberOfCommits() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getNumberOfConflicts() - Method in class org.infinispan.xsite.irac.DefaultIracManager
 
getNumberOfConflictsLocalWins() - Method in class org.infinispan.xsite.irac.DefaultIracManager
 
getNumberOfConflictsMerged() - Method in class org.infinispan.xsite.irac.DefaultIracManager
 
getNumberOfConflictsRemoteWins() - Method in class org.infinispan.xsite.irac.DefaultIracManager
 
getNumberOfCpus() - Method in interface org.infinispan.health.HostInfo
Returns the number of CPUs installed in the host.
getNumberOfCpus() - Method in interface org.infinispan.health.jmx.HealthJMXExposer
Returns the total amount of CPUs for the JVM.
getNumberOfCreatedCaches() - Method in class org.infinispan.manager.DefaultCacheManager
 
getNumberOfDiscards() - Method in class org.infinispan.xsite.irac.DefaultIracManager
 
getNumberOfEntries() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getNumberOfEntries() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getNumberOfEntries() - Method in class org.infinispan.stats.impl.StatsCollector
Deprecated, for removal: This API element is subject to removal in a future version.
getNumberOfGets() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getNumberOfGlobalConnections() - Method in class org.infinispan.server.core.transport.NettyTransport
 
getNumberOfGlobalConnections() - Method in interface org.infinispan.server.core.transport.Transport
 
getNumberOfIndexedEntities(String) - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getNumberOfLocalCommits() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getNumberOfLocalConnections() - Method in class org.infinispan.server.core.transport.NettyTransport
 
getNumberOfLocalConnections() - Method in interface org.infinispan.server.core.transport.Transport
 
getNumberOfLocksAvailable() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getNumberOfLocksAvailable() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getNumberOfLocksAvailable() - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
 
getNumberOfLocksHeld() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticLockManager
 
getNumberOfLocksHeld() - Method in class org.infinispan.extendedstats.wrappers.TopKeyLockManager
 
getNumberOfLocksHeld() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getNumberOfLocksHeld() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getNumberOfLocksHeld() - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
 
getNumberOfLocksHeld() - Method in interface org.infinispan.util.concurrent.locks.LockManager
 
getNumberOfNodes() - Method in interface org.infinispan.health.ClusterHealth
Returns the number of nodes in the cluster.
getNumberOfNodes() - Method in interface org.infinispan.health.jmx.HealthJMXExposer
Returns total nodes in the cluster.
getNumberOfPuts() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getNumberOfRemoteGets() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getNumberOfRemotePuts() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getNumberOfRunningCaches() - Method in class org.infinispan.manager.DefaultCacheManager
 
getNumberOfTombstones() - Method in class org.infinispan.xsite.irac.DefaultIracManager
 
getNumberXSiteRequests() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getNumberXSiteRequestsReceived() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getNumberXSiteRequestsReceivedFrom(String) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getNumberXSiteRequestsSentTo(String) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getNumericVersion() - Method in class org.infinispan.metadata.EmbeddedMetadata
 
getNumericVersion() - Method in class org.infinispan.metadata.impl.PrivateMetadata
 
getNumLocksHeld() - Method in interface org.infinispan.util.concurrent.locks.impl.LockContainer
 
getNumLocksHeld() - Method in class org.infinispan.util.concurrent.locks.impl.PerKeyLockContainer
 
getNumLocksHeld() - Method in class org.infinispan.util.concurrent.locks.impl.StripedLockContainer
 
getNumNodes() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
getNumNodes() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
getNumNodes() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getNumOwners() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
 
getNumOwners() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
getNumOwners() - Method in class org.infinispan.topology.CacheJoinInfo
 
getNumSegments() - Method in interface org.infinispan.client.hotrod.CacheTopologyInfo
 
getNumSegments() - Method in class org.infinispan.client.hotrod.impl.CacheTopologyInfoImpl
 
getNumSegments() - Method in interface org.infinispan.distribution.ch.ConsistentHash
 
getNumSegments() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
 
getNumSegments() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
getNumSegments() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
getNumSegments() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
 
getNumSegments() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
getNumSegments() - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
getNumSegments() - Method in class org.infinispan.topology.CacheJoinInfo
 
getNumSegments() - Method in class org.infinispan.util.StripedHashFunction
 
getObject() - Method in class org.infinispan.spring.embedded.InfinispanDefaultCacheFactoryBean
 
getObject() - Method in class org.infinispan.spring.embedded.provider.ContainerEmbeddedCacheManagerFactoryBean
 
getObject() - Method in class org.infinispan.spring.embedded.provider.SpringEmbeddedCacheManagerFactoryBean
 
getObject() - Method in class org.infinispan.spring.embedded.support.InfinispanEmbeddedCacheManagerFactoryBean
 
getObject() - Method in class org.infinispan.spring.embedded.support.InfinispanNamedEmbeddedCacheFactoryBean
 
getObject() - Method in class org.infinispan.spring.remote.provider.ContainerRemoteCacheManagerFactoryBean
 
getObject() - Method in class org.infinispan.spring.remote.provider.SpringRemoteCacheManagerFactoryBean
 
getObject() - Method in class org.infinispan.spring.remote.support.InfinispanNamedRemoteCacheFactoryBean
 
getObject() - Method in class org.infinispan.spring.remote.support.InfinispanRemoteCacheManagerFactoryBean
 
getObjectFields() - Method in class org.infinispan.search.mapper.mapping.metamodel.IndexMetamodel
 
getObjectFields() - Method in class org.infinispan.search.mapper.mapping.metamodel.ObjectFieldMetamodel
 
getObjectFilter(String) - Method in interface org.infinispan.objectfilter.Matcher
 
getObjectFilter(String, List<FieldAccumulator>) - Method in interface org.infinispan.objectfilter.Matcher
 
getObjectFilter(FilterSubscription) - Method in interface org.infinispan.objectfilter.Matcher
Obtains an ObjectFilter instance that is capable of testing a single filter condition.
getObjectFilter(Query<?>) - Method in interface org.infinispan.objectfilter.Matcher
 
getObjectLoadingExecutionAvgTime() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getObjectLoadingExecutionMaxTime() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getObjectLoadingTotalTime() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getObjectName() - Method in class org.infinispan.jmx.ResourceDMBean
The ObjectName.
getObjectsLoadedCount() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getObjectType() - Method in class org.infinispan.spring.embedded.InfinispanDefaultCacheFactoryBean
 
getObjectType() - Method in class org.infinispan.spring.embedded.provider.ContainerEmbeddedCacheManagerFactoryBean
 
getObjectType() - Method in class org.infinispan.spring.embedded.provider.SpringEmbeddedCacheManagerFactoryBean
 
getObjectType() - Method in class org.infinispan.spring.embedded.support.InfinispanEmbeddedCacheManagerFactoryBean
 
getObjectType() - Method in class org.infinispan.spring.embedded.support.InfinispanNamedEmbeddedCacheFactoryBean
 
getObjectType() - Method in class org.infinispan.spring.remote.provider.ContainerRemoteCacheManagerFactoryBean
 
getObjectType() - Method in class org.infinispan.spring.remote.provider.SpringRemoteCacheManagerFactoryBean
 
getObjectType() - Method in class org.infinispan.spring.remote.support.InfinispanNamedRemoteCacheFactoryBean
 
getObjectType() - Method in class org.infinispan.spring.remote.support.InfinispanRemoteCacheManagerFactoryBean
 
getObservation() - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
 
getObservation() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
getObservation() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
 
getObservation() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
getOffHeapMemoryUsed() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getOffHeapMemoryUsed() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getOffHeapMemoryUsed() - Method in class org.infinispan.stats.impl.StatsCollector
 
getOffHeapMemoryUsed() - Method in class org.infinispan.stats.impl.StatsImpl
 
getOffHeapMemoryUsed() - Method in interface org.infinispan.stats.Stats
The amount of off-heap memory used by this cache, or -1 if the cache stores data in the heap.
getOffline() - Method in class org.infinispan.xsite.status.AbstractMixedSiteStatus
 
getOfflineStatus(String) - Method in class org.infinispan.xsite.status.DefaultTakeOfflineManager
 
getOffset() - Method in interface org.infinispan.commons.io.ByteBuffer
Returns the offset within the underlying byte[] (as returned by ByteBuffer.getBuf() owned by this buffer instance.
getOffset() - Method in class org.infinispan.commons.io.ByteBufferImpl
 
getOldMembers() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
getOldMembers() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
Gets the previous list of members.
getOldMetadata() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntryChange
 
getOldMetadata() - Method in interface org.infinispan.container.entries.MVCCEntry
 
getOldMetadata() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getOldMetadata() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
getOldMetadata() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryModifiedEvent
Regardless of whether isPre() is true or is false, this method returns the metadata of the entry being deleted.
getOldMetadata() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryRemovedEvent
Regardless of whether isPre() is true or is false, this method returns the metadata of the entry being deleted.
getOldMetadata() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getOldState() - Method in class org.infinispan.client.hotrod.counter.impl.HotRodCounterEvent
 
getOldState() - Method in interface org.infinispan.counter.api.CounterEvent
 
getOldValue() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntryChange
 
getOldValue() - Method in class org.infinispan.client.hotrod.counter.impl.HotRodCounterEvent
 
getOldValue() - Method in interface org.infinispan.container.entries.MVCCEntry
 
getOldValue() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getOldValue() - Method in interface org.infinispan.counter.api.CounterEvent
 
getOldValue() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
getOldValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryModifiedEvent
Retrieves the old value of the entry being modified.
getOldValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryRemovedEvent
Regardless of whether isPre() is true or is false, this method returns the value of the entry being deleted.
getOldValue() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getOnline() - Method in class org.infinispan.xsite.status.AbstractMixedSiteStatus
 
getOp() - Method in class org.infinispan.server.hotrod.HotRodHeader
 
getOperationName() - Method in class org.infinispan.factories.impl.MBeanMetadata.OperationMetadata
 
getOperations() - Method in class org.infinispan.factories.impl.MBeanMetadata
 
getOperationsFactory() - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
getOperationsFactory() - Method in interface org.infinispan.client.hotrod.impl.InternalRemoteCache
 
getOperationsFactory() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getOptionalComponent(Class<T>) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
getOptionalDependencies() - Method in interface org.infinispan.factories.impl.ModuleMetadataBuilder
 
getOrCreateCache(String, A) - Method in interface org.infinispan.commons.api.CacheContainerAdmin
Retrieves an existing cache or creates one using the specified template if it doesn't exist
getOrCreateCache(String, String) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
 
getOrCreateCache(String, String) - Method in interface org.infinispan.client.hotrod.RemoteCacheManagerAdmin
Retrieves an existing cache on the remote server cluster.
getOrCreateCache(String, String) - Method in interface org.infinispan.commons.api.CacheContainerAdmin
Retrieves an existing cache or creates one using the specified template if it doesn't exist
getOrCreateCache(String, String) - Method in class org.infinispan.manager.DefaultCacheManagerAdmin
 
getOrCreateCache(String, String) - Method in interface org.infinispan.manager.EmbeddedCacheManagerAdmin
Retrieves an existing cache or creates one using the specified template if it doesn't exist
getOrCreateCache(String, String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.GlobalConfigurationManager
Defines a cluster-wide cache configuration using the supplied template or retrieves an existing one
getOrCreateCache(String, String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.GlobalConfigurationManagerImpl
 
getOrCreateCache(String, DefaultTemplate) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
 
getOrCreateCache(String, DefaultTemplate) - Method in interface org.infinispan.client.hotrod.RemoteCacheManagerAdmin
Retrieves an existing cache on the remote server cluster.
getOrCreateCache(String, BasicConfiguration) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
 
getOrCreateCache(String, BasicConfiguration) - Method in interface org.infinispan.client.hotrod.RemoteCacheManagerAdmin
Retrieves an existing cache on the remote server cluster.
getOrCreateCache(String, Configuration) - Method in class org.infinispan.manager.DefaultCacheManagerAdmin
 
getOrCreateCache(String, Configuration) - Method in interface org.infinispan.manager.EmbeddedCacheManagerAdmin
Retrieves an existing cache or creates one across the cluster using the specified configuration.
getOrCreateCache(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.GlobalConfigurationManager
Defines a cluster-wide cache configuration or retrieves an existing one
getOrCreateCache(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.GlobalConfigurationManagerImpl
 
GetOrCreateCacheAction - Class in org.infinispan.security.actions
GetOrCreateCacheAction.
GetOrCreateCacheAction(EmbeddedCacheManager, String, Configuration) - Constructor for class org.infinispan.security.actions.GetOrCreateCacheAction
 
getOrCreateCacheInfo(WrappedBytes) - Method in class org.infinispan.client.hotrod.impl.TopologyInfo
 
getOrCreateComponent(Class<T>) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
Retrieves a component if one exists, and if not, attempts to find a factory capable of constructing the component (factories annotated with the DefaultFactoryFor annotation that is capable of creating the component class).
getOrCreateComponent(Class<T>, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
getOrCreateComponent(Class<T>, String, boolean) - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
getOrCreateComponent(Class<T>, String, boolean) - Method in class org.infinispan.factories.ComponentRegistry
 
getOrCreateLocalTransaction(Transaction, boolean) - Method in class org.infinispan.transaction.impl.TransactionTable
Returns the TransactionXaAdapter corresponding to the supplied transaction.
getOrCreateLocalTransaction(Transaction, boolean, Supplier<GlobalTransaction>) - Method in class org.infinispan.transaction.impl.TransactionTable
Similar to TransactionTable.getOrCreateLocalTransaction(Transaction, boolean) but with a custom global transaction factory.
getOrCreateRemoteTransaction(GlobalTransaction, List<WriteCommand>) - Method in class org.infinispan.transaction.impl.TransactionTable
Returns an existing remote transaction or creates one if none exists.
getOrCreateRemoteTransaction(GlobalTransaction, List<WriteCommand>, int) - Method in class org.infinispan.transaction.impl.TransactionTable
 
getOrCreateStreamLibContainer(Cache) - Static method in class org.infinispan.extendedstats.topK.StreamSummaryContainer
 
getOrCreateTemplate(String, Configuration) - Method in class org.infinispan.manager.DefaultCacheManagerAdmin
 
getOrCreateTemplate(String, Configuration) - Method in interface org.infinispan.manager.EmbeddedCacheManagerAdmin
Retrieves an existing template or creates one across the cluster using the specified configuration.
getOrCreateTemplate(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.GlobalConfigurationManager
Defines a cluster-wide configuration template
getOrCreateTemplate(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.GlobalConfigurationManagerImpl
 
GetOrCreateTemplateAction - Class in org.infinispan.security.actions
GetOrCreateCacheAction.
GetOrCreateTemplateAction(EmbeddedCacheManager, String, Configuration) - Constructor for class org.infinispan.security.actions.GetOrCreateTemplateAction
 
getOrDefault(Object, V) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getOrDefault(Object, V) - Method in class org.infinispan.cache.impl.EncoderCache
 
getOrDefault(Object, V) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
 
getOrderedParameters() - Method in class org.infinispan.persistence.sql.QueryNamedParameterParser.ParserResults
 
getOrderedUpdatesManager() - Method in class org.infinispan.factories.ComponentRegistry
 
getOrigin() - Method in class org.infinispan.context.impl.AbstractInvocationContext
 
getOrigin() - Method in class org.infinispan.context.impl.ImmutableContext
 
getOrigin() - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
 
getOrigin() - Method in interface org.infinispan.context.InvocationContext
 
getOriginator() - Method in class org.infinispan.server.hotrod.tx.table.TxState
 
getOrRegisterStateMachine(String, Supplier<T>, RaftChannelConfiguration) - Method in enum org.infinispan.remoting.transport.impl.EmptyRaftManager
 
getOutput(String) - Method in class org.infinispan.io.GridFilesystem
Deprecated.
Opens an OutputStream for writing to the file denoted by pathname.
getOutput(String, boolean) - Method in class org.infinispan.io.GridFilesystem
Deprecated.
Opens an OutputStream for writing to the file denoted by pathname.
getOutput(String, boolean, int) - Method in class org.infinispan.io.GridFilesystem
Deprecated.
Opens an OutputStream for writing to the file denoted by pathname.
getOutput(GridFile) - Method in class org.infinispan.io.GridFilesystem
Deprecated.
Opens an OutputStream for writing to the given file.
getOwned(int) - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
 
getOwned(Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
getOwned(Address) - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
 
getOwned(Address) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
getOwner() - Method in interface org.infinispan.util.concurrent.locks.ExtendedLockPromise
 
getOwner() - Method in interface org.infinispan.xsite.irac.IracManagerKeyInfo
 
getOwner() - Method in class org.infinispan.xsite.irac.IracManagerKeyInfoImpl
 
getOwner(Object) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticLockManager
 
getOwner(Object) - Method in class org.infinispan.extendedstats.wrappers.TopKeyLockManager
 
getOwner(Object) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
 
getOwner(Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
Retrieves the owner of the lock for the key.
getOwnerAddress() - Method in class org.infinispan.notifications.cachelistener.cluster.RemoteClusterListener
 
getOwners() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfo
 
getOwners(int) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
getOwnershipLevel() - Method in class org.infinispan.lock.api.ClusteredLockConfiguration
 
getParameter(String) - Method in class org.infinispan.commons.dataconversion.MediaType
 
getParameter(String) - Method in interface org.infinispan.rest.framework.RestRequest
 
getParameter(String) - Method in class org.infinispan.rest.NettyRestRequest
 
getParameter(Map<String, List<String>>, String) - Method in class org.infinispan.server.core.admin.AdminServerTask
 
getParameterNames() - Method in interface org.infinispan.objectfilter.ObjectFilter
Returns the filter parameter names or an empty Set if there are no parameters.
getParameters() - Method in class org.infinispan.commons.dataconversion.MediaType
 
getParameters() - Method in interface org.infinispan.objectfilter.ObjectFilter
The parameter values.
getParameters() - Method in interface org.infinispan.query.dsl.ParameterContext
Deprecated.
Returns the named parameters Map.
getParameters() - Method in interface org.infinispan.query.dsl.Query
Returns the named parameters Map.
getParameters() - Method in class org.infinispan.server.core.admin.embeddedserver.CacheCreateTask
 
getParameters() - Method in class org.infinispan.server.core.admin.embeddedserver.CacheReindexTask
 
getParameters() - Method in class org.infinispan.server.core.admin.embeddedserver.CacheRemoveTask
 
getParameters() - Method in class org.infinispan.server.core.admin.embeddedserver.CacheUpdateConfigurationAttributeTask
 
getParameters() - Method in class org.infinispan.server.core.admin.embeddedserver.CacheUpdateIndexSchemaTask
 
getParameters() - Method in class org.infinispan.server.core.admin.embeddedserver.TemplateCreateTask
 
getParameters() - Method in class org.infinispan.server.core.admin.embeddedserver.TemplateNamesTask
 
getParameters() - Method in class org.infinispan.server.core.admin.embeddedserver.TemplateRemoveTask
 
getParameters() - Method in interface org.infinispan.tasks.Task
The named parameters accepted by this task
getParameters() - Method in class org.infinispan.tasks.TaskContext
Gets a map of named parameters for the task
getParent() - Method in class org.infinispan.commons.jdkspecific.ProcessInfo
 
getParent() - Method in class org.infinispan.io.GridFile
Deprecated.
 
getParentFile() - Method in class org.infinispan.io.GridFile
Deprecated.
 
getParserRegistry() - Method in class org.infinispan.rest.InvocationHelper
 
getPartialTransactions() - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
 
getPartialTransactions() - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
 
getPartialTransactions() - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
getPartitionHandling() - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
 
getPassivations() - Method in class org.infinispan.eviction.impl.AbstractPassivationManager
 
getPassivations() - Method in interface org.infinispan.eviction.impl.PassivationManager
 
getPassivations() - Method in class org.infinispan.eviction.impl.PassivationManagerImpl
 
getPassivations() - Method in class org.infinispan.eviction.impl.PassivationManagerStub
 
getPassivations() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getPassivations() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getPassword() - Method in class org.infinispan.client.hotrod.impl.HotRodURI
 
getPassword() - Method in class org.infinispan.client.hotrod.security.BasicCallbackHandler
 
getPath() - Method in class org.infinispan.io.GridFile
Deprecated.
Returns path of this file.
getPath() - Method in interface org.infinispan.objectfilter.SortField
The field path.
getPath() - Method in class org.infinispan.remoting.transport.jgroups.FileJGroupsChannelConfigurator
 
getPendingActions() - Method in class org.infinispan.util.concurrent.ActionSequencer
 
getPendingActivationCount() - Method in interface org.infinispan.eviction.impl.ActivationManager
 
getPendingActivationCount() - Method in class org.infinispan.eviction.impl.ActivationManagerImpl
 
getPendingActivationCount() - Method in class org.infinispan.eviction.impl.ActivationManagerStub
 
getPendingCH() - Method in class org.infinispan.topology.CacheTopology
The future consistent hash.
getPendingCommands() - Method in class org.infinispan.util.concurrent.CommandAckCollector
 
getPendingTasks() - Method in class org.infinispan.server.core.transport.NettyTransport
 
getPendingTasks() - Method in interface org.infinispan.server.core.transport.Transport
 
getPendingViewAsString() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getPerCacheInboundInvocationHandler() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getComponent(PerCacheInboundInvocationHandler.class);
getPercentageSuccessWriteTransactions() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getPercentageWriteTransactions() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getPercentile(PercentileStatistic, int) - Method in class org.infinispan.extendedstats.CacheStatisticCollector
 
getPercentile(PercentileStatistic, int) - Method in class org.infinispan.extendedstats.CacheStatisticManager
 
getPercentileLocalReadOnlyTransaction(int) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getPercentileLocalRWriteTransaction(int) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getPercentileRemoteReadOnlyTransaction(int) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getPercentileRemoteWriteTransaction(int) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getPermissions() - Method in class org.infinispan.security.impl.CacheRoleImpl
 
getPermissions() - Method in class org.infinispan.security.impl.SubjectACL
 
getPermissions() - Method in interface org.infinispan.security.Role
Returns the list of permissions associated with this role
getPermissions(Subject) - Method in interface org.infinispan.security.AuthorizationManager
Returns the permissions that the specified Subject has for the cache
getPermissions(Subject) - Method in class org.infinispan.security.impl.AuthorizationManagerImpl
 
getPermissions(Subject) - Method in class org.infinispan.security.impl.PermissiveAuthorizationManager
 
getPermissions(AuthorizationConfiguration, Subject) - Method in class org.infinispan.security.impl.Authorizer
 
GetPersistenceManagerAction - Class in org.infinispan.security.actions
 
GetPersistenceManagerAction(EmbeddedCacheManager, String) - Constructor for class org.infinispan.security.actions.GetPersistenceManagerAction
 
getPersistenceMarshaller() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getComponent(PersistenceMarshaller.class, PERSISTENCE_MARSHALLER);
getPersistenceMarshaller() - Method in class org.infinispan.marshall.core.GlobalMarshaller
 
getPersistenceMarshaller() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getPersistenceMarshaller() - Method in interface org.infinispan.persistence.spi.InitializationContext
Returns the persistence marshaller which should be used to marshall/unmarshall all stored bytes.
getPersistenceMarshaller() - Method in class org.infinispan.persistence.support.DelegatingInitializationContext
 
getPersistenceMode(Storage) - Static method in class org.infinispan.counter.impl.Utils
 
getPersistentStateChecksum() - Method in class org.infinispan.topology.CacheJoinInfo
 
getPersistentUuid(Address) - Method in interface org.infinispan.topology.PersistentUUIDManager
Retrieves the PersistentUUID of a node given its Address
getPersistentUuid(Address) - Method in class org.infinispan.topology.PersistentUUIDManagerImpl
 
getPersistentUUID() - Method in class org.infinispan.topology.CacheJoinInfo
 
getPersistentUUID() - Method in interface org.infinispan.topology.LocalTopologyManager
Returns the local UUID of this node.
getPersistentUUID() - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
getPhase() - Method in class org.infinispan.topology.CacheTopology
 
getPhysicalAddresses() - Method in class org.infinispan.manager.CacheManagerInfo
 
getPhysicalAddresses() - Method in class org.infinispan.manager.DefaultCacheManager
 
getPhysicalAddresses() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
getPhysicalAddresses() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getPhysicalAddresses() - Method in interface org.infinispan.remoting.transport.Transport
Retrieves the current cache instance's physical network addresses.
getPhysicalAddressesRaw() - Method in class org.infinispan.manager.CacheManagerInfo
 
getPid() - Method in class org.infinispan.commons.jdkspecific.ProcessInfo
 
getPointerCount() - Method in class org.infinispan.container.offheap.MemoryAddressHash
 
getPoolSize() - Method in class org.infinispan.executors.ManageableExecutorService
 
getPort() - Method in class org.infinispan.server.core.AbstractProtocolServer
 
getPort() - Method in class org.infinispan.server.core.transport.NettyTransport
 
getPort() - Method in interface org.infinispan.server.core.transport.Transport
 
getPort() - Method in class org.infinispan.server.hotrod.MultiHomedServerAddress
 
getPort() - Method in interface org.infinispan.server.hotrod.ServerAddress
 
getPort() - Method in class org.infinispan.server.hotrod.SingleHomedServerAddress
 
getPositionDescription() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
Return string describing current position of parsers as text 'STATE [seen %s...] @line:column'.
getPositionDescription() - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returns a short text describing the current parser state, including the position, a description of the current event and the data source if known.
getPrefix() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
getPrefix() - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returns the prefix of the current element.
getPrefixWildcardOrRegexpQueriesCannotBeFuzzy(String) - Method in interface org.infinispan.query.logging.Log
 
getPreloadedTopologyId() - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
getPreloadedTopologyId() - Method in interface org.infinispan.scattered.ScatteredVersionManager
 
getPreparedTransaction(XidImpl) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Local call returning the remote transaction identified by the supplied xid or null.
getPreparedTransaction(XidImpl) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
getPreparedTransactions() - Method in class org.infinispan.server.hotrod.tx.table.GlobalTxTable
 
getPreparedTransactionsFromCluster() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
Returns the list of transactions in prepared state from both local and remote cluster nodes.
getPreparedTransactionsFromCluster() - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
 
getPrettyName() - Method in enum org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
 
getPrettyName() - Method in enum org.infinispan.commons.tx.lookup.LookupNames.TransactionManagerFactory
 
getPrev() - Method in class org.infinispan.commons.util.KeyValueWithPrevious
 
getPrimaryOwned(int) - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
 
getPrimaryOwned(Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
getPrimaryOwned(Address) - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
 
getPrimaryOwned(Address) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
getPrimaryOwner(int) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
 
getPrimaryOwner(int) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
 
getPrimarySegmentsByServer(byte[]) - Method in class org.infinispan.client.hotrod.impl.TopologyInfo
 
getPrimarySegmentsForOwner(Address) - Method in interface org.infinispan.distribution.ch.ConsistentHash
Returns the segments that this cache member is the primary owner for.
getPrimarySegmentsForOwner(Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
 
getPrimarySegmentsForOwner(Address) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
getPrimarySegmentsForOwner(Address) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
 
getPrincipals() - Method in class org.infinispan.server.core.security.simple.SimpleSubjectUserInfo
 
getPrincipals() - Method in interface org.infinispan.server.core.security.SubjectUserInfo
Get the principals for this user.
getPrivateSingletonSetClass() - Static method in class org.infinispan.marshall.exts.CollectionExternalizer
 
getPrivateSynchronizedSetClass() - Static method in class org.infinispan.marshall.exts.CollectionExternalizer
 
getProjection() - Method in interface org.infinispan.objectfilter.FilterSubscription
The array of '.' separated path names of the projected fields if any, or null otherwise.
getProjection() - Method in interface org.infinispan.objectfilter.ObjectFilter.FilterResult
Returns the projection, if a projection was requested or null otherwise.
getProjection() - Method in interface org.infinispan.objectfilter.ObjectFilter
The array of '.' separated path names of the projected fields if any, or null otherwise.
getProjection() - Method in interface org.infinispan.query.dsl.Query
Deprecated.
since 11.0. This method will be removed in next major version. To find out if a query uses projections use Query.hasProjections()
getProjection() - Method in class org.infinispan.query.remote.client.FilterResult
Returns the projection, if a projection was requested or null otherwise.
getProjectionType() - Method in class org.infinispan.search.mapper.mapping.metamodel.ValueFieldMetamodel
 
getProjectionTypes() - Method in interface org.infinispan.objectfilter.ObjectFilter
The types of the projects paths (see ObjectFilter.getProjection() or null if there are no projections.
getProperties() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getProperties() - Method in class org.infinispan.client.hotrod.impl.HotRodURI
 
getProperties() - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationReader
 
getProperties() - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
getProperty(String) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationReader
 
getProperty(String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
getProperty(String) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
getProperty(String) - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Look up the value of a property.
getProperty(String) - Static method in class org.infinispan.commons.util.Version
 
getProperty(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
getProperty(String) - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
 
getProperty(String) - Method in interface org.infinispan.globalstate.ScopedPersistentState
Retrieves a state property
getProperty(String, boolean) - Method in class org.infinispan.commons.util.TypedProperties
Get the property associated with the key, optionally applying string property replacement as defined in StringPropertyReplacer.replaceProperties(java.lang.String) to the result.
getProperty(String, String) - Static method in class org.infinispan.commons.util.LegacyKeySupportSystemProperties
 
getProperty(String, String, boolean) - Method in class org.infinispan.commons.util.TypedProperties
Get the property associated with the key, optionally applying string property replacement as defined in StringPropertyReplacer.replaceProperties(java.lang.String) to the result.
getProperty(String, String, String) - Static method in class org.infinispan.commons.util.LegacyKeySupportSystemProperties
 
getProtocolServer() - Method in class org.infinispan.rest.InvocationHelper
 
getProtocolServers() - Method in interface org.infinispan.server.core.ServerManagement
 
getProtocolStack() - Method in class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator
 
getProtocolStack() - Method in class org.infinispan.remoting.transport.jgroups.FileJGroupsChannelConfigurator
 
getProtocolStackString() - Method in class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator
 
getProtocolStackString() - Method in class org.infinispan.remoting.transport.jgroups.FileJGroupsChannelConfigurator
 
getProtocolVersion() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getProtocolVersion() - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
getProtocolVersion() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getProtocolVersion() - Method in interface org.infinispan.client.hotrod.RemoteCache
Returns the HotRod protocol version supported by this RemoteCache implementation
getProtofile(String) - Method in interface org.infinispan.query.remote.client.ProtobufMetadataManagerMBean
Gets the contents of a registered *.proto schema file.
getProtoFile() - Method in class org.infinispan.commons.GlobalContextInitializerImpl
 
getProtoFile() - Method in class org.infinispan.commons.marshall.PersistenceContextInitializerImpl
 
getProtoFile() - Method in class org.infinispan.commons.marshall.UserContextInitializerImpl
 
getProtoFile() - Method in class org.infinispan.multimap.impl.PersistenceContextInitializerImpl
 
getProtoFile() - Method in class org.infinispan.persistence.jdbc.impl.PersistenceContextInitializerImpl
 
getProtoFile() - Method in class org.infinispan.persistence.rocksdb.PersistenceContextInitializerImpl
 
getProtoFile() - Method in class org.infinispan.query.impl.PersistenceContextInitializerImpl
 
getProtoFile() - Method in class org.infinispan.rest.distribution.DataDistributionContextInitializerImpl
 
getProtoFile() - Method in class org.infinispan.server.core.PersistenceContextInitializerImpl
 
getProtoFile() - Method in class org.infinispan.server.memcached.PersistenceContextInitializerImpl
 
getProtoFile() - Method in class org.infinispan.spring.common.session.PersistenceContextInitializerImpl
 
getProtoFileName() - Method in class org.infinispan.commons.GlobalContextInitializerImpl
 
getProtoFileName() - Method in class org.infinispan.commons.marshall.PersistenceContextInitializerImpl
 
getProtoFileName() - Method in class org.infinispan.commons.marshall.UserContextInitializerImpl
 
getProtoFileName() - Method in class org.infinispan.multimap.impl.PersistenceContextInitializerImpl
 
getProtoFileName() - Method in class org.infinispan.persistence.jdbc.impl.PersistenceContextInitializerImpl
 
getProtoFileName() - Method in class org.infinispan.persistence.rocksdb.PersistenceContextInitializerImpl
 
getProtoFileName() - Method in class org.infinispan.query.impl.PersistenceContextInitializerImpl
 
getProtoFileName() - Method in class org.infinispan.rest.distribution.DataDistributionContextInitializerImpl
 
getProtoFileName() - Method in class org.infinispan.server.core.PersistenceContextInitializerImpl
 
getProtoFileName() - Method in class org.infinispan.server.memcached.PersistenceContextInitializerImpl
 
getProtoFileName() - Method in class org.infinispan.spring.common.session.PersistenceContextInitializerImpl
 
getProtofileNames() - Method in interface org.infinispan.query.remote.client.ProtobufMetadataManagerMBean
Get the full names of all registered schema files.
getProtoFileReader() - Method in class org.infinispan.commons.GlobalContextInitializerImpl
 
getProtoFileReader() - Method in class org.infinispan.commons.marshall.PersistenceContextInitializerImpl
 
getProtoFileReader() - Method in class org.infinispan.commons.marshall.UserContextInitializerImpl
 
getProtoFileReader() - Method in class org.infinispan.multimap.impl.PersistenceContextInitializerImpl
 
getProtoFileReader() - Method in class org.infinispan.persistence.jdbc.impl.PersistenceContextInitializerImpl
 
getProtoFileReader() - Method in class org.infinispan.persistence.rocksdb.PersistenceContextInitializerImpl
 
getProtoFileReader() - Method in class org.infinispan.query.impl.PersistenceContextInitializerImpl
 
getProtoFileReader() - Method in class org.infinispan.rest.distribution.DataDistributionContextInitializerImpl
 
getProtoFileReader() - Method in class org.infinispan.server.core.PersistenceContextInitializerImpl
 
getProtoFileReader() - Method in class org.infinispan.server.memcached.PersistenceContextInitializerImpl
 
getProtoFileReader() - Method in class org.infinispan.spring.common.session.PersistenceContextInitializerImpl
 
getProxies() - Method in class org.infinispan.commons.maven.MavenSettings
 
getProxyFor(URL) - Method in class org.infinispan.commons.maven.MavenSettings
 
getPublisherHandler() - Method in class org.infinispan.factories.ComponentRegistry
 
getQualifiedLocation(GlobalConfiguration, String, String, String) - Static method in class org.infinispan.persistence.PersistenceUtil
 
getQualifiedName() - Method in class org.infinispan.server.core.AbstractProtocolServer
 
getQualifiedResources(BackupManager.Resources.Type) - Method in class org.infinispan.server.core.backup.BackupManagerResources
 
getQualifiedResources(BackupManager.Resources.Type) - Method in interface org.infinispan.server.core.BackupManager.Resources
 
getQueriesJdbcConfiguration() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfiguration
 
getQuery() - Method in class org.infinispan.query.remote.json.JsonQueryRequest
 
getQueryCache(Cache<?, ?>) - Static method in class org.infinispan.query.impl.ComponentRegistryUtils
Returns the optional QueryCache.
getQueryFactory(Cache<?, ?>) - Static method in class org.infinispan.query.Search
Obtains a query factory to build DSL-based Ickle queries.
getQueryFactory(RemoteCache<?, ?>) - Static method in class org.infinispan.client.hotrod.Search
 
getQueryInterceptor(Cache<?, ?>) - Static method in class org.infinispan.query.impl.ComponentRegistryUtils
 
getQueryStatistics(AdvancedCache<?, ?>) - Static method in class org.infinispan.query.impl.ComponentRegistryUtils
 
getQueryString() - Method in interface org.infinispan.query.dsl.Query
Returns the Ickle query string.
getQueryString() - Method in class org.infinispan.query.impl.QueryDefinition
 
getQueueCount() - Method in class org.infinispan.configuration.cache.IndexWriterConfiguration
 
getQueueSize() - Method in class org.infinispan.configuration.cache.IndexWriterConfiguration
 
getQueueSize() - Method in class org.infinispan.executors.ManageableExecutorService
 
getQueueSize() - Method in class org.infinispan.xsite.irac.DefaultIracManager
 
getRack() - Method in class org.infinispan.distribution.topologyaware.TopologyInfo.Node
 
getRackId() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
 
getRackId() - Method in interface org.infinispan.remoting.transport.TopologyAwareAddress
 
getRackIndex(Address) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getRackMachines(String, String) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getRackNodes(String, String) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getRamBufferSize() - Method in class org.infinispan.configuration.cache.IndexWriterConfiguration
 
getRaw() - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
Deprecated.
Gets the internal buffer array.
getRaw() - Method in class org.infinispan.io.ImmutableMarshalledValueByteStream
Deprecated.
 
getRaw() - Method in class org.infinispan.io.MarshalledValueByteStream
Deprecated.
 
getRawBuffer() - Method in class org.infinispan.commons.io.ExposedByteArrayOutputStream
Deprecated.
Gets the internal buffer array.
getRawBuffer() - Method in class org.infinispan.commons.io.LazyByteArrayOutputStream
Gets the internal buffer array.
getReadableChannel(String) - Method in class org.infinispan.io.GridFilesystem
Deprecated.
Opens a ReadableGridFileChannel for reading from the file denoted by the given file path.
getReadConsistentHash() - Method in interface org.infinispan.distribution.DistributionManager
Deprecated, for removal: This API element is subject to removal in a future version.
Since 11.0, to be removed in 14.0. Please use DistributionManager.getCacheTopology() instead.
getReadConsistentHash() - Method in class org.infinispan.distribution.impl.DistributionManagerImpl
 
getReadConsistentHash() - Method in class org.infinispan.topology.CacheTopology
Read operations should always go to the "current" owners.
getReadConsistentHashAtEnd() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getReadConsistentHashAtEnd() - Method in interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
 
getReadConsistentHashAtStart() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getReadConsistentHashAtStart() - Method in interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
 
getReadTimeout() - Method in class org.infinispan.spring.remote.provider.SpringRemoteCacheManager
 
getReadWriteRatio() - Method in interface org.infinispan.stats.CacheContainerStats
Deprecated.
 
getReadWriteRatio() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getReadWriteRatio() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getReadWriteRatio() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getReadWriteRatio() - Method in class org.infinispan.stats.impl.StatsCollector
 
getRealm() - Method in class org.infinispan.client.hotrod.security.BasicCallbackHandler
 
getReaper() - Method in interface org.infinispan.server.hotrod.iteration.IterationState
 
getRebalanceId() - Method in class org.infinispan.topology.CacheTopology
The id of the latest started rebalance.
getRebalancingStatus() - Method in class org.infinispan.topology.ClusterCacheStatus
 
getRebalancingStatus(String) - Method in interface org.infinispan.topology.ClusterTopologyManager
Retrieves the rebalancing status of a cache
getRebalancingStatus(String) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
getRebalancingStatus(String) - Method in interface org.infinispan.topology.LocalTopologyManager
Retrieve the rebalancing status for the specified cache
getRebalancingStatus(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
getReceiveBufferSize() - Method in class org.infinispan.server.core.transport.NettyTransport
 
getReceiveBufferSize() - Method in interface org.infinispan.server.core.transport.Transport
 
getRecoveryManager() - Method in class org.infinispan.factories.ComponentRegistry
 
getRefreshInterval() - Method in class org.infinispan.configuration.cache.IndexReaderConfiguration
 
getRegexps() - Method in class org.infinispan.configuration.global.AllowListConfiguration
 
getRegexps() - Method in class org.infinispan.configuration.global.WhiteListConfiguration
Deprecated.
 
getRegisteredComponents() - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
Run consumer for each registered component in the current scope.
getRegisteredComponents() - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
 
getRelayNodesAddress() - Method in class org.infinispan.manager.CacheManagerInfo
 
getRelayNodesAddress() - Method in class org.infinispan.manager.DefaultCacheManager
 
getRelayNodesAddress() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
getRelayNodesAddress() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getRelayNodesAddress() - Method in interface org.infinispan.remoting.transport.Transport
 
getReleaseFutureForKey(Object) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getReleaseFutureForKey(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
It returns a CompletableFuture that completes when the lock for the key is released.
getReleaseFutureForKeys(Collection<Object>) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getReleaseFutureForKeys(Collection<Object>) - Method in interface org.infinispan.transaction.xa.CacheTransaction
Same as CacheTransaction.getReleaseFutureForKey(Object) but it returns a pair with the key and the future.
getRemainingTimeout() - Method in interface org.infinispan.util.concurrent.locks.PendingLockPromise
 
getRemote(ExtendedStatistic) - Method in class org.infinispan.extendedstats.container.StatisticsSnapshot
 
getRemoteAddress() - Method in interface org.infinispan.rest.framework.RestRequest
 
getRemoteAddress() - Method in class org.infinispan.rest.NettyRestRequest
 
getRemoteBias(Object) - Method in interface org.infinispan.scattered.BiasManager
 
getRemoteBias(Object) - Method in class org.infinispan.scattered.impl.BiasManagerImpl
 
getRemoteCache() - Method in class org.infinispan.persistence.remote.RemoteStore
 
getRemoteCacheContainer() - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
getRemoteCacheContainer() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getRemoteCacheContainer() - Method in interface org.infinispan.client.hotrod.RemoteCache
Returns the RemoteCacheContainer that created this cache.
getRemoteCacheManager() - Method in interface org.infinispan.client.hotrod.RemoteCache
Deprecated, for removal: This API element is subject to removal in a future version.
Since 14.0. Use RemoteCache.getRemoteCacheContainer() instead.
getRemoteGetExecutionTime() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getRemoteGlobalTransaction() - Method in class org.infinispan.transaction.impl.TransactionTable
 
getRemoteGlobalTransaction() - Method in interface org.infinispan.transaction.TransactionTable
 
getRemoteHits() - Method in class org.infinispan.client.hotrod.impl.ClientStatistics
 
getRemoteHits() - Method in interface org.infinispan.client.hotrod.jmx.RemoteCacheClientStatisticsMXBean
Returns the number of hits for a remote cache.
getRemoteIndex() - Method in enum org.infinispan.extendedstats.container.ExtendedStatistic
 
getRemoteIndex(ExtendedStatistic) - Static method in class org.infinispan.extendedstats.container.ConcurrentGlobalContainer
 
getRemoteLocksAcquired() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
getRemoteLocksAcquired() - Method in class org.infinispan.transaction.impl.LocalTransaction
 
getRemoteMisses() - Method in class org.infinispan.client.hotrod.impl.ClientStatistics
 
getRemoteMisses() - Method in interface org.infinispan.client.hotrod.jmx.RemoteCacheClientStatisticsMXBean
Returns the number of misses for a remote cache.
getRemotePutExecutionTime() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getRemoteRemoves() - Method in class org.infinispan.client.hotrod.impl.ClientStatistics
 
getRemoteRemoves() - Method in interface org.infinispan.client.hotrod.jmx.RemoteCacheClientStatisticsMXBean
Returns the number of removes for a remote cache.
getRemoteRepositories() - Method in class org.infinispan.commons.maven.MavenSettings
 
getRemoteSites() - Method in class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator
 
getRemoteSites() - Method in class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.RemoteSites
 
getRemoteStatsSize() - Static method in enum org.infinispan.extendedstats.container.ExtendedStatistic
 
getRemoteStoreBuilder() - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
 
getRemoteStores() - Method in class org.infinispan.client.hotrod.impl.ClientStatistics
 
getRemoteStores() - Method in interface org.infinispan.client.hotrod.jmx.RemoteCacheClientStatisticsMXBean
Returns the number of remote cache stores (put, replace) that the client applied.
getRemoteTopGets() - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
 
getRemoteTopPuts() - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
 
getRemoteTransaction(GlobalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
Returns the RemoteTransaction associated with the supplied transaction id.
getRemoteTransaction(GlobalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
 
getRemoteTransactions() - Method in class org.infinispan.transaction.impl.TransactionTable
 
getRemoteTransactionXid(Long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
Iterates over the remote transactions and returns the XID of the one that has an internal id equal with the supplied internal Id.
getRemoteTxCount() - Method in class org.infinispan.transaction.impl.TransactionTable
 
getRemoveHits() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getRemoveHits() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getRemoveHits() - Method in class org.infinispan.stats.impl.StatsCollector
 
getRemoveHits() - Method in class org.infinispan.stats.impl.StatsImpl
 
getRemoveHits() - Method in interface org.infinispan.stats.Stats
 
getRemoveMisses() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getRemoveMisses() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getRemoveMisses() - Method in class org.infinispan.stats.impl.StatsCollector
 
getRemoveMisses() - Method in class org.infinispan.stats.impl.StatsImpl
 
getRemoveMisses() - Method in interface org.infinispan.stats.Stats
 
getReplicationCount() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getReplicationDegree() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getReplicationFailures() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
GetRequest - Enum constant in enum org.infinispan.server.memcached.MemcachedOperation
 
getRequestBalancingStrategy() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getRequestId() - Method in class org.infinispan.remoting.transport.AbstractRequest
 
getRequestId() - Method in interface org.infinispan.remoting.transport.impl.Request
 
getRequestMediaType() - Method in class org.infinispan.encoding.DataConversion
 
getRequestOpCode() - Method in enum org.infinispan.server.hotrod.HotRodOperation
 
getRequestor() - Method in interface org.infinispan.util.concurrent.locks.ExtendedLockPromise
 
getRequiredDependencies() - Method in interface org.infinispan.factories.impl.ModuleMetadataBuilder
 
getRequiredMinimumNumberOfNodes() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getRequiredMinimumNumberOfNodes() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getRequiredMinimumNumberOfNodes() - Method in class org.infinispan.stats.impl.StatsCollector
 
getRequiredMinimumNumberOfNodes() - Method in class org.infinispan.stats.impl.StatsImpl
 
getRequiredMinimumNumberOfNodes() - Method in interface org.infinispan.stats.Stats
 
getResourceAsStream(String, ClassLoader) - Static method in class org.infinispan.commons.util.Util
 
getResourceAsString(String, ClassLoader) - Static method in class org.infinispan.commons.util.Util
 
getResourceResolver() - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationReader
 
getResourceResolver() - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
getResourceResolver() - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationReader
 
getResources(String) - Method in class org.infinispan.commons.util.AggregatedClassLoader
 
getResources(BackupManager.Resources, BlockingManager, EmbeddedCacheManager, GlobalComponentRegistry, ParserRegistry, Path) - Static method in class org.infinispan.server.core.backup.resources.ContainerResourceFactory
 
getResponse() - Method in class org.infinispan.rest.NettyRestResponse
 
getResponse(CacheRpcCommand, Object) - Method in class org.infinispan.remoting.responses.DefaultResponseGenerator
 
getResponse(CacheRpcCommand, Object) - Method in interface org.infinispan.remoting.responses.ResponseGenerator
 
getResponseGenerator() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getComponent(ResponseGenerator.class);
getResponseOpCode() - Method in enum org.infinispan.server.hotrod.HotRodOperation
 
getResponseValue() - Method in class org.infinispan.remoting.responses.PrepareResponse
 
getResponseValue() - Method in class org.infinispan.remoting.responses.SuccessfulResponse
 
getResponseValue() - Method in class org.infinispan.remoting.responses.UnsuccessfulResponse
 
getResponseValue() - Method in class org.infinispan.remoting.responses.UnsureResponse
 
getResponseValue() - Method in class org.infinispan.remoting.responses.ValidResponse
 
getRestCacheManager() - Method in class org.infinispan.rest.InvocationHelper
 
getRestChannelInitializer() - Method in class org.infinispan.rest.RestServer
Returns Netty Channel Initializer for REST.
getRestHandler() - Method in class org.infinispan.rest.RestChannelInitializer
 
getRestoreNames() - Method in class org.infinispan.server.core.backup.BackupManagerImpl
 
getRestoreNames() - Method in interface org.infinispan.server.core.BackupManager
 
getRestoreStatus(String) - Method in class org.infinispan.server.core.backup.BackupManagerImpl
 
getRestoreStatus(String) - Method in interface org.infinispan.server.core.BackupManager
Return the current BackupManager.Status of a Restore request.
getResultFunction() - Method in class org.infinispan.server.hotrod.iteration.IterableIterationResult
 
getResultSize() - Method in interface org.infinispan.query.dsl.Query
Deprecated.
since 10.1. This will be removed in 12. It's closest replacement is QueryResult.hitCount() which returns an optional long.
getResultSize() - Method in interface org.infinispan.query.impl.IndexedQuery
 
getResultSize() - Method in class org.infinispan.query.impl.IndexedQueryImpl
 
getRetries() - Method in interface org.infinispan.client.hotrod.jmx.RemoteCacheManagerMXBean
Returns the total number of retries that have been executed
getRetries() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
getRetrievals() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getRetrievals() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getRetrievals() - Method in class org.infinispan.stats.impl.StatsCollector
 
getRetrievals() - Method in class org.infinispan.stats.impl.StatsImpl
 
getRetrievals() - Method in interface org.infinispan.stats.Stats
 
getReturnType() - Method in class org.infinispan.factories.impl.MBeanMetadata.OperationMetadata
 
getRole(String) - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
getRole(String) - Method in class org.infinispan.security.mappers.ClusterPermissionMapper
 
getRole(String) - Method in interface org.infinispan.security.RolePermissionMapper
 
getRoles() - Method in class org.infinispan.security.impl.SubjectACL
 
getRoles() - Method in class org.infinispan.security.mappers.ClusterRoleMapper.RoleSet
 
getRollbackException() - Method in class org.infinispan.commons.tx.TransactionImpl
 
getRootCause(Throwable) - Static method in class org.infinispan.commons.util.Util
 
getRoutingTableAsString() - Method in interface org.infinispan.distribution.ch.ConsistentHash
Returns a string containing all the segments and their associated addresses.
getRoutingTableAsString() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
 
getRoutingTableAsString() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
getRoutingTableAsString() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
 
getRow() - Method in exception class org.infinispan.commons.dataconversion.internal.Json.MalformedJsonException
 
getRpcManager() - Method in interface org.infinispan.AdvancedCache
Returns the component in charge of communication with other caches in the cluster.
getRpcManager() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getRpcManager() - Method in class org.infinispan.cache.impl.CacheImpl
 
getRpcManager() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getRpcManager() - Method in class org.infinispan.factories.ComponentRegistry
 
getRpcManager() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getRpcManager() - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateProvider
 
getRpcManager() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateProvider
getRpcManager() - Method in class org.infinispan.xsite.statetransfer.XSiteStateProviderImpl
 
getRunningActions() - Method in class org.infinispan.util.concurrent.ActionSequencer
 
getRunningCacheCount() - Method in class org.infinispan.manager.CacheManagerInfo
 
getRunningCacheCount() - Method in class org.infinispan.manager.DefaultCacheManager
 
getRunningStateTransfers() - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateTransferManager
 
getRunningStateTransfers() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
 
getRunningStateTransfers() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
getSaslClientFactories(ClassLoader, Provider[], boolean) - Static method in class org.infinispan.commons.util.SaslUtils
Returns a collection of all the registered SaslClientFactorys where the order is based on the order of the Provider registration and/or class path order.
getSaslMechanism() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getSaslServerFactories(ClassLoader, Provider[], boolean) - Static method in class org.infinispan.commons.util.SaslUtils
Returns a collection of all of the registered SaslServerFactorys where the order is based on the order of the Provider registration and/or class path order.
getScheduledExecutor(Properties) - Method in class org.infinispan.executors.DefaultScheduledExecutorFactory
 
getScheduledExecutor(Properties) - Method in interface org.infinispan.executors.ScheduledExecutorFactory
 
getScheduledExecutor(Properties, AccessControlContext) - Method in class org.infinispan.executors.DefaultScheduledExecutorFactory
 
getScheduledExecutor(Properties, AccessControlContext) - Method in interface org.infinispan.executors.SecurityAwareScheduledExecutorFactory
 
getScheduledExecutorService() - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateProvider
 
getScheduledExecutorService() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateProvider
getScheduledExecutorService() - Method in class org.infinispan.xsite.statetransfer.XSiteStateProviderImpl
 
getScheduledTasks() - Method in class org.infinispan.executors.ExecutorAllCompletionService
 
getSchema() - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationReader
 
getSchema() - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
 
getSchemaJdbcConfiguration() - Method in class org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfiguration
Deprecated, for removal: This API element is subject to removal in a future version.
getSchemaVersion() - Static method in class org.infinispan.commons.util.Version
 
getSchemaVersion() - Static method in class org.infinispan.Version
Deprecated.
 
getScope() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
 
getScope() - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
 
getScope() - Method in interface org.infinispan.globalstate.ScopedPersistentState
Returns the name of this persistent state's scope
getScope() - Method in class org.infinispan.globalstate.ScopedState
 
getScript(String) - Method in interface org.infinispan.scripting.ScriptingManager
Retrieves the source code of an existing script.
getScriptNames() - Method in interface org.infinispan.scripting.ScriptingManager
Retrieves names of all available scripts.
getSearchIndexer() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
 
getSearchIndexer() - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
 
getSearchMapping(Cache<?, ?>) - Static method in class org.infinispan.query.impl.ComponentRegistryUtils
 
getSearchQueryBuilder() - Method in class org.infinispan.query.impl.QueryDefinition
 
getSearchQueryExecutionAvgTime() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getSearchQueryExecutionCount() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getSearchQueryExecutionMaxTime() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getSearchQueryExecutionMaxTimeQueryString() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getSearchQueryTotalTime() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getSearchStatistics(Cache<K, V>) - Static method in class org.infinispan.query.Search
Returns search statistics for the local node.
getSearchStatsRetriever(Cache<?, ?>) - Static method in class org.infinispan.query.impl.ComponentRegistryUtils
 
getSearchVersion() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
 
getSecurityBuilder() - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
 
getSecurityPermission() - Method in enum org.infinispan.security.AuthorizationPermission
 
getSegment() - Method in interface org.infinispan.commands.SegmentSpecificCommand
Returns the segment that this key maps to.
getSegment() - Method in class org.infinispan.commons.util.SegmentAwareKey
 
getSegment() - Method in class org.infinispan.container.versioning.irac.IracTombstoneInfo
 
getSegment() - Method in interface org.infinispan.persistence.spi.NonBlockingStore.SegmentedPublisher
Returns the segment for all keys in the publisher.
getSegment() - Method in class org.infinispan.persistence.support.SegmentPublisherWrapper
 
getSegment() - Method in class org.infinispan.persistence.support.SingleSegmentPublisher
 
getSegment() - Method in class org.infinispan.reactive.publisher.impl.PublisherHandler.SegmentResult
 
getSegment() - Method in interface org.infinispan.xsite.irac.IracManagerKeyInfo
 
getSegment() - Method in class org.infinispan.xsite.irac.IracManagerKeyInfoImpl
 
getSegment(Object) - Method in class org.infinispan.distribution.ch.impl.AffinityPartitioner
 
getSegment(Object) - Method in class org.infinispan.distribution.ch.impl.HashFunctionPartitioner
 
getSegment(Object) - Method in class org.infinispan.distribution.ch.impl.SingleSegmentKeyPartitioner
 
getSegment(Object) - Method in interface org.infinispan.distribution.ch.KeyPartitioner
Obtains the segment for a key.
getSegment(Object) - Method in class org.infinispan.distribution.group.impl.GroupingPartitioner
 
getSegment(Object) - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
getSegmentDistribution(int) - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
getSegmentEndHashes() - Method in class org.infinispan.distribution.ch.impl.HashFunctionPartitioner
 
getSegmentForKey(Object) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
 
getSegmentForKey(Object) - Method in class org.infinispan.container.impl.DefaultDataContainer
 
getSegmentForKey(Object) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
 
getSegmentForKey(Object) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
 
getSegmentMax() - Method in class org.infinispan.persistence.sifs.TemporaryTable
 
getSegmentsForOwner(Address) - Method in interface org.infinispan.distribution.ch.ConsistentHash
Returns the segments owned by a cache member.
getSegmentsForOwner(Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
 
getSegmentsForOwner(Address) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
 
getSegmentsForOwner(Address) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
 
getSegmentSize(int) - Static method in class org.infinispan.commons.util.Util
Returns the size of each segment, given a number of segments.
getSegmentsPerServer() - Method in interface org.infinispan.client.hotrod.CacheTopologyInfo
 
getSegmentsPerServer() - Method in class org.infinispan.client.hotrod.impl.CacheTopologyInfoImpl
 
getSegmentState(int) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
 
getSegmentState(int) - Method in interface org.infinispan.scattered.ScatteredVersionManager
 
getSelectAllSql(IntSet) - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
 
getSelectAllSql(IntSet) - Method in class org.infinispan.persistence.sql.QueriesJdbcStore.QueryTableOperations
 
getSelectAllSql(IntSet) - Method in class org.infinispan.persistence.sql.TableJdbcStore.TableTableOperations
 
getSelectAllStatement(List<String>) - Method in interface org.infinispan.persistence.jdbc.common.SqlManager
 
getSelectRowSql() - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
 
getSelectRowSql() - Method in class org.infinispan.persistence.sql.QueriesJdbcStore.QueryTableOperations
 
getSelectRowSql() - Method in class org.infinispan.persistence.sql.TableJdbcStore.TableTableOperations
 
getSelectStatement(List<String>, List<String>) - Method in interface org.infinispan.persistence.jdbc.common.SqlManager
 
getSendBufferSize() - Method in class org.infinispan.server.core.transport.NettyTransport
 
getSendBufferSize() - Method in interface org.infinispan.server.core.transport.Transport
 
getSendingSiteName() - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateTransferManager
 
getSendingSiteName() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateConsumer
 
getSendingSiteName() - Method in class org.infinispan.xsite.statetransfer.XSiteStateConsumerImpl
 
getSendingSiteName() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
 
getSendingSiteName() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
getSendTimeMillis() - Method in class org.infinispan.remoting.transport.AggregateBackupResponse
 
getSendTimeMillis() - Method in interface org.infinispan.remoting.transport.BackupResponse
Return the time in millis when this operation was initiated.
getSendTimeMillis() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsBackupResponse
 
getSerializationContext() - Method in class org.infinispan.commons.marshall.ImmutableProtoStreamMarshaller
 
getSerializationContext() - Method in class org.infinispan.commons.marshall.ProtoStreamMarshaller
 
getSerializationContext(RemoteCacheContainer) - Static method in class org.infinispan.client.hotrod.marshall.MarshallerUtil
A convenience method to return the SerializationContext associated with the ProtoStreamMarshaller configured on the provided RemoteCacheManager.
getSerializationContext(RemoteCacheManager) - Static method in class org.infinispan.client.hotrod.marshall.ProtoStreamMarshaller
Deprecated, for removal: This API element is subject to removal in a future version.
since 10.0 and will be removed in the future. Use MarshallerUtil.getSerializationContext(RemoteCacheManager) instead.
getSerializedBytes() - Method in class org.infinispan.spring.common.session.MapSessionProtoAdapter.SessionAttribute
 
getServer() - Method in class org.infinispan.rest.InvocationHelper
 
getServerAddress() - Method in exception class org.infinispan.client.hotrod.exceptions.RemoteIllegalLifecycleStateException
 
getServerAddress() - Method in exception class org.infinispan.client.hotrod.exceptions.TransportException
 
getServerDataPath() - Method in interface org.infinispan.server.core.ServerManagement
 
getServerList() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getServerReport() - Method in interface org.infinispan.server.core.ServerManagement
 
getServers() - Method in interface org.infinispan.client.hotrod.jmx.RemoteCacheManagerMXBean
Returns a list of servers to which the client is currently connected in the format of ip_address:port_number.
getServers() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
 
getServers(WrappedBytes) - Method in class org.infinispan.client.hotrod.impl.TopologyInfo
 
getServerStateManager() - Method in class org.infinispan.server.core.AbstractProtocolServer
 
getServerStateManager() - Method in interface org.infinispan.server.core.ServerManagement
 
getSignature() - Method in class org.infinispan.factories.impl.MBeanMetadata.OperationMetadata
 
getSite() - Method in class org.infinispan.container.versioning.irac.IracEntryVersion.MapEntry
 
getSite() - Method in class org.infinispan.distribution.topologyaware.TopologyInfo.Node
 
getSite() - Method in class org.infinispan.manager.DefaultCacheManager
 
getSite() - Method in class org.infinispan.metadata.impl.IracMetadata
 
getSiteId() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
 
getSiteId() - Method in interface org.infinispan.remoting.transport.TopologyAwareAddress
 
getSiteIndex(Address) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getSiteName() - Method in class org.infinispan.xsite.events.XSiteEvent
 
getSiteName() - Method in class org.infinispan.xsite.spi.SiteEntry
 
getSiteName() - Method in class org.infinispan.xsite.statetransfer.RemoteSiteStatus
 
getSiteNodes(String) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getSiteRacks(String) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
 
getSites() - Method in class org.infinispan.manager.CacheManagerInfo
 
getSites() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
getSites() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.SitesViewChangedEvent
 
getSitesMissingCoordinator(Collection<Address>) - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateProvider
 
getSitesMissingCoordinator(Collection<Address>) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateProvider
 
getSitesMissingCoordinator(Collection<Address>) - Method in class org.infinispan.xsite.statetransfer.XSiteStateProviderImpl
 
getSiteState(String) - Method in class org.infinispan.xsite.status.DefaultTakeOfflineManager
 
getSiteState(String) - Method in class org.infinispan.xsite.status.NoOpTakeOfflineManager
 
getSiteState(String) - Method in interface org.infinispan.xsite.status.TakeOfflineManager
Returns the site state for site siteName.
getSitesView() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getSitesView() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
getSitesView() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getSitesView() - Method in interface org.infinispan.remoting.transport.Transport
Get the view of interconnected sites.
getSiteView() - Method in class org.infinispan.manager.DefaultCacheManager
 
getSize(long) - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
 
getSize(long, boolean) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
Returns how many bytes in memory this address location uses assuming it is an InternalCacheEntry.
getSize(long, boolean) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
 
getSizeCommand() - Method in interface org.infinispan.persistence.jdbc.common.SqlManager
 
getSizeSql() - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
 
getSizeSql() - Method in class org.infinispan.persistence.sql.QueriesJdbcStore.QueryTableOperations
 
getSizeSql() - Method in class org.infinispan.persistence.sql.TableJdbcStore.TableTableOperations
 
getSnapshot() - Method in class org.infinispan.extendedstats.container.ConcurrentGlobalContainer
 
getSniHostName() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getSocketFactory() - Method in class org.infinispan.remoting.transport.jgroups.AbstractJGroupsChannelConfigurator
 
getSortFields() - Method in interface org.infinispan.objectfilter.FilterSubscription
The array of sort specifications if defined, or null otherwise.
getSortFields() - Method in interface org.infinispan.objectfilter.ObjectFilter
The array of sort specifications if defined, or null otherwise.
getSortProjection() - Method in interface org.infinispan.objectfilter.ObjectFilter.FilterResult
Returns the projection of fields used for sorting, if sorting was requested or null otherwise.
getSortProjection() - Method in class org.infinispan.query.remote.client.FilterResult
Returns the projection of fields that appear in the 'order by' clause, if any, or null otherwise.
getSoTimeout() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getSource() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryEvent
 
getSource() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getSqlToUse() - Method in class org.infinispan.persistence.sql.QueryNamedParameterParser.ParserResults
 
getSqlType() - Method in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.Parameter
 
getSSLProtocol() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getSslProvider() - Static method in class org.infinispan.commons.util.SslContextFactory
 
getStableCacheTopology(String) - Method in interface org.infinispan.topology.LocalTopologyManager
 
getStableCacheTopology(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
 
getStableTopology() - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
Whenever a new cache topology without a pendingCH and with at least numOwners owners for each segment is installed, and the cache is AvailabilityMode.AVAILABLE, the current cache topology is marked as the stable topology.
getStableTopology() - Method in class org.infinispan.topology.CacheStatusResponse
 
getStableTopology() - Method in class org.infinispan.topology.ClusterCacheStatus
 
getStack() - Method in class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.RemoteSite
 
getStaleStatsThreshold() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getStaleStatsThreshold() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getStaleStatsThreshold() - Method in interface org.infinispan.stats.ClusterContainerStats
 
getStaleStatsThreshold() - Method in class org.infinispan.stats.impl.ClusterContainerStatsImpl
 
getStaleStatsThreshold() - Method in class org.infinispan.stats.impl.AbstractClusterStats
 
getStaleStatsThreshold() - Method in class org.infinispan.stats.impl.LocalContainerStatsImpl
 
getStandalone() - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
 
getStartOffset() - Method in interface org.infinispan.query.dsl.Query
 
getStartOffset() - Method in class org.infinispan.query.remote.json.JsonQueryRequest
 
getStat(String) - Method in class org.infinispan.stats.impl.AbstractClusterStats
 
getStat(String) - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getStat(String) - Method in class org.infinispan.stats.impl.ClusterContainerStatsImpl
 
getStat(String) - Method in class org.infinispan.stats.impl.LocalContainerStatsImpl
 
getState(CacheXid) - Method in class org.infinispan.server.hotrod.tx.table.GlobalTxTable
 
getStateCache() - Method in interface org.infinispan.globalstate.GlobalConfigurationManager
Returns the global state cache
getStateCache() - Method in class org.infinispan.globalstate.impl.GlobalConfigurationManagerImpl
 
getStateConsumer() - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateTransferManager
 
getStateConsumer() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
 
getStateConsumer() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
getStatement() - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations.FlowableConnection
 
getStatementType() - Method in class org.infinispan.query.impl.QueryDefinition
 
getStateProvider() - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateTransferManager
 
getStateProvider() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
 
getStateProvider() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
getStateTransferFlag() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getStateTransferLock() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getComponent(StateTransferManager.class);
getStateTransferManager() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getComponent(StateTransferManager.class);
getStatistic(String) - Method in class org.infinispan.client.hotrod.impl.ServerStatisticsImpl
 
getStatistic(String) - Method in interface org.infinispan.client.hotrod.ServerStatistics
 
getStatisticsEnabled() - Method in class org.infinispan.eviction.impl.ActivationManagerImpl
 
getStatisticsEnabled() - Method in class org.infinispan.eviction.impl.PassivationManagerImpl
 
getStatisticsEnabled() - Method in class org.infinispan.eviction.impl.PassivationManagerStub
 
getStatisticsEnabled() - Method in interface org.infinispan.jmx.JmxStatisticsExposer
Returns whether an interceptor's statistics are being captured.
getStatisticsEnabled() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getStatisticsEnabled() - Method in class org.infinispan.stats.impl.AbstractClusterStats
 
getStatisticsEnabled() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getStatisticsEnabled() - Method in class org.infinispan.stats.impl.ClusterContainerStatsImpl
 
getStatisticsEnabled() - Method in class org.infinispan.stats.impl.LocalContainerStatsImpl
 
getStatisticsEnabled() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getStatisticsEnabled() - Method in class org.infinispan.stats.impl.StatsCollector
 
getStatisticsEnabled() - Method in class org.infinispan.xsite.irac.DefaultIracManager
 
getStatisticValue(String) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getStats() - Method in interface org.infinispan.AdvancedCache
Returns a Stats object that allows several statistics associated with this cache at runtime.
getStats() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getStats() - Method in class org.infinispan.cache.impl.CacheImpl
 
getStats() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getStats() - Method in class org.infinispan.cache.impl.StatsCollectingCache
 
getStats() - Method in class org.infinispan.manager.DefaultCacheManager
 
getStats() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Deprecated, for removal: This API element is subject to removal in a future version.
Since 10.1.3. This mixes statistics across unrelated caches so the reported numbers don't have too much relevance.
getStats() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getStats() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getStatsMap() - Method in class org.infinispan.client.hotrod.impl.ServerStatisticsImpl
 
getStatsMap() - Method in interface org.infinispan.client.hotrod.ServerStatistics
 
getStatus() - Method in interface org.infinispan.Cache
 
getStatus() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getStatus() - Method in class org.infinispan.cache.impl.CacheImpl
 
getStatus() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getStatus() - Method in class org.infinispan.commons.tx.TransactionImpl
Get the status of the transaction.
getStatus() - Method in class org.infinispan.commons.tx.TransactionManagerImpl
 
getStatus() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
Retrieves the state of the registry
getStatus() - Method in interface org.infinispan.functional.FunctionalMap
Functional map's status.
getStatus() - Method in class org.infinispan.functional.impl.ReadOnlyMapImpl
 
getStatus() - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
 
getStatus() - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
 
getStatus() - Method in class org.infinispan.functional.impl.FunctionalMapImpl
 
getStatus() - Method in interface org.infinispan.health.CacheHealth
Returns Cache health status.
getStatus() - Method in class org.infinispan.manager.DefaultCacheManager
 
getStatus() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getStatus() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getStatus() - Method in class org.infinispan.rest.framework.impl.LookupResultImpl
 
getStatus() - Method in interface org.infinispan.rest.framework.impl.RestResponseBuilder
 
getStatus() - Method in class org.infinispan.rest.framework.impl.SimpleRestResponse.Builder
 
getStatus() - Method in class org.infinispan.rest.framework.impl.SimpleRestResponse
 
getStatus() - Method in interface org.infinispan.rest.framework.LookupResult
 
getStatus() - Method in interface org.infinispan.rest.framework.RestResponse
 
getStatus() - Method in class org.infinispan.rest.NettyRestResponse.Builder
 
getStatus() - Method in class org.infinispan.rest.NettyRestResponse
 
getStatus() - Method in exception class org.infinispan.rest.RestResponseException
 
getStatus() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getStatus() - Method in interface org.infinispan.server.core.ServerManagement
 
getStatus() - Method in class org.infinispan.server.hotrod.tx.table.TxState
 
getStatus() - Method in interface org.infinispan.topology.ClusterTopologyManager
 
getStatus() - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
 
getStatus() - Method in class org.infinispan.transaction.tm.EmbeddedUserTransaction
 
getStatus() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfo
The value represent transaction's state as described by the status field.
getStatus() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
Following values might be returned: - Status.STATUS_PREPARED if the tx is prepared - Status.STATUS_COMMITTED if the tx is committed - Status.STATUS_ROLLEDBACK if the tx is rollback - null otherwise
getStatus() - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateTransferManager
 
getStatus() - Method in class org.infinispan.xsite.statetransfer.RemoteSiteStatus
 
getStatus() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
 
getStatus() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
 
getStatusCode() - Method in class org.infinispan.server.hotrod.iteration.IterableIterationResult
 
getStorageFormat() - Method in interface org.infinispan.commons.dataconversion.Encoder
Deprecated.
Returns the MediaType produced by this encoder or null if the storage format is not known.
getStorageFormat() - Method in class org.infinispan.commons.dataconversion.GlobalMarshallerEncoder
Deprecated.
 
getStorageFormat() - Method in class org.infinispan.commons.dataconversion.IdentityEncoder
Deprecated.
 
getStorageFormat() - Method in class org.infinispan.commons.dataconversion.JavaSerializationEncoder
Deprecated.
 
getStorageFormat() - Method in class org.infinispan.commons.dataconversion.UTF8Encoder
Deprecated.
 
getStorageFormat() - Method in class org.infinispan.jboss.marshalling.dataconversion.GenericJbossMarshallerEncoder
Deprecated.
 
getStorageMediaType() - Method in class org.infinispan.encoding.DataConversion
 
getStorageMediaType(boolean) - Method in class org.infinispan.encoding.impl.StorageConfigurationManager
 
getStoredValue() - Method in class org.infinispan.persistence.modifications.Store
 
getStoreFile(String, String) - Static method in class org.infinispan.persistence.file.SingleFileStore
 
getStores() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getStores() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getStores() - Method in class org.infinispan.stats.impl.StatsCollector
 
getStores() - Method in class org.infinispan.stats.impl.StatsImpl
 
getStores() - Method in interface org.infinispan.stats.Stats
 
getStores(Class<T>) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
 
getStoresAsString() - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
 
getStoreWrites() - Method in interface org.infinispan.stats.ClusterCacheStats
 
getStoreWrites() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getStream() - Method in interface org.infinispan.commons.io.ByteBuffer
 
getStream() - Method in class org.infinispan.commons.io.ByteBufferImpl
 
getStreamResponse(HotRodHeader, HotRodServer, Channel, int, CacheEntry<byte[], byte[]>) - Method in class org.infinispan.server.hotrod.Encoder4x
 
getStreamResponse(HotRodHeader, HotRodServer, Channel, int, CacheEntry<byte[], byte[]>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
 
getStreamSupplier(boolean) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getStringMapping(Object) - Method in class org.infinispan.persistence.keymappers.DefaultTwoWayKey2StringMapper
 
getStringMapping(Object) - Method in interface org.infinispan.persistence.keymappers.Key2StringMapper
Must return an unique String for the supplied key.
getStringMapping(Object) - Method in class org.infinispan.persistence.keymappers.WrappedByteArrayOrPrimitiveMapper
 
getStrongCounter(String) - Method in class org.infinispan.client.hotrod.counter.impl.RemoteCounterManager
 
getStrongCounter(String) - Method in interface org.infinispan.counter.api.CounterManager
Returns the StrongCounter with that specific name.
getSubgroupsMerged() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
getSubgroupsMerged() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.MergeEvent
 
getSubject() - Method in class org.infinispan.manager.DefaultCacheManager
 
getSubject() - Method in interface org.infinispan.manager.EmbeddedCacheManager
 
getSubject() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getSubject() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
getSubject() - Method in interface org.infinispan.rest.framework.RestRequest
 
getSubject() - Method in class org.infinispan.rest.NettyRestRequest
 
getSubject() - Static method in class org.infinispan.security.Security
If using Security.doAs(Subject, PrivilegedAction) or Security.doAs(Subject, PrivilegedExceptionAction), returns the Subject associated with the current thread otherwise it returns the Subject associated with the current AccessControlContext
getSubject() - Method in class org.infinispan.server.core.security.simple.SimpleSubjectUserInfo
 
getSubject() - Method in interface org.infinispan.server.core.security.SubjectUserInfo
Returns the subject
getSubject() - Method in class org.infinispan.tasks.TaskContext
The optional Subject which is executing this task
getSubject(HotRodOperation) - Method in class org.infinispan.server.hotrod.Authentication
 
getSubjectUserInfo(Collection<Principal>) - Method in interface org.infinispan.server.core.security.AuthorizingCallbackHandler
 
getSubjectUserPrincipal(Subject) - Static method in class org.infinispan.security.Security
Returns the first principal of a subject
getSubType() - Method in class org.infinispan.commons.dataconversion.MediaType
 
getSuccessRatio() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getSuccessRatioFloatingPoint() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getSuffix() - Method in enum org.infinispan.commons.util.MemoryUnit
Deprecated.
 
getSuperMBeanClassName() - Method in class org.infinispan.factories.impl.MBeanMetadata
 
getSupportedMediaTypes() - Method in class org.infinispan.commons.dataconversion.DefaultTranscoder
 
getSupportedMediaTypes() - Method in class org.infinispan.commons.dataconversion.OneToManyTranscoder
 
getSupportedMediaTypes() - Method in interface org.infinispan.commons.dataconversion.Transcoder
 
getSupportedMediaTypes() - Method in class org.infinispan.encoding.impl.TwoStepTranscoder
 
getSupportedPrivateClasses() - Static method in class org.infinispan.marshall.exts.CollectionExternalizer
Returns an immutable Set that contains all of the private classes (e.g.
getSupportedPrivateClasses() - Static method in class org.infinispan.marshall.exts.MapExternalizer
Returns an immutable Set that contains all of the private classes (e.g.
getSuspect() - Method in exception class org.infinispan.remoting.transport.jgroups.SuspectException
 
getSyncRpcOptions() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticRpcManager
 
getSyncRpcOptions() - Method in interface org.infinispan.remoting.rpc.RpcManager
 
getSyncRpcOptions() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
GetSystemPropertyAction - Class in org.infinispan.security.actions
GetSystemPropertyAction.
GetSystemPropertyAction(String) - Constructor for class org.infinispan.security.actions.GetSystemPropertyAction
 
GetSystemPropertyAction(String, String) - Constructor for class org.infinispan.security.actions.GetSystemPropertyAction
 
GetSystemPropertyAsBooleanAction - Class in org.infinispan.security.actions
Wrapper for Boolean.getBoolean(propertyName)
GetSystemPropertyAsBooleanAction(String) - Constructor for class org.infinispan.security.actions.GetSystemPropertyAsBooleanAction
 
GetSystemPropertyAsIntegerAction - Class in org.infinispan.security.actions
Wrapper for Integer.getInteger(propertyName, defaultValue).
GetSystemPropertyAsIntegerAction(String, int) - Constructor for class org.infinispan.security.actions.GetSystemPropertyAsIntegerAction
 
getTableManager() - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
 
getTags() - Method in class org.infinispan.commons.stat.CounterMetricInfo
 
getTags() - Method in class org.infinispan.commons.stat.DistributionSummaryMetricInfo
 
getTags() - Method in class org.infinispan.commons.stat.FunctionTimerMetricInfo
 
getTags() - Method in class org.infinispan.commons.stat.GaugeMetricInfo
 
getTags() - Method in class org.infinispan.commons.stat.TimeGaugeMetricInfo
 
getTags() - Method in class org.infinispan.commons.stat.TimerMetricInfo
 
getTags() - Method in interface org.infinispan.commons.stat.MetricInfo
 
getTakeOfflineManager() - Method in class org.infinispan.factories.ComponentRegistry
 
getTarget() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
getTarget() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
getTarget() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
 
getTarget() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.ListenerInvocationImpl
 
getTarget() - Method in interface org.infinispan.notifications.impl.ListenerInvocation
The listener instance that is notified of events
getTarget(int) - Method in class org.infinispan.remoting.transport.impl.MultiTargetRequest
 
getTargetsSize() - Method in class org.infinispan.remoting.transport.impl.MultiTargetRequest
 
getTaskContextName() - Method in class org.infinispan.server.core.admin.AdminServerTask
 
getTaskContextName() - Method in class org.infinispan.server.core.admin.embeddedserver.CacheCreateTask
 
getTaskContextName() - Method in class org.infinispan.server.core.admin.embeddedserver.CacheGetOrCreateTask
 
getTaskContextName() - Method in class org.infinispan.server.core.admin.embeddedserver.CacheNamesTask
 
getTaskContextName() - Method in class org.infinispan.server.core.admin.embeddedserver.CacheReindexTask
 
getTaskContextName() - Method in class org.infinispan.server.core.admin.embeddedserver.CacheRemoveTask
 
getTaskContextName() - Method in class org.infinispan.server.core.admin.embeddedserver.CacheUpdateConfigurationAttributeTask
 
getTaskContextName() - Method in class org.infinispan.server.core.admin.embeddedserver.CacheUpdateIndexSchemaTask
 
getTaskContextName() - Method in class org.infinispan.server.core.admin.embeddedserver.TemplateCreateTask
 
getTaskContextName() - Method in class org.infinispan.server.core.admin.embeddedserver.TemplateNamesTask
 
getTaskContextName() - Method in class org.infinispan.server.core.admin.embeddedserver.TemplateRemoveTask
 
getTaskManager() - Method in interface org.infinispan.server.core.ServerManagement
 
getTaskOperationName() - Method in class org.infinispan.server.core.admin.AdminServerTask
 
getTaskOperationName() - Method in class org.infinispan.server.core.admin.embeddedserver.CacheCreateTask
 
getTaskOperationName() - Method in class org.infinispan.server.core.admin.embeddedserver.CacheGetOrCreateTask
 
getTaskOperationName() - Method in class org.infinispan.server.core.admin.embeddedserver.CacheNamesTask
 
getTaskOperationName() - Method in class org.infinispan.server.core.admin.embeddedserver.CacheReindexTask
 
getTaskOperationName() - Method in class org.infinispan.server.core.admin.embeddedserver.CacheRemoveTask
 
getTaskOperationName() - Method in class org.infinispan.server.core.admin.embeddedserver.CacheUpdateConfigurationAttributeTask
 
getTaskOperationName() - Method in class org.infinispan.server.core.admin.embeddedserver.CacheUpdateIndexSchemaTask
 
getTaskOperationName() - Method in class org.infinispan.server.core.admin.embeddedserver.TemplateCreateTask
 
getTaskOperationName() - Method in class org.infinispan.server.core.admin.embeddedserver.TemplateNamesTask
 
getTaskOperationName() - Method in class org.infinispan.server.core.admin.embeddedserver.TemplateRemoveTask
 
getTasks() - Method in class org.infinispan.server.core.admin.AdminOperationsHandler
 
getTcpKeepAlive() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getTcpNoDelay() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getTcpNoDelay() - Method in class org.infinispan.server.core.transport.NettyTransport
 
getTcpNoDelay() - Method in interface org.infinispan.server.core.transport.Transport
 
getTemplate() - Method in class org.infinispan.globalstate.impl.CacheState
 
getTemplateName() - Method in enum org.infinispan.client.hotrod.DefaultTemplate
Use this method to retrieve the value of a template configured in the infinispan-defaults.xml file
getterMethod(Class<?>, Class<?>) - Static method in class org.infinispan.commons.util.BeanUtils
Returns a Method object corresponding to a getter that retrieves an instance of componentClass from target.
getterName(Class<?>) - Static method in class org.infinispan.commons.util.BeanUtils
Returns a getter for a given class
getText() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
getText() - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returns the text content of the current event as String.
getText() - Method in exception class org.infinispan.rest.RestResponseException
 
getTextCharacters(int[]) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
 
getTextCharacters(int[]) - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
Returns the buffer that contains the text of the current event, as well as the start offset and length relevant for the current event.
getThreadFactory(String) - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
 
getThreadPool(String) - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
 
getThreadPoolSize() - Method in class org.infinispan.configuration.cache.IndexWriterConfiguration
 
getThroughput() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getTimeout() - Method in class org.infinispan.server.hotrod.tx.table.TxState
 
getTimeout() - Method in class org.infinispan.topology.CacheJoinInfo
 
getTimeoutMs() - Method in class org.infinispan.remoting.transport.AbstractRequest
 
getTimeService() - Method in class org.infinispan.factories.AbstractComponentRegistry
Deprecated.
 
getTimeService() - Method in class org.infinispan.factories.ComponentRegistry
 
getTimeService() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getTimeService() - Method in class org.infinispan.persistence.InitializationContextImpl
 
getTimeService() - Method in interface org.infinispan.persistence.spi.InitializationContext
 
getTimeService() - Method in class org.infinispan.persistence.support.DelegatingInitializationContext
 
getTimeService() - Method in class org.infinispan.server.hotrod.HotRodServer
 
getTimeService(Cache<?, ?>) - Static method in class org.infinispan.query.impl.ComponentRegistryUtils
 
getTimeSinceReset() - Method in class org.infinispan.client.hotrod.impl.ClientStatistics
 
getTimeSinceReset() - Method in interface org.infinispan.client.hotrod.jmx.RemoteCacheClientStatisticsMXBean
Returns the time, in seconds, since the last reset.
getTimeSinceReset() - Method in class org.infinispan.stats.impl.AbstractClusterStats
 
getTimeSinceReset() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getTimeSinceReset() - Method in class org.infinispan.stats.impl.LocalContainerStatsImpl
 
getTimeSinceReset() - Method in class org.infinispan.stats.impl.StatsCollector
 
getTimeSinceReset() - Method in class org.infinispan.stats.impl.StatsImpl
 
getTimeSinceReset() - Method in interface org.infinispan.stats.Stats
 
getTimeSinceStart() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated.
 
getTimeSinceStart() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
 
getTimeSinceStart() - Method in class org.infinispan.stats.impl.StatsCollector
 
getTimeSinceStart() - Method in class org.infinispan.stats.impl.StatsImpl
 
getTimeSinceStart() - Method in interface org.infinispan.stats.Stats
 
getTimeToLiveSecondsHeader() - Method in interface org.infinispan.rest.framework.RestRequest
 
getTimeToLiveSecondsHeader() - Method in class org.infinispan.rest.NettyRestRequest
 
getTimeUnit() - Method in class org.infinispan.commons.stat.TimeGaugeMetricInfo
 
getToken() - Method in class org.infinispan.client.hotrod.security.TokenCallbackHandler
 
getTombstone(Object) - Method in class org.infinispan.container.versioning.irac.DefaultIracTombstoneManager
 
getTombstone(Object) - Method in interface org.infinispan.container.versioning.irac.IracTombstoneManager
Returns the tombstone associated to the key or null if it doesn't exist.
getTombstone(Object) - Method in class org.infinispan.container.versioning.irac.NoOpIracTombstoneManager
 
getTombstoneCleanupTaskCurrentDelay() - Method in class org.infinispan.xsite.irac.DefaultIracManager
 
getTopContendedKeys() - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
 
getTopKFrom(StreamSummaryContainer.Stat) - Method in class org.infinispan.extendedstats.topK.StreamSummaryContainer
getTopKFrom(StreamSummaryContainer.Stat, int) - Method in class org.infinispan.extendedstats.topK.StreamSummaryContainer
 
getTopKFromAsKeyString(StreamSummaryContainer.Stat) - Method in class org.infinispan.extendedstats.topK.StreamSummaryContainer
Same as StreamSummaryContainer.getTopKFrom(StreamSummaryContainer.Stat) but the keys are returned in their String format.
getTopKFromAsKeyString(StreamSummaryContainer.Stat, int) - Method in class org.infinispan.extendedstats.topK.StreamSummaryContainer
Same as StreamSummaryContainer.getTopKFrom(StreamSummaryContainer.Stat, int) but the keys are returned in their String format.
getTopLockedKeys() - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
 
getTopLockFailedKeys() - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
 
getTopology(ByteString) - Method in class org.infinispan.container.versioning.irac.IracEntryVersion
 
getTopologyAge() - Method in class org.infinispan.client.hotrod.impl.TopologyInfo
 
getTopologyId() - Method in interface org.infinispan.client.hotrod.CacheTopologyInfo
 
getTopologyId() - Method in class org.infinispan.client.hotrod.impl.CacheTopologyInfoImpl
 
getTopologyId() - Method in class org.infinispan.client.hotrod.impl.ClientTopology
 
getTopologyId() - Method in class org.infinispan.commands.AbstractTopologyAffectedCommand
 
getTopologyId() - Method in interface org.infinispan.commands.TopologyAffectedCommand
 
getTopologyId() - Method in class org.infinispan.container.versioning.irac.TopologyIracVersion
 
getTopologyId() - Method in class org.infinispan.container.versioning.SimpleClusteredVersion
 
getTopologyId() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticRpcManager
 
getTopologyId() - Method in interface org.infinispan.remoting.rpc.RpcManager
Returns the current topology id.
getTopologyId() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getTopologyId() - Method in class org.infinispan.server.hotrod.HotRodHeader
 
getTopologyId() - Method in class org.infinispan.topology.CacheTopology
 
getTopologyId() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getTopologyId() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
getTopWriteSkewFailedKeys() - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
 
getTotalBytesRead() - Method in class org.infinispan.server.core.transport.NettyTransport
 
getTotalBytesRead() - Method in interface org.infinispan.server.core.transport.Transport
 
getTotalBytesWritten() - Method in class org.infinispan.server.core.transport.NettyTransport
 
getTotalBytesWritten() - Method in interface org.infinispan.server.core.transport.Transport
 
getTotalMemoryKb() - Method in interface org.infinispan.health.HostInfo
Gets total memory in KB.
getTotalMemoryKb() - Method in interface org.infinispan.health.jmx.HealthJMXExposer
Returns the amount of total memory (KB) in the host.
getTotalNumberOfEntries() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
Deprecated, for removal: This API element is subject to removal in a future version.
getTotalNumberOfEntries() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
Deprecated, for removal: This API element is subject to removal in a future version.
getTotalNumberOfEntries() - Method in class org.infinispan.stats.impl.StatsCollector
Deprecated, for removal: This API element is subject to removal in a future version.
getTotalNumberOfEntries() - Method in class org.infinispan.stats.impl.StatsImpl
Deprecated, for removal: This API element is subject to removal in a future version.
getTotalNumberOfEntries() - Method in interface org.infinispan.stats.Stats
Deprecated, for removal: This API element is subject to removal in a future version.
Since 13.0, please use Stats.getStores() instead
getTotalResults() - Method in class org.infinispan.query.remote.json.JsonQueryResponse
 
getTotalSpace() - Method in class org.infinispan.io.GridFile
Deprecated.
 
getTotalSyncRpcOptions() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticRpcManager
 
getTotalSyncRpcOptions() - Method in interface org.infinispan.remoting.rpc.RpcManager
 
getTransaction() - Method in class org.infinispan.commons.tx.TransactionManagerImpl
 
getTransaction() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
 
getTransaction() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
 
getTransaction() - Method in interface org.infinispan.context.impl.TxInvocationContext
Returns the tx associated with the current thread.
getTransaction() - Method in class org.infinispan.transaction.impl.LocalTransaction
 
getTransaction() - Method in class org.infinispan.transaction.tm.EmbeddedBaseTransactionManager
 
getTransactionManager() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getTransactionManager() - Method in class org.infinispan.cache.impl.CacheImpl
 
getTransactionManager() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getTransactionManager() - Method in class org.infinispan.client.hotrod.transaction.lookup.GenericTransactionManagerLookup
 
getTransactionManager() - Method in class org.infinispan.client.hotrod.transaction.lookup.RemoteTransactionManagerLookup
 
getTransactionManager() - Method in interface org.infinispan.commons.api.TransactionalCache
 
getTransactionManager() - Method in interface org.infinispan.commons.tx.lookup.TransactionManagerLookup
Returns a new TransactionManager.
getTransactionManager() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getTransactionManager() - Method in class org.infinispan.transaction.lookup.EmbeddedTransactionManagerLookup
 
getTransactionManager() - Method in class org.infinispan.transaction.lookup.GenericTransactionManagerLookup
Get the system-wide used TransactionManager
getTransactionManager() - Method in class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
 
getTransactionManager() - Method in class org.infinispan.transaction.lookup.WildflyTransactionManagerLookup
 
getTransactionManagerLookup() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getTransactionMode() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getTransactionSynchronizationRegistry() - Method in interface org.infinispan.transaction.lookup.TransactionSynchronizationRegistryLookup
Returns a new TransactionSynchronizationRegistry.
getTransactionTable() - Method in class org.infinispan.factories.ComponentRegistry
 
getTransactionTableRef() - Method in class org.infinispan.factories.ComponentRegistry
 
getTransactionTimeout() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getTransactionTimeout() - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
 
getTranscoder(Class<T>) - Method in interface org.infinispan.marshall.core.EncoderRegistry
 
getTranscoder(Class<T>) - Method in class org.infinispan.marshall.core.EncoderRegistryImpl
 
getTranscoder(MediaType, MediaType) - Method in interface org.infinispan.marshall.core.EncoderRegistry
Obtain an instance of Transcoder from the registry.
getTranscoder(MediaType, MediaType) - Method in class org.infinispan.marshall.core.EncoderRegistryImpl
 
getTransport() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
 
getTransport() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticRpcManager
 
getTransport() - Method in class org.infinispan.manager.DefaultCacheManager
 
getTransport() - Method in interface org.infinispan.manager.EmbeddedCacheManager
Deprecated, for removal: This API element is subject to removal in a future version.
getTransport() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
 
getTransport() - Method in interface org.infinispan.remoting.rpc.RpcManager
 
getTransport() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
 
getTransport() - Method in class org.infinispan.server.core.AbstractProtocolServer
 
getTransport() - Method in interface org.infinispan.server.core.ProtocolServer
Returns the transport for this server
getTransportFactory() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getTrimmedBuffer() - Method in class org.infinispan.commons.io.LazyByteArrayOutputStream
Gets a buffer that is trimmed so that there are no excess bytes.
getTrustManagerFactory() - Method in class org.infinispan.commons.util.SslContextFactory
 
getTrustStoreFileName() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getTrustStorePassword() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getTrustStorePath() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
Deprecated, for removal: This API element is subject to removal in a future version.
Since 12.0 and will be removed in 15.0
getTrustStoreType() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getTxConnection(Transaction) - Method in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
 
getTxState() - Method in class org.infinispan.server.hotrod.tx.PrepareCoordinator
 
getType() - Method in interface org.infinispan.client.hotrod.event.ClientEvent
 
getType() - Method in class org.infinispan.client.hotrod.event.impl.CreatedEventImpl
 
getType() - Method in class org.infinispan.client.hotrod.event.impl.CustomEventImpl
 
getType() - Method in class org.infinispan.client.hotrod.event.impl.ExpiredEventImpl
 
getType() - Method in class org.infinispan.client.hotrod.event.impl.ModifiedEventImpl
 
getType() - Method in class org.infinispan.client.hotrod.event.impl.RemovedEventImpl
 
getType() - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
 
getType() - Method in class org.infinispan.commons.dataconversion.MediaType
 
getType() - Method in class org.infinispan.factories.impl.MBeanMetadata.AttributeMetadata
 
getType() - Method in class org.infinispan.factories.impl.MBeanMetadata.OperationParameterMetadata
 
getType() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
getType() - Method in interface org.infinispan.notifications.cachelistener.event.Event
 
getType() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getType() - Method in class org.infinispan.notifications.cachelistener.filter.EventType
 
getType() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.Event
 
getType() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
getType() - Method in class org.infinispan.persistence.modifications.Clear
 
getType() - Method in interface org.infinispan.persistence.modifications.Modification
 
getType() - Method in class org.infinispan.persistence.modifications.ModificationsList
 
getType() - Method in class org.infinispan.persistence.modifications.Remove
 
getType() - Method in class org.infinispan.persistence.modifications.Store
 
getType() - Method in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.Parameter
 
getType() - Method in class org.infinispan.search.mapper.mapping.metamodel.ValueFieldMetamodel
 
getType() - Method in class org.infinispan.server.core.admin.AdminServerTask
 
getType() - Method in interface org.infinispan.tasks.ServerTask
 
getType() - Method in interface org.infinispan.tasks.Task
Returns the type of task.
getType() - Method in class org.infinispan.xsite.events.XSiteEvent
 
getTypeClasses() - Method in class org.infinispan.cache.impl.BiFunctionMapper.Externalizer
 
getTypeClasses() - Method in class org.infinispan.cache.impl.EncoderEntryMapper.Externalizer
 
getTypeClasses() - Method in class org.infinispan.cache.impl.EncoderKeyMapper.Externalizer
 
getTypeClasses() - Method in class org.infinispan.cache.impl.EncoderValueMapper.Externalizer
 
getTypeClasses() - Method in class org.infinispan.cache.impl.FunctionMapper.Externalizer
 
getTypeClasses() - Method in class org.infinispan.commons.hash.MurmurHash3.Externalizer
 
getTypeClasses() - Method in class org.infinispan.commons.io.ByteBufferImpl.Externalizer
 
getTypeClasses() - Method in class org.infinispan.commons.marshall.AdminFlagExternalizer
 
getTypeClasses() - Method in interface org.infinispan.commons.marshall.AdvancedExternalizer
Deprecated.
Returns a collection of Class instances representing the types that this AdvancedExternalizer can marshall.
getTypeClasses() - Method in class org.infinispan.commons.marshall.SingletonExternalizer
 
getTypeClasses() - Method in class org.infinispan.commons.marshall.SuppliedExternalizer
 
getTypeClasses() - Method in class org.infinispan.commons.marshall.WrappedByteArray.Externalizer
 
getTypeClasses() - Method in class org.infinispan.commons.util.ImmutableListCopy.Externalizer
 
getTypeClasses() - Method in class org.infinispan.commons.util.Immutables.ImmutableMapWrapperExternalizer
 
getTypeClasses() - Method in class org.infinispan.commons.util.Immutables.ImmutableSetWrapperExternalizer
 
getTypeClasses() - Static method in class org.infinispan.commons.util.IntSetsExternalization
 
getTypeClasses() - Method in class org.infinispan.container.entries.ImmortalCacheEntry.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.ImmortalCacheValue.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheEntry.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.MortalCacheEntry.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.MortalCacheValue.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.RemoteMetadata.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.TransientCacheEntry.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.TransientCacheValue.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.entries.TransientMortalCacheValue.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.versioning.NumericVersion.Externalizer
 
getTypeClasses() - Method in class org.infinispan.container.versioning.SimpleClusteredVersion.Externalizer
 
getTypeClasses() - Method in class org.infinispan.context.Flag.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.impl.TopologyAwareConsistentHashFactory.Externalizer
 
getTypeClasses() - Method in class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory.Externalizer
 
getTypeClasses() - Method in class org.infinispan.encoding.DataConversion.Externalizer
 
getTypeClasses() - Method in class org.infinispan.filter.AcceptAllKeyValueFilter.Externalizer
 
getTypeClasses() - Method in class org.infinispan.filter.CacheFilters.CacheFiltersExternalizer
 
getTypeClasses() - Method in class org.infinispan.filter.CompositeKeyValueFilter.Externalizer
 
getTypeClasses() - Method in class org.infinispan.functional.impl.EntryViews.NoValueReadOnlyViewExternalizer
 
getTypeClasses() - Method in class org.infinispan.functional.impl.EntryViews.ReadOnlySnapshotViewExternalizer
 
getTypeClasses() - Method in class org.infinispan.functional.impl.EntryViews.ReadWriteSnapshotViewExternalizer
 
getTypeClasses() - Method in class org.infinispan.functional.impl.StatsEnvelope.Externalizer
 
getTypeClasses() - Method in class org.infinispan.globalstate.impl.CacheState.Externalizer
 
getTypeClasses() - Method in class org.infinispan.globalstate.ScopedState.Externalizer
 
getTypeClasses() - Method in class org.infinispan.globalstate.ScopeFilter.Externalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.ConstantLambdaExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.LambdaWithMetasExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.SetValueIfEqualsReturnBooleanExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.ClassExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.CollectionExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.DoubleSummaryStatisticsExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.EnumExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.EnumSetExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.IntSummaryStatisticsExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.LongSummaryStatisticsExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.MapExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.EntryVersionParamExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.LifespanExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.MaxIdleExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.OptionalExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.ThrowableExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.TriangleAckExternalizer
 
getTypeClasses() - Method in class org.infinispan.marshall.exts.UuidExternalizer
 
getTypeClasses() - Method in class org.infinispan.metadata.EmbeddedMetadata.Externalizer
 
getTypeClasses() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl.Externalizer
Deprecated.
 
getTypeClasses() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent.Externalizer
 
getTypeClasses() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerRemoveCallable.Externalizer
 
getTypeClasses() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerReplicateCallable.Externalizer
 
getTypeClasses() - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventConverterAsConverter.Externalizer
 
getTypeClasses() - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterAsKeyValueFilter.Externalizer
 
getTypeClasses() - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverterAsKeyValueFilterConverter.Externalizer
 
getTypeClasses() - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterAsCacheEventFilter.Externalizer
 
getTypeClasses() - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter.Externalizer
 
getTypeClasses() - Method in class org.infinispan.partitionhandling.AvailabilityMode.Externalizer
 
getTypeClasses() - Method in class org.infinispan.persistence.remote.upgrade.AddSourceRemoteStoreTask.Externalizer
 
getTypeClasses() - Method in class org.infinispan.persistence.remote.upgrade.CheckRemoteStoreTask.Externalizer
 
getTypeClasses() - Method in class org.infinispan.persistence.remote.upgrade.DisconnectRemoteStoreTask.Externalizer
 
getTypeClasses() - Method in class org.infinispan.persistence.remote.upgrade.MigrationTask.EntryWriterExternalizer
 
getTypeClasses() - Method in class org.infinispan.persistence.remote.upgrade.MigrationTask.Externalizer
 
getTypeClasses() - Method in class org.infinispan.persistence.remote.upgrade.RemovedFilter.Externalizer
 
getTypeClasses() - Method in class org.infinispan.query.impl.QueryDefinition.Externalizer
 
getTypeClasses() - Method in class org.infinispan.reactive.publisher.PublisherReducers.PublisherReducersExternalizer
 
getTypeClasses() - Method in class org.infinispan.reactive.publisher.PublisherTransformers.PublisherTransformersExternalizer
 
getTypeClasses() - Method in class org.infinispan.remoting.responses.BiasRevocationResponse.Externalizer
 
getTypeClasses() - Method in class org.infinispan.remoting.responses.CacheNotFoundResponse.Externalizer
 
getTypeClasses() - Method in class org.infinispan.remoting.responses.ExceptionResponse.Externalizer
 
getTypeClasses() - Method in class org.infinispan.remoting.responses.SuccessfulResponse.Externalizer
 
getTypeClasses() - Method in class org.infinispan.remoting.responses.UnsuccessfulResponse.Externalizer
 
getTypeClasses() - Method in class org.infinispan.remoting.responses.UnsureResponse.Externalizer
 
getTypeClasses() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress.Externalizer
 
getTypeClasses() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress.Externalizer
 
getTypeClasses() - Method in class org.infinispan.server.hotrod.event.KeyValueWithPreviousEventConverterExternalizer
 
getTypeClasses() - Method in class org.infinispan.server.hotrod.iteration.IterationFilter.IterationFilterExternalizer
 
getTypeClasses() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl.DistributedCacheStatsCallableExternalizer
 
getTypeClasses() - Method in class org.infinispan.stream.impl.CacheBiConsumers.Externalizer
 
getTypeClasses() - Method in class org.infinispan.stream.impl.CacheIntermediatePublisher.ReducerExternalizer
 
getTypeClasses() - Method in class org.infinispan.stream.impl.CacheStreamIntermediateReducer.ReducerExternalizer
 
getTypeClasses() - Method in class org.infinispan.stream.StreamMarshalling.StreamMarshallingExternalizer
 
getTypeClasses() - Method in class org.infinispan.topology.CacheJoinInfo.Externalizer
 
getTypeClasses() - Method in class org.infinispan.topology.CacheStatusResponse.Externalizer
 
getTypeClasses() - Method in class org.infinispan.topology.CacheTopology.Externalizer
 
getTypeClasses() - Method in class org.infinispan.topology.ManagerStatusResponse.Externalizer
 
getTypeClasses() - Method in class org.infinispan.topology.PersistentUUID.Externalizer
 
getTypeClasses() - Method in class org.infinispan.transaction.xa.GlobalTransaction.Externalizer
 
getTypeClasses() - Method in class org.infinispan.util.IntSetExternalizer
 
getTypeClasses() - Method in class org.infinispan.util.KeyValuePair.Externalizer
 
getTypeClasses() - Static method in class org.infinispan.xsite.commands.remote.Ids
 
getTypeClasses() - Method in class org.infinispan.xsite.commands.remote.XSiteRequestExternalizer
 
getTypeClasses() - Method in class org.infinispan.xsite.statetransfer.XSiteState.XSiteStateExternalizer
 
getTypeName() - Method in class org.infinispan.commons.dataconversion.MediaType$___Marshaller_f2fc301543ca54d0326b5d8ce3b7199226a678253252e7ac46f1fad54bd90568
 
getTypeName() - Method in class org.infinispan.commons.marshall.WrappedByteArray$___Marshaller_dd5f1f82b70f419159a02b94c2ffa39a035efa36bc3f94e3bec8f1fb78d5e078
 
getTypeName() - Method in class org.infinispan.commons.util.KeyValueWithPrevious$___Marshaller_9145896a24b67e12a03ab245b027743214e8f0a00cff4e94594e6701c8f07ff1
 
getTypeName() - Method in class org.infinispan.commons.util.NullValue$___Marshaller_a83283d4dbbe8b8520f457699d99f19344b973d04786829de1e22c08915e6e56
 
getTypeName() - Method in class org.infinispan.container.entries.RemoteMetadata$___Marshaller_4cb4a1b59ce257eb4994240cafc1894764116cb17c3875df246d2943dcbdce0d
 
getTypeName() - Method in class org.infinispan.container.versioning.irac.IracEntryVersion$___Marshaller_1d33e9a17b1520460201f2d05b09e88a3eb2df8efbb49f8a10103069f8b573d5
 
getTypeName() - Method in class org.infinispan.container.versioning.irac.MapEntry$___Marshaller_37a121f54771729f5bc90dae7b319161c44a1e9491f8af866c7aba312bf9651e
 
getTypeName() - Method in class org.infinispan.container.versioning.irac.TopologyIracVersion$___Marshaller_14f804c9dae1c80820c4a124ae0decae2266c24993f77973d0fee34d7db215d2
 
getTypeName() - Method in class org.infinispan.container.versioning.NumericVersion$___Marshaller_54e14f07f0b2d32fc02dc14b15442c6b41ee1d50304f1e61ddb56d9feb6975b1
 
getTypeName() - Method in class org.infinispan.container.versioning.SimpleClusteredVersion$___Marshaller_f7402494821fa8e2ee025bf7d4a4b60322db5a0eb2018b6aa5836c002c8e07b7
 
getTypeName() - Method in class org.infinispan.counter.api.CounterConfiguration$___Marshaller_200ccbe7f9bd55cd3d0f90bae5ea29adc0a29590c936038020329c50ede7e29f
 
getTypeName() - Method in class org.infinispan.counter.api.CounterState$___Marshaller_93aa5d27c0d57954ec79247b055254b02d5c87a64e0764e392772b387eb7542d
 
getTypeName() - Method in class org.infinispan.counter.api.CounterType$___Marshaller_4dd4ef0972bf79fd96da56b8ce9348d84b1c42596acd7df3abf86c5e467887f5
 
getTypeName() - Method in class org.infinispan.counter.api.Storage$___Marshaller_ed04a8616efd062a7c88e9e578efa97c99224ac3211dd20ca76376455f84a9ae
 
getTypeName() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata$___Marshaller_d639102389197d7d9d67594c1f4f7cd51d35bdb2ed77d89d90c58b8d63ad3ab0
 
getTypeName() - Method in class org.infinispan.metadata.EmbeddedExpirableMetadata$___Marshaller_57542ccf09e811f3460251c589ca05aed449dbbc1765661fa3851dddaac8dd71
 
getTypeName() - Method in class org.infinispan.metadata.EmbeddedLifespanExpirableMetadata$___Marshaller_8da6d90d1f279b201c958e38c4b73ab7f2712dc1dc20b32c21334eacdfc6fd4b
 
getTypeName() - Method in class org.infinispan.metadata.EmbeddedMaxIdleExpirableMetadata$___Marshaller_6887b83200c53e83a8233e38450ed44c3191b4968b578e16a63c12add76959ed
 
getTypeName() - Method in class org.infinispan.metadata.EmbeddedMetadata$___Marshaller_d44c815cc3de96e45a01e06b569541e480035dc14f5499e3f3edc3fa7c6fe67
 
getTypeName() - Method in class org.infinispan.metadata.impl.IracMetadata$___Marshaller_cf0a6ded5e9e5b145ea5821d40d9659677d03a5df3e405762cc053e3bbb15e64
 
getTypeName() - Method in class org.infinispan.metadata.impl.PrivateMetadata$___Marshaller_2707b1b527c228e45215e24669c8ab752e6a1689fb6e3510d925b1e899b8ee06
 
getTypeName() - Method in class org.infinispan.multimap.impl.Bucket$___Marshaller_686dc55729a31972fef7d4722c2e90e0421789a20c8a9d4176be1714ac94d28c
 
getTypeName() - Method in class org.infinispan.persistence.rocksdb.ExpiryBucket$___Marshaller_c1bbd47a4aa119c6b21703d5030cb689b65205a24de2638d9c9f2ce1f3a222f6
 
getTypeName() - Method in class org.infinispan.persistence.rocksdb.MetadataImpl$___Marshaller_b44737a8b6b24b0cd6de162703366becf9e68a2ce287544774acbaaa7268814
 
getTypeName() - Method in class org.infinispan.query.impl.KnownClassKey$___Marshaller_b1b9e11dd7f2c702e88c180bbc686b798fa5794bc27ae13347aacd2e4a465e3d
 
getTypeName() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress$___Marshaller_fff84712bca7d00f611bdc3fd76a067b0a3a1f4981a7d3aad1c9257d9a5d7324
 
getTypeName() - Method in class org.infinispan.rest.distribution.CacheDistributionInfo$___Marshaller_d29d2c8791a59bb0952e36da57e31d3d06e79a149845ac44d334bd095efcb62c
 
getTypeName() - Method in class org.infinispan.rest.distribution.CacheDistributionRunnable$___Marshaller_45f1040aff503b6010c6b926057475925f0a64804eab6e8f0d6f4ba5ddce3a36
 
getTypeName() - Method in class org.infinispan.rest.distribution.NodeDistributionInfo$___Marshaller_50bcddd047df75d5979a51292e9db600cc21f4e1e18d6fe36b39e9a26196ea0e
 
getTypeName() - Method in class org.infinispan.security.AuthorizationPermission$___Marshaller_e4a67ef18a1f2ebc30b0d1e396f24e2098535911da768fa734361c9903b14240
 
getTypeName() - Method in class org.infinispan.security.impl.CacheRoleImpl$___Marshaller_8ebe2292503551beeebd9f0cc1e432a19521b4115fff99f8859a58acb74d6d74
 
getTypeName() - Method in class org.infinispan.security.impl.SubjectAdapter$___Marshaller_75e0224333a6eeeafc364cef114fe68e65410956aa87814e98e0722f4d8a588d
 
getTypeName() - Method in class org.infinispan.security.mappers.RoleSet$___Marshaller_2fda1a742ac008d38f1c852650748615da7cca98a60afaa87bb162ebc6157665
 
getTypeName() - Method in class org.infinispan.server.core.backup.resources.CacheBackupEntry$___Marshaller_b2d0dee2aac68dcec862a9e304f7e24daf8a89e2925ed0f1902a4f7e597df134
 
getTypeName() - Method in class org.infinispan.server.core.backup.resources.CounterBackupEntry$___Marshaller_2af248d5cc134577501d751e859e0021aca6b7f47edf43acc378580b56297af6
 
getTypeName() - Method in class org.infinispan.server.memcached.MemcachedMetadata$___Marshaller_582bc1c0173638c6bfeeee0149c471f14236f1b1d719f55da181f90c415f8bf1
 
getTypeName() - Method in class org.infinispan.spring.common.session.MapSessionProtoAdapter.SessionAttributeRawMarshaller
 
getTypeName() - Method in class org.infinispan.spring.common.session.MapSessionProtoAdapter$___Marshaller_71442e7b0d28786c1f10a1743da12fcd08d64dc0b8a798e5658e855284c87eee
 
getTypeName() - Method in class org.infinispan.spring.common.session.SessionAttribute$___Marshaller_5dcef48338013ff033aa3ebdfe72b959048a23f1ab1b4e671508996ffee0358b
 
getTypeName() - Method in class org.infinispan.spring.common.session.SessionUpdateRemappingFunctionProtoAdapter$___Marshaller_9c0544bb624c0af23e5a5e11e8120017e963b2cee452968f8524051818abdb2b
 
getTypeName() - Method in class org.infinispan.util.ByteString$___Marshaller_8e599c0fc1e9a512b7cdb7c05fb5529744ecac265708e69fd30c5e989237252a
 
getTypeSubtype() - Method in class org.infinispan.commons.dataconversion.MediaType
 
getUncombinedProtocolStack() - Method in class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator
 
getUncombinedRemoteSites() - Method in class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator
 
getUnionCH() - Method in class org.infinispan.topology.CacheTopology
The union of the current and future consistent hashes.
getUnionConsistentHash() - Method in interface org.infinispan.notifications.cachelistener.event.DataRehashedEvent
Deprecated, for removal: This API element is subject to removal in a future version.
Since 9.0
getUnionConsistentHash() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getUnreadBufferedCount() - Method in class org.infinispan.jboss.marshalling.commons.ExtendedRiverUnmarshaller
Returns number unread buffered bytes.
GetUnwrappedCacheAction<A,K,V> - Class in org.infinispan.security.actions
GetUnwrappedCacheAction.
GetUnwrappedCacheAction(A) - Constructor for class org.infinispan.security.actions.GetUnwrappedCacheAction
 
getUpdatedEntryVersions() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getUpdatedEntryVersions() - Method in interface org.infinispan.transaction.xa.CacheTransaction
 
getUpsertRowSql() - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
 
getUpsertRowSql() - Method in class org.infinispan.persistence.sql.QueriesJdbcStore.QueryTableOperations
 
getUpsertRowSql() - Method in class org.infinispan.persistence.sql.TableJdbcStore.TableTableOperations
 
getUpsertStatement(List<String>, List<String>) - Method in interface org.infinispan.persistence.jdbc.common.SqlManager
 
getURI() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getURI() - Method in interface org.infinispan.commons.configuration.io.ConfigurationSchemaVersion
 
getURI() - Method in class org.infinispan.configuration.parsing.Schema
 
getUsableSpace() - Method in class org.infinispan.io.GridFile
Deprecated.
 
getUseAuth() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getUserMarshaller() - Method in interface org.infinispan.marshall.persistence.PersistenceMarshaller
 
getUsername() - Method in class org.infinispan.client.hotrod.impl.HotRodURI
 
getUsername() - Method in class org.infinispan.client.hotrod.security.BasicCallbackHandler
 
getUserName() - Method in class org.infinispan.server.core.security.simple.SimpleSubjectUserInfo
 
getUserName() - Method in interface org.infinispan.server.core.security.SubjectUserInfo
Get the name for this user.
getUserTransaction() - Static method in class org.infinispan.transaction.lookup.EmbeddedTransactionManagerLookup
 
getUserTransaction() - Method in class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
 
getUserTransaction() - Method in class org.infinispan.transaction.lookup.WildflyTransactionManagerLookup
 
getUserTransaction() - Static method in class org.infinispan.transaction.tm.EmbeddedTransactionManager
 
getUseSSL() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
 
getValue() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.ValueAndMetadata
 
getValue() - Method in enum org.infinispan.client.hotrod.configuration.ClientIntelligence
 
getValue() - Method in class org.infinispan.client.hotrod.impl.VersionedOperationResponse
 
getValue() - Method in class org.infinispan.client.hotrod.impl.VersionedValueImpl
 
getValue() - Method in interface org.infinispan.client.hotrod.VersionedValue
 
getValue() - Method in class org.infinispan.commons.dataconversion.internal.Json
 
getValue() - Method in class org.infinispan.commons.util.AbstractMap.SimpleEntry
 
getValue() - Method in class org.infinispan.commons.util.KeyValueWithPrevious
 
getValue() - Method in class org.infinispan.commons.util.SimpleImmutableEntry
 
getValue() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
 
getValue() - Method in interface org.infinispan.container.entries.CacheEntry
Retrieves the value of this entry
getValue() - Method in class org.infinispan.container.entries.ClearCacheEntry
 
getValue() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
 
getValue() - Method in class org.infinispan.container.entries.ImmortalCacheValue
 
getValue() - Method in interface org.infinispan.container.entries.InternalCacheValue
 
getValue() - Method in class org.infinispan.container.entries.NullCacheEntry
 
getValue() - Method in class org.infinispan.container.entries.ReadCommittedEntry
 
getValue() - Method in interface org.infinispan.counter.api.StrongCounter
It fetches the current value.
getValue() - Method in interface org.infinispan.counter.api.SyncStrongCounter
 
getValue() - Method in interface org.infinispan.counter.api.SyncWeakCounter
 
getValue() - Method in interface org.infinispan.counter.api.WeakCounter
It returns the counter's value.
getValue() - Method in class org.infinispan.counter.impl.SyncStrongCounterAdapter
 
getValue() - Method in class org.infinispan.counter.impl.SyncWeakCounterAdapter
 
getValue() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
 
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryActivatedEvent
Retrieves the value of the entry being activated.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryCreatedEvent
Retrieves the value of the entry being created.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryEvent
Retrieves the value of the affected cache entry
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryExpiredEvent
Retrieves the value of the entry being expired.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryInvalidatedEvent
Retrieves the value of the entry being invalidated.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryLoadedEvent
Retrieves the value of the entry being loaded.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryModifiedEvent
Deprecated, for removal: This API element is subject to removal in a future version.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryPassivatedEvent
Retrieves the value of the entry being passivated.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryRemovedEvent
Retrieves the value of the entry being deleted.
getValue() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryVisitedEvent
Retrieves the value of the entry being visited.
getValue() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getValue() - Method in enum org.infinispan.persistence.rocksdb.configuration.CompressionType
 
getValue() - Method in class org.infinispan.persistence.sifs.EntryRecord
 
getValue() - Method in interface org.infinispan.persistence.spi.MarshallableEntry
Returns the same value as MarshallableEntry.getKeyBytes(), but unmarshalled.
getValue() - Method in class org.infinispan.query.remote.json.Hit
 
getValue() - Method in class org.infinispan.query.remote.json.JsonProjection
 
getValue() - Method in enum org.infinispan.rest.RequestHeader
 
getValue() - Method in enum org.infinispan.rest.ResponseHeader
 
getValue() - Method in enum org.infinispan.server.hotrod.ProtocolFlag
 
getValue() - Method in class org.infinispan.spring.common.session.MapSessionProtoAdapter.SessionAttribute
 
getValue() - Method in class org.infinispan.util.KeyValuePair
 
getValue() - Method in class org.infinispan.xsite.spi.SiteEntry
 
getValue(Object, String) - Static method in class org.infinispan.commons.util.ReflectionUtil
Retrieves the value of a field of an object instance via reflection
getValue(ExtendedStatistic) - Method in class org.infinispan.extendedstats.container.BaseExtendedStatisticsContainer
 
getValue(ExtendedStatistic) - Method in interface org.infinispan.extendedstats.container.ExtendedStatisticsContainer
 
getValue(ExtendedStatistic) - Method in class org.infinispan.extendedstats.TransactionStatistics
 
getValueBytes() - Method in interface org.infinispan.persistence.spi.MarshallableEntry
Returns the value in serialize format.
getValueBytes() - Method in interface org.infinispan.persistence.spi.MarshalledValue
 
getValueDataConversion() - Method in interface org.infinispan.AdvancedCache
 
getValueDataConversion() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getValueDataConversion() - Method in class org.infinispan.cache.impl.BiFunctionMapper
 
getValueDataConversion() - Method in class org.infinispan.cache.impl.CacheImpl
 
getValueDataConversion() - Method in class org.infinispan.cache.impl.EncoderCache
 
getValueDataConversion() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getValueDataConversion() - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
 
getValueDataConversion() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
 
getValueDataConversion() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
 
getValueDataConversion() - Method in class org.infinispan.notifications.cachelistener.ListenerHolder
 
getValueDataConversion() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getValueFields() - Method in class org.infinispan.search.mapper.mapping.metamodel.IndexMetamodel
 
getValueFields() - Method in class org.infinispan.search.mapper.mapping.metamodel.ObjectFieldMetamodel
 
getValueFromCtx(K, InvocationContext) - Method in interface org.infinispan.container.impl.InternalEntryFactory
Retrieve an InternalCacheValue from the provided InvocationContext if an InternalCacheEntry exists, otherwise create InternalCacheEntry from the context's CacheEntry and return its value.
getValueFromCtx(K, InvocationContext) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
 
getValueMediaType() - Method in class org.infinispan.server.hotrod.HotRodHeader
 
GetValueOperation - Class in org.infinispan.client.hotrod.counter.operation
A counter operation that returns the counter's value.
GetValueOperation(ChannelFactory, AtomicReference<ClientTopology>, Configuration, String, boolean) - Constructor for class org.infinispan.client.hotrod.counter.operation.GetValueOperation
 
getValueSizeEstimate() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
Deprecated, for removal: This API element is subject to removal in a future version.
Since 12.0, does nothing and will be removed in 15.0
getValueStorageMediaType() - Method in class org.infinispan.encoding.impl.StorageConfigurationManager
 
getValueType() - Method in class org.infinispan.client.hotrod.DataFormat
 
getValueType() - Method in interface org.infinispan.client.hotrod.marshall.MediaTypeMarshaller
The decided type for the values.
getValueWrapper() - Method in class org.infinispan.encoding.impl.StorageConfigurationManager
 
getVariables() - Method in class org.infinispan.rest.framework.impl.LookupResultImpl
 
getVariables() - Method in interface org.infinispan.rest.framework.LookupResult
In case the invocation contains paths with VariablePathItem, returns the value for each variable or empty otherwise.
getVersion() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
 
getVersion() - Method in class org.infinispan.cache.impl.CacheImpl
Returns the version of Infinispan.
getVersion() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getVersion() - Method in interface org.infinispan.client.hotrod.event.ClientCacheEntryCreatedEvent
Provides access to the version of the created cache entry.
getVersion() - Method in interface org.infinispan.client.hotrod.event.ClientCacheEntryModifiedEvent
Provides access to the version of the modified cache entry.
getVersion() - Method in class org.infinispan.client.hotrod.event.impl.CreatedEventImpl
 
getVersion() - Method in class org.infinispan.client.hotrod.event.impl.ModifiedEventImpl
 
getVersion() - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
getVersion() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getVersion() - Method in class org.infinispan.client.hotrod.impl.VersionedMetadataImpl
 
getVersion() - Method in class org.infinispan.client.hotrod.impl.VersionedValueImpl
 
getVersion() - Method in enum org.infinispan.client.hotrod.ProtocolVersion
 
getVersion() - Method in interface org.infinispan.client.hotrod.Versioned
 
getVersion() - Method in interface org.infinispan.commons.api.BasicCache
Retrieves the version of Infinispan
getVersion() - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
 
getVersion() - Static method in class org.infinispan.commons.util.Version
 
getVersion() - Method in interface org.infinispan.container.entries.versioned.Versioned
Deprecated.
 
getVersion() - Method in class org.infinispan.container.versioning.irac.TopologyIracVersion
 
getVersion() - Method in class org.infinispan.container.versioning.NumericVersion
 
getVersion() - Method in class org.infinispan.container.versioning.SimpleClusteredVersion
 
getVersion() - Method in class org.infinispan.manager.CacheManagerInfo
 
getVersion() - Method in class org.infinispan.manager.DefaultCacheManager
 
getVersion() - Method in class org.infinispan.metadata.impl.IracMetadata
 
getVersion() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getVersion() - Method in class org.infinispan.server.hotrod.counter.listener.ClientCounterEvent
 
getVersion() - Method in class org.infinispan.server.hotrod.HotRodHeader
 
getVersion() - Method in enum org.infinispan.server.hotrod.HotRodVersion
 
getVersion() - Static method in class org.infinispan.Version
Deprecated.
 
getVersion(ByteString) - Method in class org.infinispan.container.versioning.irac.IracEntryVersion
 
getVersionGenerator() - Method in class org.infinispan.factories.ComponentRegistry
Caching shortcut for #getLocalComponent(VersionGenerator.class)
getVersionPrefix() - Method in class org.infinispan.container.versioning.RankCalculator
 
getVersionShort() - Static method in class org.infinispan.commons.util.Version
 
getVersionShort() - Static method in class org.infinispan.Version
Deprecated.
 
getVersionShort(String) - Static method in class org.infinispan.commons.util.Version
 
getVersionShort(String) - Static method in class org.infinispan.Version
Deprecated.
 
getVersionsRead() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
 
getVersionsRead() - Method in interface org.infinispan.transaction.xa.CacheTransaction
Note: used in Repeatable Read + Write Skew + Clustering + Versioning.
getViewId() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
 
getViewId() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
Get JGroups view id.
getViewId() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
 
getViewId() - Method in class org.infinispan.remoting.transport.jgroups.ClusterView
 
getViewId() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
 
getViewId() - Method in interface org.infinispan.remoting.transport.Transport
 
getWaitList() - Method in class org.infinispan.remoting.responses.BiasRevocationResponse
 
getWeakCounter(String) - Method in class org.infinispan.client.hotrod.counter.impl.RemoteCounterManager
 
getWeakCounter(String) - Method in interface org.infinispan.counter.api.CounterManager
Returns the WeakCounter with that specific name.
getWeight() - Method in class org.infinispan.commons.dataconversion.MediaType
 
getWithMetadata(K) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
getWithMetadata(K) - Method in interface org.infinispan.client.hotrod.multimap.RemoteMultimapCache
Returns a MetadataCollection<V> of the values associated with key in this multimap cache, if any.
getWithMetadata(K) - Method in interface org.infinispan.client.hotrod.RemoteCache
Returns the MetadataValue associated to the supplied key param, or null if it doesn't exist.
getWithMetadataAsync(K) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
getWithMetadataAsync(K) - Method in class org.infinispan.client.hotrod.impl.InvalidatedNearRemoteCache
 
getWithMetadataAsync(K) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getWithMetadataAsync(K) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
 
getWithMetadataAsync(K) - Method in interface org.infinispan.client.hotrod.RemoteCache
Asynchronously returns the MetadataValue associated to the supplied key param, or null if it doesn't exist.
getWithMetadataAsync(K, SocketAddress) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
 
getWithMetadataAsync(K, SocketAddress) - Method in interface org.infinispan.client.hotrod.impl.InternalRemoteCache
 
getWithMetadataAsync(K, SocketAddress) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
 
getWithMetadataResponse(HotRodHeader, HotRodServer, Channel, CacheEntry<byte[], byte[]>) - Method in class org.infinispan.server.hotrod.Encoder4x
 
getWithMetadataResponse(HotRodHeader, HotRodServer, Channel, CacheEntry<byte[], byte[]>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
 
GetWithVersionRequest - Enum constant in enum org.infinispan.server.memcached.MemcachedOperation
 
getWrappedMessage() - Method in class org.infinispan.spring.common.session.MapSessionProtoAdapter.SessionAttribute
 
getWrapper() - Method in class org.infinispan.encoding.DataConversion
Deprecated, for removal: This API element is subject to removal in a future version.
Since 11.0. To be removed in 14.0, with no replacement.
getWrapper(boolean) - Method in class org.infinispan.encoding.impl.StorageConfigurationManager
 
getWrapper(Class<? extends Wrapper>, byte) - Method in interface org.infinispan.marshall.core.EncoderRegistry
Deprecated, for removal: This API element is subject to removal in a future version.
Since 11.0. To be removed in 14.0, with DataConversion.getWrapper()
getWrapper(Class<? extends Wrapper>, byte) - Method in class org.infinispan.marshall.core.EncoderRegistryImpl
 
getWrapperClass() - Method in class org.infinispan.encoding.DataConversion
Deprecated, for removal: This API element is subject to removal in a future version.
Since 11.0. To be removed in 14.0, with no replacement.
getWritableChannel(String) - Method in class org.infinispan.io.GridFilesystem
Deprecated.
Opens a WritableGridFileChannel for writing to the file denoted by pathname.
getWritableChannel(String, boolean) - Method in class org.infinispan.io.GridFilesystem
Deprecated.
Opens a WritableGridFileChannel for writing to the file denoted by pathname.
getWritableChannel(String, boolean, int) - Method in class org.infinispan.io.GridFilesystem
Deprecated.
Opens a WritableGridFileChannel for writing to the file denoted by pathname.
getWriteConsistentHash() - Method in interface org.infinispan.distribution.DistributionManager
Deprecated, for removal: This API element is subject to removal in a future version.
Since 11.0, to be removed in 14.0. Please use DistributionManager.getCacheTopology() instead.
getWriteConsistentHash() - Method in class org.infinispan.distribution.impl.DistributionManagerImpl
 
getWriteConsistentHash() - Method in class org.infinispan.topology.CacheTopology
When there is a rebalance in progress, write operations should go to the union of the "current" and "future" owners.
getWriteConsistentHashAtEnd() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getWriteConsistentHashAtEnd() - Method in interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
 
getWriteConsistentHashAtStart() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
 
getWriteConsistentHashAtStart() - Method in interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
 
getWriteOwners(Object) - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
getWriteOwners(Collection<?>) - Method in class org.infinispan.distribution.LocalizedCacheTopology
 
getWritePermission() - Method in interface org.infinispan.security.AuthorizationManager
Returns the permission required to write to the resource associated with this AuthorizationManager.
getWritePermission() - Method in class org.infinispan.security.impl.AuthorizationManagerImpl
 
getWritePermission() - Method in class org.infinispan.security.impl.PermissiveAuthorizationManager
 
getWriteSkewProbability() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
 
getWriteTimeout() - Method in class org.infinispan.spring.common.provider.SpringCache
 
getWriteTimeout() - Method in class org.infinispan.spring.remote.provider.SpringRemoteCacheManager
 
getXaResource() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
Returns the XAResource which can be used to do transactional recovery.
getXAResource() - Method in interface org.infinispan.AdvancedCache
Returns the XAResource associated with this cache which can be used to do transactional recovery.
getXAResource() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
 
getXAResource() - Method in class org.infinispan.cache.impl.CacheImpl
 
getXAResource() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
 
getXAResource() - Method in class org.infinispan.security.impl.SecureCacheImpl
 
getXid() - Method in class org.infinispan.commons.tx.TransactionImpl
 
getXid() - Method in class org.infinispan.server.hotrod.tx.table.CacheXid
 
getXid() - Method in class org.infinispan.transaction.xa.GlobalTransaction
 
getXid() - Method in class org.infinispan.transaction.xa.LocalXaTransaction
 
getXid() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfo
 
getXSiteCacheMapper() - Method in class org.infinispan.factories.GlobalComponentRegistry
 
getXSiteStateTransferManager() - Method in class org.infinispan.factories.ComponentRegistry
 
GIBIBYTES - Enum constant in enum org.infinispan.commons.util.MemoryUnit
Deprecated.
 
GIGABYTES - Enum constant in enum org.infinispan.commons.util.MemoryUnit
Deprecated.
 
GLASSFISH - Enum constant in enum org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
 
global(boolean) - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition.Builder
 
GLOBAL - Enum constant in enum org.infinispan.configuration.parsing.Element
 
GLOBAL - Enum constant in enum org.infinispan.configuration.parsing.ParserScope
The top-level scope at which cache containers, jgroups and threads are defined
GLOBAL - Enum constant in enum org.infinispan.factories.impl.Scopes
A single instance of the component is shared by all the caches.
GLOBAL - Enum constant in enum org.infinispan.factories.scopes.Scopes
A single instance of the component is shared by all the caches.
GLOBAL_MARSHALLER - Static variable in interface org.infinispan.commons.dataconversion.EncoderIds
Deprecated, for removal: This API element is subject to removal in a future version.
Since 11.0, will be removed with ISPN-9622
GLOBAL_SCOPE - Static variable in interface org.infinispan.globalstate.ScopedPersistentState
 
GLOBAL_STATE - Enum constant in enum org.infinispan.configuration.parsing.Element
 
GLOBAL_TRANSACTION - Static variable in interface org.infinispan.commons.marshall.Ids
 
GLOBAL_TX_TABLE_CACHE_NAME - Static variable in class org.infinispan.server.hotrod.LifecycleCallbacks
Cache name to store the global transaction table.
globalACLCache() - Method in interface org.infinispan.security.GlobalSecurityManager
Returns the global ACL cache
globalACLCache() - Method in class org.infinispan.security.impl.GlobalSecurityManagerImpl
 
GlobalAuthorizationConfiguration - Class in org.infinispan.configuration.global
GlobalAuthorizationConfiguration.
GlobalAuthorizationConfiguration(AttributeSet, PrincipalRoleMapperConfiguration, RolePermissionMapperConfiguration) - Constructor for class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
 
GlobalAuthorizationConfigurationBuilder - Class in org.infinispan.configuration.global
GlobalAuthorizationConfigurationBuilder.
GlobalAuthorizationConfigurationBuilder(GlobalSecurityConfigurationBuilder) - Constructor for class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
 
globalComponentRegistry - Variable in class org.infinispan.factories.AnyScopeComponentFactory
 
GlobalComponentRegistry - Class in org.infinispan.factories
A global component registry where shared components are stored.
GlobalComponentRegistry(GlobalConfiguration, EmbeddedCacheManager, Set<String>, ModuleRepository, ConfigurationManager) - Constructor for class org.infinispan.factories.GlobalComponentRegistry
Creates an instance of the component registry.
GlobalComponentRegistry.ModuleInitializer - Class in org.infinispan.factories
globalConfiguration - Variable in class org.infinispan.factories.AnyScopeComponentFactory
 
GlobalConfiguration - Class in org.infinispan.configuration.global
Configuration component that exposes the global configuration.
GlobalConfigurationBuilder - Class in org.infinispan.configuration.global
 
GlobalConfigurationBuilder() - Constructor for class org.infinispan.configuration.global.GlobalConfigurationBuilder
 
GlobalConfigurationChildBuilder - Interface in org.infinispan.configuration.global
 
GlobalConfigurationManager - Interface in org.infinispan.globalstate
The GlobalConfigurationManager is the main interface for sharing runtime configuration state across a cluster.
GlobalConfigurationManagerImpl - Class in org.infinispan.globalstate.impl
Implementation of GlobalConfigurationManager
GlobalConfigurationManagerImpl() - Constructor for class org.infinispan.globalstate.impl.GlobalConfigurationManagerImpl
 
GlobalConfigurationStateListener - Class in org.infinispan.globalstate.impl
Listens to events on the global state cache and manages cache configuration creation / removal accordingly
GlobalContextInitializer - Interface in org.infinispan.commons
Interface used to initialise the global SerializationContext using the specified Pojos, and the generated proto files and marshallers.
GlobalContextInitializerImpl - Class in org.infinispan.commons
WARNING: Generated code! Do not edit!
GlobalContextInitializerImpl() - Constructor for class org.infinispan.commons.GlobalContextInitializerImpl
 
globalId() - Method in class org.infinispan.transaction.xa.GlobalTransaction
Returns a simplified representation of the transaction.
globalIdLength() - Method in class org.infinispan.commons.tx.XidImpl
 
globalIdOffset() - Method in class org.infinispan.commons.tx.XidImpl
 
GlobalJmxConfiguration - Class in org.infinispan.configuration.global
 
GlobalJmxConfigurationBuilder - Class in org.infinispan.configuration.global
Configures JMX for the cache manager and its caches.