Index
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 -
This is a base class that should be used when implementing a CacheEventFilterConverter that provides default implementations for the
CacheEventFilter.accept(Object, Object, org.infinispan.metadata.Metadata, Object, org.infinispan.metadata.Metadata, EventType)
andConverter.convert(Object, Object, org.infinispan.metadata.Metadata)
methods so they just call theCacheEventFilterConverter.filterAndConvert(Object, Object, org.infinispan.metadata.Metadata, Object, org.infinispan.metadata.Metadata, EventType)
method and then do the right thing. - AbstractCacheEventFilterConverter() - Constructor for class org.infinispan.notifications.cachelistener.filter.AbstractCacheEventFilterConverter
- AbstractCacheStream<Original,
T, S extends BaseStream<T, S>, S2 extends S> - Class in org.infinispan.stream.impl -
Abstract stream that provides all of the common functionality required for all types of Streams including the various primitive types.
- AbstractCacheStream(Address, boolean, InvocationContext, long, int, Executor, ComponentRegistry, Function<? super Original, ?>, ClusterPublisherManager<?, ?>) - Constructor for class org.infinispan.stream.impl.AbstractCacheStream
- AbstractCacheStream(AbstractCacheStream<Original, T, S, S2>) - Constructor for class org.infinispan.stream.impl.AbstractCacheStream
- AbstractCacheTransaction - Class in org.infinispan.transaction.impl
-
Base class for local and remote transaction.
- AbstractCacheTransaction(GlobalTransaction, int, long) - Constructor for class org.infinispan.transaction.impl.AbstractCacheTransaction
- AbstractClientEvent - Class in org.infinispan.client.hotrod.event.impl
- AbstractClientEvent(byte[]) - Constructor for class org.infinispan.client.hotrod.event.impl.AbstractClientEvent
- AbstractClusterStats - Class in org.infinispan.stats.impl
- AbstractComponentFactory - Class in org.infinispan.factories
-
Factory that creates components used internally within Infinispan, and also wires dependencies into the components.
- AbstractComponentFactory() - Constructor for class org.infinispan.factories.AbstractComponentFactory
- AbstractComponentRegistry - Class in org.infinispan.factories
-
Deprecated, for removal: This API element is subject to removal in a future version.
- AbstractConfigurationChildBuilder - Class in org.infinispan.client.hotrod.configuration
-
AbstractConfigurationChildBuilder.
- AbstractConfigurationChildBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
- AbstractConfigurationReader - Class in org.infinispan.commons.configuration.io
- AbstractConfigurationReader(ConfigurationResourceResolver, Properties, PropertyReplacer, NamingStrategy) - Constructor for class org.infinispan.commons.configuration.io.AbstractConfigurationReader
- AbstractConfigurationWriter - Class in org.infinispan.commons.configuration.io
- AbstractConfigurationWriter(Writer, int, boolean, boolean, NamingStrategy) - Constructor for class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- AbstractConfigurationWriter.Tag - Class in org.infinispan.commons.configuration.io
- AbstractConsistentHash - Class in org.infinispan.distribution.ch.impl
- AbstractConsistentHash(int, List<Address>, float[]) - Constructor for class org.infinispan.distribution.ch.impl.AbstractConsistentHash
- AbstractConsistentHash(int, List<Address>, Map<Address, Float>) - Constructor for class org.infinispan.distribution.ch.impl.AbstractConsistentHash
- AbstractConsistentHash(ScopedPersistentState) - Constructor for class org.infinispan.distribution.ch.impl.AbstractConsistentHash
- AbstractConsistentHashFactory<CH extends ConsistentHash> - Class in org.infinispan.distribution.ch.impl
- AbstractConsistentHashFactory() - Constructor for class org.infinispan.distribution.ch.impl.AbstractConsistentHashFactory
- 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 -
Similar to
AbstractDelegatingCache
, but forAdvancedCache
. - 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 aMapSession
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 extends AbstractJdbcStoreConfiguration,
S extends AbstractJdbcStoreConfigurationBuilder<T, S>> - Class in org.infinispan.persistence.jdbc.common.configuration - AbstractJdbcStoreConfigurationBuilder(PersistenceConfigurationBuilder, AttributeSet) - Constructor for class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
- AbstractJdbcStoreConfigurationChildBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,
S>> - Class in org.infinispan.persistence.jdbc.common.configuration -
AbstractJdbcStoreConfigurationChildBuilder.
- AbstractJdbcStoreConfigurationChildBuilder(AbstractJdbcStoreConfigurationBuilder<?, S>) - Constructor for class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationChildBuilder
- AbstractJdbcStoreConfigurationParser - Class in org.infinispan.persistence.jdbc.common.configuration
- AbstractJdbcStoreConfigurationParser() - Constructor for class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationParser
- AbstractJdbcStoreConfigurationSerializer - Class in org.infinispan.persistence.jdbc.common.configuration
-
AbstractJdbcStoreConfigurationSerializer.
- AbstractJdbcStoreConfigurationSerializer() - Constructor for class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationSerializer
- AbstractJGroupsChannelConfigurator - Class in org.infinispan.remoting.transport.jgroups
- AbstractJGroupsChannelConfigurator() - Constructor for class org.infinispan.remoting.transport.jgroups.AbstractJGroupsChannelConfigurator
- AbstractKeyValueFilterConverter<K,
V, C> - Class in org.infinispan.filter -
This is a base class that should be used when implementing a KeyValueFilterConverter that provides default implementations for the
KeyValueFilter.accept(Object, Object, org.infinispan.metadata.Metadata)
andConverter.convert(Object, Object, org.infinispan.metadata.Metadata)
methods so they just call theKeyValueFilterConverter.filterAndConvert(Object, Object, org.infinispan.metadata.Metadata)
method and then do the right thing. - AbstractKeyValueFilterConverter() - Constructor for class org.infinispan.filter.AbstractKeyValueFilterConverter
- AbstractListenerImpl<T,
L extends ListenerInvocation<T>> - Class in org.infinispan.notifications.impl -
Functionality common to both
CacheManagerNotifierImpl
andCacheNotifierImpl
- AbstractListenerImpl() - Constructor for class org.infinispan.notifications.impl.AbstractListenerImpl
- AbstractListenerImpl.AbstractInvocationBuilder - Class in org.infinispan.notifications.impl
- AbstractListenerImpl.ListenerInvocationImpl<A> - Class in org.infinispan.notifications.impl
-
Class that encapsulates a valid invocation for a given registered listener - containing a reference to the method to be invoked as well as the target object.
- AbstractMap<K,
V> - Class in org.infinispan.commons.util -
Similar to the JDK's AbstractMap, this provides common functionality for custom map implementations.
- AbstractMap() - Constructor for class org.infinispan.commons.util.AbstractMap
- AbstractMap.SimpleEntry<K,
V> - Class in org.infinispan.commons.util - AbstractMarshaller - Class in org.infinispan.commons.marshall
-
Abstract Marshaller implementation containing shared implementations.
- AbstractMarshaller() - Constructor for class org.infinispan.commons.marshall.AbstractMarshaller
- AbstractMixedSiteStatus<E> - Class in org.infinispan.xsite.status
-
Abstract class to create mixed
SiteStatus
. - AbstractMixedSiteStatus(Collection<E>, Collection<E>) - Constructor for class org.infinispan.xsite.status.AbstractMixedSiteStatus
- AbstractModuleConfigurationBuilder - Class in org.infinispan.configuration.cache
-
AbstractModuleConfigurationBuilder.
- AbstractModuleConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
- AbstractNamedCacheComponentFactory - Class in org.infinispan.factories
-
A component factory for creating components scoped per-cache.
- AbstractNamedCacheComponentFactory() - Constructor for class org.infinispan.factories.AbstractNamedCacheComponentFactory
- AbstractPassivationManager - Class in org.infinispan.eviction.impl
-
A passivation manager
- AbstractPassivationManager() - Constructor for class org.infinispan.eviction.impl.AbstractPassivationManager
- AbstractPersistenceConfigurationChildBuilder - Class in org.infinispan.configuration.cache
-
AbstractPersistenceConfigurationChildBuilder.
- AbstractPersistenceConfigurationChildBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractPersistenceConfigurationChildBuilder
- AbstractProtocolServer<C extends ProtocolServerConfiguration> - Class in org.infinispan.server.core
-
A common protocol server dealing with common property parameter validation and assignment and transport lifecycle.
- AbstractProtocolServer(String) - Constructor for class org.infinispan.server.core.AbstractProtocolServer
- AbstractProtocolServerConfigurationChildBuilder<T extends ProtocolServerConfiguration,
S extends ProtocolServerConfigurationChildBuilder<T, S>> - Class in org.infinispan.server.core.configuration -
Helper
- AbstractProtocolServerConfigurationChildBuilder(ProtocolServerConfigurationChildBuilder<T, S>) - Constructor for class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
- AbstractRemoteCacheManagerFactory - Class in org.infinispan.spring.remote
-
An abstract base class for factories creating cache manager that are backed by an Infinispan RemoteCacheManager.
- AbstractRemoteCacheManagerFactory() - Constructor for class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
- AbstractRemoteStoreConfigurationChildBuilder<S> - Class in org.infinispan.persistence.remote.configuration
-
AbstractRemoteStoreConfigurationChildBuilder.
- AbstractRemoteStoreConfigurationChildBuilder(RemoteStoreConfigurationBuilder, AttributeSet) - Constructor for class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- AbstractRequest<T> - Class in org.infinispan.remoting.transport
-
A remote invocation request.
- AbstractRequest(long, ResponseCollector<T>, RequestRepository) - Constructor for class org.infinispan.remoting.transport.AbstractRequest
- AbstractSchemaJdbcConfiguration - Class in org.infinispan.persistence.sql.configuration
- AbstractSchemaJdbcConfiguration(AttributeSet, AsyncStoreConfiguration, ConnectionFactoryConfiguration, SchemaJdbcConfiguration) - Constructor for class org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfiguration
- AbstractSchemaJdbcConfigurationBuilder<T extends AbstractSchemaJdbcConfiguration,
S extends AbstractSchemaJdbcConfigurationBuilder<T, S>> - Class in org.infinispan.persistence.sql.configuration - AbstractSchemaJdbcConfigurationBuilder(PersistenceConfigurationBuilder, AttributeSet) - Constructor for class org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfigurationBuilder
- AbstractSchemaJdbcStore<K,
V, C extends AbstractSchemaJdbcConfiguration> - Class in org.infinispan.persistence.sql - AbstractSchemaJdbcStore() - Constructor for class org.infinispan.persistence.sql.AbstractSchemaJdbcStore
- AbstractSchemaJdbcStore.Parameter - Class in org.infinispan.persistence.sql
- AbstractSchemaJdbcStore.ProtoSchemaOptions<K,
V, C extends AbstractSchemaJdbcConfiguration> - Class in org.infinispan.persistence.sql - AbstractSchemaJdbcStore.ProtostreamFieldType - Enum in org.infinispan.persistence.sql
- AbstractSchemaJdbcStore.SchemaTableOperations<K,
V, C extends AbstractSchemaJdbcConfiguration> - Class in org.infinispan.persistence.sql - AbstractSecurityConfigurationChildBuilder - Class in org.infinispan.client.hotrod.configuration
-
AbstractSecurityConfigurationChildBuilder.
- AbstractSecurityConfigurationChildBuilder - Class in org.infinispan.persistence.remote.configuration
-
AbstractSecurityConfigurationChildBuilder.
- AbstractSegmentedAdvancedLoadWriteStore<K,
V> - Class in org.infinispan.persistence.support -
Abstract segment loader writer that implements all the single key non segmented methods by invoking the segmented equivalent by passing in the segment returned from invoking
AbstractSegmentedAdvancedLoadWriteStore.getKeyMapper()
. - AbstractSegmentedAdvancedLoadWriteStore() - Constructor for class org.infinispan.persistence.support.AbstractSegmentedAdvancedLoadWriteStore
- AbstractSegmentedStoreConfiguration<T extends AbstractStoreConfiguration> - Class in org.infinispan.configuration.cache
-
Abstract store configuration that should be extended when the store configuration supports being segmented.
- AbstractSegmentedStoreConfiguration(AttributeSet, AsyncStoreConfiguration) - Constructor for class org.infinispan.configuration.cache.AbstractSegmentedStoreConfiguration
- AbstractSiteStatusBuilder<E> - Class in org.infinispan.xsite.status
-
A
SiteStatus
builder based on its online and offline members. - AbstractSiteStatusBuilder() - Constructor for class org.infinispan.xsite.status.AbstractSiteStatusBuilder
- AbstractStoreConfiguration - Class in org.infinispan.configuration.cache
- AbstractStoreConfiguration(AttributeSet, AsyncStoreConfiguration) - Constructor for class org.infinispan.configuration.cache.AbstractStoreConfiguration
- AbstractStoreConfigurationBuilder<T extends StoreConfiguration,
S extends AbstractStoreConfigurationBuilder<T, S>> - Class in org.infinispan.configuration.cache - AbstractStoreConfigurationBuilder(PersistenceConfigurationBuilder, AttributeSet) - Constructor for class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
- AbstractStoreConfigurationBuilder(PersistenceConfigurationBuilder, AttributeSet, AttributeSet) - Constructor for class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
- AbstractStoreConfigurationChildBuilder<S> - Class in org.infinispan.configuration.cache
- AbstractStoreConfigurationChildBuilder(StoreConfigurationBuilder<? extends AbstractStoreConfiguration, ? extends StoreConfigurationBuilder<?, ?>>) - Constructor for class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
- AbstractStoreSerializer - Class in org.infinispan.configuration.serializing
-
AbstractStoreSerializer.
- AbstractStoreSerializer() - Constructor for class org.infinispan.configuration.serializing.AbstractStoreSerializer
- AbstractThreadPoolExecutorFactory<T extends ExecutorService> - Class in org.infinispan.factories.threads
-
Abstract
ThreadPoolExecutorFactory
that contains commons variables for configuring a thread pool - AbstractThreadPoolExecutorFactory(int, int, int, long) - Constructor for class org.infinispan.factories.threads.AbstractThreadPoolExecutorFactory
- AbstractTopologyAffectedCommand - Class in org.infinispan.commands
-
Base class for commands that carry topology id.
- AbstractTopologyAffectedCommand() - Constructor for class org.infinispan.commands.AbstractTopologyAffectedCommand
- AbstractTranscoder - Class in org.infinispan.commons.dataconversion
-
Class to inherit when implementing transcoders, will handle pre and post processing of the content.
- AbstractTranscoder() - Constructor for class org.infinispan.commons.dataconversion.AbstractTranscoder
- AbstractTransport - Class in org.infinispan.remoting.transport
-
Deprecated, 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 extends AbstractCacheTransaction> - Class in org.infinispan.context.impl
-
Support class for
TxInvocationContext
. - AbstractTxInvocationContext(T, Address) - Constructor for class org.infinispan.context.impl.AbstractTxInvocationContext
- AbstractTypedPropertiesConfiguration - Class in org.infinispan.commons.configuration
- AbstractTypedPropertiesConfiguration(Properties) - Constructor for class org.infinispan.commons.configuration.AbstractTypedPropertiesConfiguration
-
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, 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 extends ProtocolServerConfiguration> - Class in org.infinispan.server.core.transport
-
This class provides the functionality to either accept or reject new
Channel
s 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 orfalse
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 aSerializationContextInitializer
viaSerializationConfigurationBuilder.addContextInitializer(SerializationContextInitializer)
, or specifying a custom marshaller for user types viaSerializationConfigurationBuilder.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 aSerializationContextInitializer
viaSerializationConfigurationBuilder.addContextInitializer(SerializationContextInitializer)
, or specifying a custom marshaller for user types viaSerializationConfigurationBuilder.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 aSerializationContextInitializer
viaSerializationConfigurationBuilder.addContextInitializer(SerializationContextInitializer)
, or specifying a custom marshaller for user types viaSerializationConfigurationBuilder.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 theProtoStreamMarshaller
'sSerializationContext
. - 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 theProtoStreamMarshaller
'sSerializationContext
. - 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 anEmbeddedCacheManager
. - 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 anEmbeddedCacheManager
. - addDependency(T, T) - Method in class org.infinispan.util.DependencyGraph
-
Add a dependency between two elements
- addDispatcher(EventDispatcher<?>) - Method in class org.infinispan.client.hotrod.event.impl.ClientListenerNotifier
- addDynamicDependency(String, String) - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
-
Add a dynamic dependency between two components.
- addDynamicDependency(String, String) - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
- addEntityType(Class<?>) - Method in class org.infinispan.search.mapper.mapping.SearchMappingBuilder
-
Register a type as an entity type with the default name, its class name.
- addEntityType(Class<?>, String) - Method in class org.infinispan.search.mapper.impl.InfinispanMappingInitiator
- addEntityType(Class<?>, String) - Method in class org.infinispan.search.mapper.mapping.SearchMappingBuilder
-
Register a type as an entity type with the given name.
- addEntityTypes(Set<Class<?>>) - Method in class org.infinispan.search.mapper.mapping.SearchMappingBuilder
- addErroneousAttribute(String) - Method in exception org.infinispan.commons.CacheConfigurationException
-
Deprecated, 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
-
Asynchronous version of
FilteringListenable.addFilteredListener(Object, CacheEventFilter, CacheEventConverter, Set)
- 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 aFlagBitSets
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 aFlagBitSets
constant instead. - addGet(Object, boolean) - Method in class org.infinispan.extendedstats.topK.StreamSummaryContainer
-
Adds the key to the read top-key.
- addGrouper(Grouper<?>) - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
-
Add a grouper
- addHexByte(StringBuilder, byte) - Static method in class org.infinispan.commons.util.Util
- addIndexedEntities(Class<?>...) - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
- addIndexedEntities(Class<?>...) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
- addIndexedEntities(Class<?>...) - Method in interface org.infinispan.configuration.cache.IndexingConfigurationChildBuilder
- addIndexedEntities(String...) - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
- addIndexedEntities(String...) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
- addIndexedEntities(String...) - Method in interface org.infinispan.configuration.cache.IndexingConfigurationChildBuilder
- addIndexedEntity(Class<?>) - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
- addIndexedEntity(Class<?>) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
- addIndexedEntity(Class<?>) - Method in interface org.infinispan.configuration.cache.IndexingConfigurationChildBuilder
- addIndexedEntity(String) - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
- addIndexedEntity(String) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
- addIndexedEntity(String) - Method in interface org.infinispan.configuration.cache.IndexingConfigurationChildBuilder
- AddIndexingOperation - Class in org.infinispan.search.mapper.work.impl
- addInterceptor() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
-
Deprecated, 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.Use
ConfigurationChildBuilder.addJavaSerialAllowList(String...)
instead. To be removed in 14.0. - addJGroupsStack(EmbeddedJGroupsChannelConfigurator, String) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
- addJGroupsStack(FileJGroupsChannelConfigurator) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
- addKeyTransformer(Class<?>, Class<?>) - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
- addKeyTransformer(Class<?>, Class<?>) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
-
Registers a transformer for a key class.
- addKeyTransformer(Class<?>, Class<?>) - Method in interface org.infinispan.configuration.cache.IndexingConfigurationChildBuilder
- addKeyValueFilterConverterFactory(String, KeyValueFilterConverterFactory) - Method in class org.infinispan.server.hotrod.HotRodServer
- addKeyValueFilterConverterFactory(String, KeyValueFilterConverterFactory) - Method in class org.infinispan.server.hotrod.iteration.DefaultIterationManager
- addKeyValueFilterConverterFactory(String, KeyValueFilterConverterFactory) - Method in interface org.infinispan.server.hotrod.iteration.IterationManager
- addListener(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- addListener(Object) - Method in class org.infinispan.cache.impl.EncoderCache
- addListener(Object) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
- addListener(Object) - Method in interface org.infinispan.notifications.Listenable
-
Adds a listener to the component.
- addListener(Object, ClassLoader) - Method in interface org.infinispan.notifications.ClassLoaderAwareListenable
-
Adds a listener along with a class loader to use for the invocation
- addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.cache.impl.EncoderCache
- addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in interface org.infinispan.notifications.FilteringListenable
-
Registers a listener that will be notified on events that pass the filter condition.
- addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, ClassLoader) - Method in interface org.infinispan.notifications.ClassLoaderAwareFilteringListenable
-
Adds a listener with the provided filter and converter and using a given classloader when invoked.
- addListener(String, T) - Method in class org.infinispan.client.hotrod.counter.impl.NotificationManager
- addListener(AttributeListener<T>) - Method in class org.infinispan.commons.configuration.attributes.Attribute
- addListener(ListenerHolder, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, ClassLoader) - Method in interface org.infinispan.notifications.DataConversionAwareListenable
- addListener(ActionListener) - Method in interface org.infinispan.remoting.inboundhandler.action.Action
-
Adds a listener to be invoked when this action is ready or canceled.
- addListener(ActionListener) - Method in class org.infinispan.remoting.inboundhandler.action.DefaultReadyAction
- addListener(ActionListener) - Method in interface org.infinispan.remoting.inboundhandler.action.ReadyAction
-
It adds a listener that is invoked when this action is ready.
- addListener(CacheTransaction.TransactionCompletedListener) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
- addListener(CacheTransaction.TransactionCompletedListener) - Method in interface org.infinispan.transaction.xa.CacheTransaction
- addListener(KeyAwareLockListener) - Method in interface org.infinispan.util.concurrent.locks.KeyAwareLockPromise
-
It adds the listener to this
LockPromise
. - addListener(LockListener) - Method in interface org.infinispan.util.concurrent.locks.LockPromise
-
Adds a
LockListener
to be invoked when the lock is available. - addListener(PendingLockListener) - Method in interface org.infinispan.util.concurrent.locks.PendingLockPromise
-
Adds a listener to this promise.
- addListener(T) - Method in class org.infinispan.client.hotrod.counter.impl.BaseCounter
- addListener(T) - Method in interface org.infinispan.counter.api.StrongCounter
-
Registers a
CounterListener
to this counter. - addListener(T) - Method in interface org.infinispan.counter.api.WeakCounter
-
Adds a
CounterListener
to this counter. - addListenerAsync(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- addListenerAsync(Object) - Method in class org.infinispan.cache.impl.CacheImpl
- addListenerAsync(Object) - Method in class org.infinispan.cache.impl.DecoratedCache
- addListenerAsync(Object) - Method in class org.infinispan.cache.impl.EncoderCache
- addListenerAsync(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- addListenerAsync(Object) - Method in class org.infinispan.manager.DefaultCacheManager
- addListenerAsync(Object) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
- addListenerAsync(Object) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- addListenerAsync(Object) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
- addListenerAsync(Object) - Method in interface org.infinispan.notifications.Listenable
-
Asynchronous version of
Listenable.addListener(Object)
- addListenerAsync(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
- addListenerAsync(Object, ClassLoader) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- addListenerAsync(Object, ClassLoader) - Method in interface org.infinispan.notifications.ClassLoaderAwareListenable
-
Asynchronous version of
ClassLoaderAwareListenable.addListener(Object, ClassLoader)
- 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
-
Asynchronous version of
FilteringListenable.addListener(Object, CacheEventFilter, CacheEventConverter)
- 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
-
An add listener operation for
StrongCounter.addListener(CounterListener)
andWeakCounter.addListener(CounterListener)
- AddListenerOperation(ChannelFactory, AtomicReference<ClientTopology>, Configuration, String, byte[], SocketAddress) - Constructor for class org.infinispan.client.hotrod.counter.operation.AddListenerOperation
- addLocalBias(Object, int) - Method in interface org.infinispan.scattered.BiasManager
-
Allow reading local data if the topology is still actual.
- addLocalBias(Object, int) - Method in class org.infinispan.scattered.impl.BiasManagerImpl
- addLocalValue(ExtendedStatistic, double) - Method in class org.infinispan.extendedstats.CacheStatisticCollector
-
Adds a value to a local statistic.
- addLockedKey(Object) - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
- addLockedKey(Object) - Method in class org.infinispan.context.impl.ClearInvocationContext
- addLockedKey(Object) - Method in class org.infinispan.context.impl.ImmutableContext
- addLockedKey(Object) - Method in class org.infinispan.context.impl.NonTxInvocationContext
- addLockedKey(Object) - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
- addLockedKey(Object) - Method in interface org.infinispan.context.InvocationContext
-
Tracks the given key as locked by this invocation context.
- addLockedKeys(Collection<?>) - Method in interface org.infinispan.context.InvocationContext
- addLockInformation(Object, boolean, boolean) - Method in class org.infinispan.extendedstats.topK.StreamSummaryContainer
-
Adds the lock information about the key, namely if the key suffer some contention and if the keys was locked or not.
- AddLoggerListenerAsyncAction - Class in org.infinispan.security.actions
-
Add logger listener action.
- AddLoggerListenerAsyncAction(EmbeddedCacheManager, Object) - Constructor for class org.infinispan.security.actions.AddLoggerListenerAsyncAction
- addMany(MetaParam...) - Method in class org.infinispan.functional.impl.MetaParams
- addMarshalledEntry(Object, MarshallableEntry<Object, Object>) - Method in class org.infinispan.persistence.support.BatchModification
- addMechanisms(String...) - Method in class org.infinispan.rest.configuration.AuthenticationConfigurationBuilder
- addMechanisms(String...) - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
- addMechanisms(String...) - Method in class org.infinispan.server.hotrod.configuration.SaslConfigurationBuilder
- addMechProperty(String, String) - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
- addMember(Address, boolean) - Method in class org.infinispan.xsite.status.CacheSiteStatusBuilder
-
Adds a member with an online/offline connection to the server based on the
online
parameter. - addMergePolicyFactory(EntryMergePolicyFactory) - Method in class org.infinispan.conflict.EntryMergePolicyFactoryRegistry
- addModification(WriteCommand) - Method in class org.infinispan.transaction.impl.LocalTransaction
- addModule(Class<T>) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- addModule(Class<T>) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- addNearCacheListener(Object, int) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- addNearCacheListener(Object, int) - Method in interface org.infinispan.client.hotrod.impl.InternalRemoteCache
-
Add a client listener to handle near cache with bloom filter optimization The listener object must be annotated with @
ClientListener
annotation. - addNearCacheListener(Object, int) - Method in class org.infinispan.client.hotrod.impl.InvalidatedNearRemoteCache
- addNearCacheListener(Object, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- addNewRule() - Method in class org.infinispan.rest.configuration.CorsConfigurationBuilder
- AddOperation - Class in org.infinispan.client.hotrod.counter.operation
-
Add operation.
- AddOperation(ChannelFactory, AtomicReference<ClientTopology>, Configuration, String, long, boolean) - Constructor for class org.infinispan.client.hotrod.counter.operation.AddOperation
- addOptionalParameter(String, Object) - Method in class org.infinispan.tasks.TaskContext
-
Adds a named parameter to the task context only if it is non-null
- addOrUpdate(Object, String, Object) - Method in class org.infinispan.search.mapper.work.impl.SearchIndexerImpl
- addOrUpdate(Object, String, Object) - Method in interface org.infinispan.search.mapper.work.SearchIndexer
- AddOrUpdateIndexingOperation - Class in org.infinispan.search.mapper.work.impl
- addOwner(int, Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
- addOwner(Address) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfo
-
Adds
owner
as a node where this transaction information is maintained. - addOwners(int, Collection<Address>) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
- addParameter(String, Object) - Method in class org.infinispan.tasks.TaskContext
-
Adds a named parameter to the task context
- addParams(StringBuilder) - Method in class org.infinispan.client.hotrod.counter.operation.RemoveListenerOperation
- addParserListener(ConfigurationParserListener) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
- addPartialCommit1PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, List<WriteCommand>) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
- addPartialCommit1PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, List<WriteCommand>) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
-
Adds a partially committed transaction.
- addPartialCommit1PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, List<WriteCommand>) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
- addPartialCommit2PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, Map<Object, IncrementableEntryVersion>) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
- addPartialCommit2PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, Map<Object, IncrementableEntryVersion>) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
-
Adds a partially committed transaction.
- addPartialCommit2PCTransaction(GlobalTransaction, Collection<Address>, Collection<Object>, Map<Object, IncrementableEntryVersion>) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
- addPartialRollbackTransaction(GlobalTransaction, Collection<Address>, Collection<Object>) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
- addPartialRollbackTransaction(GlobalTransaction, Collection<Address>, Collection<Object>) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
-
Adds a partially aborted transaction.
- addPartialRollbackTransaction(GlobalTransaction, Collection<Address>, Collection<Object>) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
- addPersistenceInterceptors(AsyncInterceptorChain, Configuration, List<StoreConfiguration>) - Method in class org.infinispan.factories.InterceptorChainFactory
-
Adds all the interceptors related to persistence to the stack.
- addPersistentAddressMapping(Address, PersistentUUID) - Method in interface org.infinispan.topology.PersistentUUIDManager
-
Adds a mapping between an
Address
and aPersistentUUID
- 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()
andIndexingConfigurationBuilder.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
-
Create a new
RemoteCacheConfiguration
. - 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 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 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.Callback to be notified when an entry is removed by the
AdvancedCacheWriter.purge(java.util.concurrent.Executor, org.infinispan.persistence.spi.AdvancedCacheWriter.PurgeListener)
method. - 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 customMarshaller
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 implementSerializable
- allMatch(SerializableIntPredicate) - Method in interface org.infinispan.IntCacheStream
-
Same as
IntStream.allMatch(IntPredicate)
except that the IntPredicate must also implementSerializable
- 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 implementSerializable
- 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
-
Configures the
EmbeddedCacheManager
ClassAllowList
. - allowMethods(String[]) - Method in class org.infinispan.rest.configuration.CorsRuleConfigurationBuilder
- allowMethodsToBlock(BlockHound.Builder, Class<?>, boolean) - Static method in class org.infinispan.commons.internal.CommonsBlockHoundIntegration
- allowOrigins(String[]) - Method in class org.infinispan.rest.configuration.CorsRuleConfigurationBuilder
- allowPublicMethodsToBlock(BlockHound.Builder, Class<?>) - Static method in class org.infinispan.commons.internal.CommonsBlockHoundIntegration
- allStringsInterned - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
-
Implementation notice: the is instance variable that controls if newString() is interning.
- allSubmissionExecutor(Predicate<? super Address>, EmbeddedCacheManager, Transport, long, TimeUnit, Executor, ScheduledExecutorService) - Static method in class org.infinispan.manager.impl.ClusterExecutors
- allTypeIdentifiers() - Method in interface org.infinispan.search.mapper.session.impl.InfinispanTypeContextProvider
- ALPNHandler - Class in org.infinispan.rest
-
Handler responsible for TLS/ALPN negotiation.
- ALPNHandler(RestServer) - Constructor for class org.infinispan.rest.ALPNHandler
- ALREADY_HAS_LOCK - Enum constant in enum org.infinispan.context.Flag
-
Flag to designate that this operation was performed on behalf of another that already has the lock for the given key.
- ALREADY_HAS_LOCK - Static variable in class org.infinispan.context.impl.FlagBitSets
- ALREADY_OFFLINE - Enum constant in enum org.infinispan.xsite.status.TakeSiteOfflineResponse
- ALREADY_ONLINE - Enum constant in enum org.infinispan.xsite.status.BringSiteOnlineResponse
- ALWAYS_REMOVE - Enum constant in enum org.infinispan.xsite.spi.XSiteMergePolicy
-
Always remove the key if there is a conflict.
- ALWAYS_TRUE_LOGIC - Static variable in class org.infinispan.transaction.impl.WriteSkewHelper
- AlwaysRemoveXSiteEntryMergePolicy<K,
V> - Class in org.infinispan.xsite.spi -
A
XSiteEntryMergePolicy
that removes the key if a conflict is detected. - alwaysTruePredicate() - Static method in class org.infinispan.stream.StreamMarshalling
-
Predicate taht always returns true irrespective of the value provided
- amendChannel(JChannel) - Method in class org.infinispan.remoting.transport.jgroups.AbstractJGroupsChannelConfigurator
- amendConfiguration(String, Integer, Long) - Method in class org.infinispan.xsite.status.DefaultTakeOfflineManager
- amendConfiguration(String, Integer, Long) - Method in class org.infinispan.xsite.status.NoOpTakeOfflineManager
- amendConfiguration(String, Integer, Long) - Method in interface org.infinispan.xsite.status.TakeOfflineManager
-
It changes the
TakeOfflineConfiguration
for sitesiteName
. - 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 implementSerializable
- anyMatch(SerializableIntPredicate) - Method in interface org.infinispan.IntCacheStream
-
Same as
IntStream.anyMatch(IntPredicate)
except that the IntPredicate must also implementSerializable
- 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 implementSerializable
- 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
-
Used by
CompletableFuture.thenComposeAsync(Function, Executor)
, it adds theExponentialBackOff
delay. - 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
- 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
AsyncInterceptor
s. - asyncInvokeNext(InvocationContext, VisitableCommand, Collection<? extends CompletionStage<?>>) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
-
Suspend invocation until all
delays
complete, then if successful invoke the next interceptor. - asyncInvokeNext(InvocationContext, VisitableCommand, CompletionStage<?>) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
-
Suspend the invocation until
delay
completes, then if successful invoke the next interceptor. - asyncInvokeNext(InvocationContext, VisitableCommand, InvocationStage) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
-
Suspend the invocation until
invocationStage
completes, then if successful invoke the next interceptor. - asyncMassIndexerStarted() - Method in interface org.infinispan.rest.logging.Log
- asyncMassIndexerSuccess() - Method in interface org.infinispan.rest.logging.Log
- AsyncNonBlockingStore<K,
V> - Class in org.infinispan.persistence.async -
A delegating NonBlockingStore implementation that batches write operations and runs the resulting batches on the delegate store in a non overlapping manner.
- AsyncNonBlockingStore(NonBlockingStore<K, V>) - Constructor for class org.infinispan.persistence.async.AsyncNonBlockingStore
- asyncPrepare(XidImpl) - Method in interface org.infinispan.commons.tx.AsyncXaResource
- asyncPrepare(XidImpl) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
- asyncProcessor - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl
- AsyncProviderState - Class in org.infinispan.xsite.statetransfer
-
A
XSiteStateProviderState
for asynchronous cross-site replication state transfer (IRAC). - asyncRollback(XidImpl) - Method in interface org.infinispan.commons.tx.AsyncXaResource
- asyncRollback(XidImpl) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
- AsyncStoreConfiguration - Class in org.infinispan.configuration.cache
-
Configuration for the async cache store.
- AsyncStoreConfiguration(AttributeSet) - Constructor for class org.infinispan.configuration.cache.AsyncStoreConfiguration
- AsyncStoreConfigurationBuilder<S> - Class in org.infinispan.configuration.cache
-
Configuration for the async cache store.
- AsyncSynchronization - Interface in org.infinispan.commons.tx
-
Non-blocking
Synchronization
. - asyncThreadPool() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
- asyncThreadPool() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
- asyncThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfiguration
-
Deprecated, 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 thisJson
array. - at(String) - Method in class org.infinispan.commons.dataconversion.internal.Json
-
Return the specified property of a
Json
object ornull
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
Attribute
s. - 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 currentAccessControlContext
, 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 commandXSiteAutoTransferStatusCommand
. - AutoStateTransferResponse(boolean, XSiteStateTransferMode) - Constructor for class org.infinispan.xsite.response.AutoStateTransferResponse
- AutoStateTransferResponseCollector - Class in org.infinispan.xsite.response
-
A
ResponseCollector
that mergesAutoStateTransferResponse
. - 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 in org.infinispan.partitionhandling
-
Thrown when a partition happened and the key that an operation tries to access is not available.
- AvailabilityException() - Constructor for exception org.infinispan.partitionhandling.AvailabilityException
- AvailabilityException(String) - Constructor for exception org.infinispan.partitionhandling.AvailabilityException
- AvailabilityException(String, Throwable) - Constructor for exception org.infinispan.partitionhandling.AvailabilityException
- AvailabilityException(Throwable) - Constructor for exception org.infinispan.partitionhandling.AvailabilityException
- availabilityInterval() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
- availabilityInterval(int) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
- AvailabilityMode - Enum in org.infinispan.partitionhandling
- AvailabilityMode.Externalizer - Class in org.infinispan.partitionhandling
- AvailabilityStrategy - Interface in org.infinispan.partitionhandling.impl
-
Implementations decide what to do when the cache membership changes, either because new nodes joined, nodes left, or there was a merge.
- AvailabilityStrategyContext - Interface in org.infinispan.partitionhandling.impl
-
Contains information about the current state of the cache.
- available() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- available() - Method in interface org.infinispan.configuration.cache.JMXStatisticsConfiguration
-
Deprecated, 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 methodCacheManager.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 methodCacheManager.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.since 10.0. Use
Transport.backupRemotely(XSiteBackup, XSiteRequest)
instead. - 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 extends BaseStream<T, S>> - Interface in org.infinispan -
Interface that defines the base methods of all streams returned from a
Cache
. - BaseCacheStream.SegmentCompletionListener - Interface in org.infinispan
-
Functional interface that is used as a callback when segments are completed.
- baseCfg - Variable in class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller
- BaseCounter - Class in org.infinispan.client.hotrod.counter.impl
- BaseCustomAsyncInterceptor - Class in org.infinispan.interceptors
-
Anyone using the
AsyncInterceptorChain.addInterceptor(AsyncInterceptor, int)
method (or any of its overloaded forms) or registering custom interceptors via XML should extend this base class when creating their own custom interceptors. - BaseCustomAsyncInterceptor() - Constructor for class org.infinispan.interceptors.BaseCustomAsyncInterceptor
- BaseExtendedStatisticsContainer - Class in org.infinispan.extendedstats.container
-
Common logic for the
ExtendedStatisticsContainer
- BaseExtendedStatisticsContainer(int) - Constructor for class org.infinispan.extendedstats.container.BaseExtendedStatisticsContainer
- BaseJdbcStore<K,
V, C extends AbstractJdbcStoreConfiguration> - Class in org.infinispan.persistence.jdbc.common.impl - BaseJdbcStore() - Constructor for class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
- BaseRequestProcessor - Class in org.infinispan.server.hotrod
- 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 extends org.infinispan.xsite.statetransfer.BaseXSiteStateProviderState.OutboundTask> - Class in org.infinispan.xsite.statetransfer
-
Common code for
AsyncProviderState
andSyncProviderState
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
-
A basic
CallbackHandler
. - 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()
andBatchingCache.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.please use
AbstractStoreConfiguration.maxBatchSize()
instead. - 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.Please use
AbstractStoreConfigurationBuilder.maxBatchSize(int)
instead. - 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'sEncodingConfiguration
to define aMediaType
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.CounterResource
- BlockingManager - Interface in org.infinispan.util.concurrent
-
Manager utility for blocking operations that runs tasks on the blocking executor and returns a
CompletionStage
orPublisher
that continues on the non-blocking executor, similar tostage.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.ScheduledExecutorFactoryConfigurationBuilder
- blockingThreadPool() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
- blockingThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfiguration
- blockingThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- blockingThreadPool() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Configuration for the blocking thread pool
- blockingThreadPool() - Method in class org.infinispan.configuration.global.ThreadsConfiguration
- blockingThreadPool() - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
- BlockingThreadPoolExecutorFactory - Class in org.infinispan.commons.executors
-
Deprecated, 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
- 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
-
The return value of
TakeOfflineManager.bringSiteOnline(String)
. - 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.AbstractModuleConfigurationBuilder
- build() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- build() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- build() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
- build() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- build() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Builds a
GlobalConfiguration
object using the settings applied to this builder - build() - Method in class org.infinispan.counter.api.CounterConfiguration.Builder
- build() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
- build() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
- build() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata.Builder
- build() - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
- build() - Method in class org.infinispan.metadata.impl.PrivateMetadata.Builder
- build() - Method in interface org.infinispan.metadata.Metadata.Builder
-
Build a metadata instance.
- build() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- build() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.DelegatingCacheInvocationBuilder
- build() - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl.DefaultBuilder
- build() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
- build() - Method in interface org.infinispan.query.dsl.QueryBuilder
-
Deprecated.Builds the query object.
- build() - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- build() - Method in interface org.infinispan.rest.framework.impl.RestRequestBuilder
- build() - Method in interface org.infinispan.rest.framework.impl.RestResponseBuilder
- build() - Method in class org.infinispan.rest.framework.impl.SimpleRestResponse.Builder
- build() - Method in class org.infinispan.rest.NettyRestResponse.Builder
- build() - Method in class org.infinispan.search.mapper.search.loading.context.impl.InfinispanLoadingContext.Builder
- build() - Method in class org.infinispan.server.core.backup.BackupManagerResources.Builder
- build() - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
- build() - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
-
Builds a configuration object
- build() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
- build() - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
- build() - Method in class org.infinispan.xsite.status.AbstractSiteStatusBuilder
- build(boolean) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- build(boolean) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- build(boolean) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- build(boolean) - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
- build(boolean) - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
- build(int) - Method in interface org.infinispan.commons.marshall.MarshallUtil.ArrayBuilder
- build(int) - Method in interface org.infinispan.commons.marshall.MarshallUtil.CollectionBuilder
- build(int) - Method in interface org.infinispan.commons.marshall.MarshallUtil.EnumBuilder
- build(int) - Method in interface org.infinispan.commons.marshall.MarshallUtil.MapBuilder
- build(Optional<SearchIntegration>) - Method in class org.infinispan.search.mapper.mapping.SearchMappingBuilder
- build(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- build(InvocationImpl.Builder) - Method in class org.infinispan.rest.framework.impl.Invocations.Builder
- buildBackupAckCommand(long, int) - Method in interface org.infinispan.commands.CommandsFactory
- buildBackupAckCommand(long, int) - Method in class org.infinispan.commands.CommandsFactoryImpl
- buildBackupMultiKeyAckCommand(long, int, int) - Method in interface org.infinispan.commands.CommandsFactory
- buildBackupMultiKeyAckCommand(long, int, int) - Method in class org.infinispan.commands.CommandsFactoryImpl
- buildBackupNoopCommand() - Method in interface org.infinispan.commands.CommandsFactory
- buildBackupNoopCommand() - Method in class org.infinispan.commands.CommandsFactoryImpl
- buildCancelPublisherCommand(String) - Method in interface org.infinispan.commands.CommandsFactory
- buildCancelPublisherCommand(String) - Method in class org.infinispan.commands.CommandsFactoryImpl
- buildCheckTransactionRpcCommand(Collection<GlobalTransaction>) - Method in interface org.infinispan.commands.CommandsFactory
- buildCheckTransactionRpcCommand(Collection<GlobalTransaction>) - Method in class org.infinispan.commands.CommandsFactoryImpl
- buildClearCommand(long) - Method in interface org.infinispan.commands.CommandsFactory
-
Builds a ClearCommand
- buildClearCommand(long) - Method in class org.infinispan.commands.CommandsFactoryImpl
- buildClusteredGetAllCommand(List<?>, long, GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
-
Builds a ClusteredGetAllCommand, which is a remote lookup command
- buildClusteredGetAllCommand(List<?>, long, GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
- buildClusteredGetCommand(Object, Integer, long) - Method in interface org.infinispan.commands.CommandsFactory
-
Builds a ClusteredGetCommand, which is a remote lookup command
- buildClusteredGetCommand(Object, Integer, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
- buildCommitCommand(GlobalTransaction) - Method in interface org.infinispan.commands.CommandsFactory
-
Builds a CommitCommand
- buildCommitCommand(GlobalTransaction) - Method in class org.infinispan.commands.CommandsFactoryImpl
- buildCompleteTransactionCommand(XidImpl, boolean) - Method in interface org.infinispan.commands.CommandsFactory
-
Builds a CompleteTransactionCommand command.
- buildCompleteTransactionCommand(XidImpl, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
- buildComputeCommand(Object, BiFunction, boolean, int, Metadata, long) - Method in interface org.infinispan.commands.CommandsFactory
-
Builds a ComputeCommand
- buildComputeCommand(Object, BiFunction, boolean, int, Metadata, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
- buildComputeIfAbsentCommand(Object, Function, int, Metadata, long) - Method in interface org.infinispan.commands.CommandsFactory
-
Builds a ComputeIfAbsentCommand
- buildComputeIfAbsentCommand(Object, Function, int, Metadata, long) - Method in class org.infinispan.commands.CommandsFactoryImpl
- buildConflictResolutionStartCommand(int, IntSet) - Method in interface org.infinispan.commands.CommandsFactory
- buildConflictResolutionStartCommand(int, IntSet) - Method in class org.infinispan.commands.CommandsFactoryImpl
- buildEntryReductionPublisherCommand(boolean, DeliveryGuarantee, IntSet, Set<K>, Set<K>, long, Function<? super Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>>, Function<? super Publisher<R>, ? extends CompletionStage<R>>) - Method in interface org.infinispan.commands.CommandsFactory
- buildEntryReductionPublisherCommand(boolean, DeliveryGuarantee, IntSet, Set<K>, Set<K>, long, Function<? super Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>>, Function<? super Publisher<R>, ? extends CompletionStage<R>>) - Method in class org.infinispan.commands.CommandsFactoryImpl
- buildEntrySetCommand(long) - Method in interface org.infinispan.commands.CommandsFactory
-
Builds a EntrySetCommand
- buildEntrySetCommand(long) - Method in class org.infinispan.commands.CommandsFactoryImpl
- builder - Variable in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
- 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 ofMetadata
instance which are full copies of thisMetadata
. - 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.since 11.0 use
CommandsFactory.buildSingleRpcCommand(VisitableCommand)
instead. - 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.ReadWriteMapImpl
- 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 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 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 in org.infinispan.commons
-
An exception that represents an error in the configuration.
- CacheConfigurationException(Exception) - Constructor for exception org.infinispan.commons.CacheConfigurationException
- CacheConfigurationException(String) - Constructor for exception org.infinispan.commons.CacheConfigurationException
- CacheConfigurationException(String, String) - Constructor for exception org.infinispan.commons.CacheConfigurationException
-
Deprecated, for removal: This API element is subject to removal in a future version.
- CacheConfigurationException(String, Throwable) - Constructor for exception 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 extends CacheContainerAdmin,
A extends BasicConfiguration> - Interface in org.infinispan.commons.api -
Administrative cache container operations.
- CacheContainerAdmin.AdminFlag - Enum in org.infinispan.commons.api
-
Flags which affect only administrative operations
- 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
orClusterCacheStats
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
orClusterCacheStats
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 readsMap.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 in org.infinispan.commons
-
Thrown when operations fail unexpectedly.
- CacheException() - Constructor for exception org.infinispan.commons.CacheException
- CacheException(String) - Constructor for exception org.infinispan.commons.CacheException
- CacheException(String, Throwable) - Constructor for exception org.infinispan.commons.CacheException
- CacheException(String, Throwable, boolean, boolean) - Constructor for exception org.infinispan.commons.CacheException
- CacheException(Throwable) - Constructor for exception org.infinispan.commons.CacheException
- 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 viaEmbeddedCacheManager.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
andKeyValueFilterConverter
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 in org.infinispan.topology
-
Thrown when a cache fails to join a cluster
- CacheJoinException() - Constructor for exception org.infinispan.topology.CacheJoinException
- CacheJoinException(String) - Constructor for exception org.infinispan.topology.CacheJoinException
- CacheJoinException(String, Throwable) - Constructor for exception org.infinispan.topology.CacheJoinException
- CacheJoinException(Throwable) - Constructor for exception org.infinispan.topology.CacheJoinException
- CacheJoinInfo - Class in org.infinispan.topology
-
This class contains the information that a cache needs to supply to the coordinator when starting up.
- CacheJoinInfo(ConsistentHashFactory, 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 abyte[]
and produces a JSON output. - CacheKeyStreamProcessor(Publisher<byte[]>) - Constructor for class org.infinispan.rest.stream.CacheKeyStreamProcessor
- CacheListenerException - Exception in org.infinispan.commons
-
Wraps exceptions produced by listener implementations.
- CacheListenerException() - Constructor for exception org.infinispan.commons.CacheListenerException
- CacheListenerException(String) - Constructor for exception org.infinispan.commons.CacheListenerException
- CacheListenerException(String, Throwable) - Constructor for exception org.infinispan.commons.CacheListenerException
- CacheListenerException(Throwable) - Constructor for exception org.infinispan.commons.CacheListenerException
- CacheLoader<K,
V> - Interface in org.infinispan.persistence.spi -
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.use
RemoteCacheConfigurationBuilder.nearCacheMode(NearCacheMode)
to enable near-caching per-cache - 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.use
RemoteCacheConfigurationBuilder.nearCacheMode(NearCacheMode)
to enable near-caching per-cache - 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 in org.infinispan.rest.cachemanager.exceptions
- CacheNotFoundException(String) - Constructor for exception org.infinispan.rest.cachemanager.exceptions.CacheNotFoundException
- CacheNotFoundResponse - Class in org.infinispan.remoting.responses
-
A response that signals the named cache is not running on the target node.
- CacheNotFoundResponse.Externalizer - Class in org.infinispan.remoting.responses
- cacheNotifier - Variable in class org.infinispan.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 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 org.infinispan.client.hotrod.exceptions.CacheNotTransactionalException
- CacheNotTransactionalException(String) - Constructor for exception org.infinispan.client.hotrod.exceptions.CacheNotTransactionalException
- CacheNotTransactionalException(String, long, int) - Constructor for exception org.infinispan.client.hotrod.exceptions.CacheNotTransactionalException
- CacheNotTransactionalException(String, Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.CacheNotTransactionalException
- CacheNotTransactionalException(Throwable) - Constructor for exception 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
-
ContainerResource
implementation forBackupManager.Resources.Type.CACHES
. - 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
- 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
andStateTransferManager
. - 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 in org.infinispan.rest.cachemanager.exceptions
- CacheUnavailableException(String) - Constructor for exception org.infinispan.rest.cachemanager.exceptions.CacheUnavailableException
- CacheUnreachableException - Exception in org.infinispan.remoting
-
Signals a backup site was unreachable.
- CacheUnreachableException(String) - Constructor for exception org.infinispan.remoting.CacheUnreachableException
- CacheUnreachableException(UnreachableException) - Constructor for exception org.infinispan.remoting.CacheUnreachableException
- 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.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.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
-
Same as
PendingLockManager.awaitPendingTransactionsForKey(TxInvocationContext, Object, long, TimeUnit)
but non-blocking. - 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
-
Same as
PendingLockManager.awaitPendingTransactionsForAllKeys(TxInvocationContext, Collection, long, TimeUnit)
but non-blocking. - 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 currentAccessControlContext
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 currentAccessControlContext
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
ofIracTombstoneInfo
and sendsIracTombstoneCleanupCommand
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 theTopologyAffectedCommand
. - 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 theClassLoader
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 theClassLoader
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
andServiceResolver
contracts that just delegates loading to an actualClassLoader
. - 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.
- 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 theClearCommand
. - 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.
- 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 theClearCommand
. - 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.ReadWriteMapImpl
- 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
andAutoCloseable
interfaces. - CloseableIterator<E> - Interface in org.infinispan.commons.util
-
Interface that provides semantics of a
Iterator
andAutoCloseable
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
-
Adapts
Collection
toCloseableIteratorCollection
- 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
-
Adapts
Set
toCloseableIteratorSet
- 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
andAutoCloseable
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
ClusteredGetCommand
s. - 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
- 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 in org.infinispan.lock.exception
-
Exception used to handle errors on clustered locks
- ClusteredLockException(String) - Constructor for exception org.infinispan.lock.exception.ClusteredLockException
- ClusteredLockException(Throwable) - Constructor for exception org.infinispan.lock.exception.ClusteredLockException
- ClusteredLockManager - Interface in org.infinispan.lock.api
-
Provides the API to define, create and remove ClusteredLocks.
- ClusteredLockManagerConfiguration - Class in org.infinispan.lock.configuration
-
The
ClusteredLockManager
configuration. - ClusteredLockManagerConfigurationBuilder - Class in org.infinispan.lock.configuration
-
The
ClusteredLockManager
configuration builder. - ClusteredLockManagerConfigurationBuilder(GlobalConfigurationBuilder) - Constructor for class org.infinispan.lock.configuration.ClusteredLockManagerConfigurationBuilder
- 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.AbstractModuleConfigurationBuilder
- 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 theSupplier
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 theSerializableSupplier
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 implementSerializable
- 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 implementSerializable
- 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 implementSerializable
- 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 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
Attribute
s andConfigurationElement
s are combined when overlaying a configuration (the overlay) on top of another (the template) usingBuilder.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 likeCompletionStage.thenCombine(CompletionStage, java.util.function.BiFunction)
to convert the values to aFlowable
. - 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.use
CommonNameRoleMapper
instead - 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
-
A compare-and-set operation for
StrongCounter.compareAndSwap(long, long)
andStrongCounter.compareAndSet(long, long)
. - 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 extends AbstractSegmentedStoreConfiguration> - Class in org.infinispan.persistence.support -
Segmented store that creates multiple inner stores for each segment.
- ComposedSegmentedLoadWriteStore(AbstractSegmentedStoreConfiguration<T>) - Constructor for class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- 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
#compute(K, BiFunction)
, which takes in an instance ofMetadata
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
-
Overloaded
Cache.compute(Object, BiFunction)
with InfinispanSerializableBiFunction
. - compute(K, SerializableBiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.Cache
-
Overloaded
BasicCache.compute(Object, BiFunction, long, TimeUnit)
with InfinispanSerializableBiFunction
. - compute(K, SerializableBiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
-
Overloaded
BasicCache.compute(Object, BiFunction, long, TimeUnit, long, TimeUnit)
with InfinispanSerializableBiFunction
. - 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
-
Asynchronous version of
ConcurrentMap.compute(Object, BiFunction)
. - 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
-
Asynchronous version of
BasicCache.compute(Object, BiFunction, long, TimeUnit)
. - 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
-
Asynchronous version of
BasicCache.compute(Object, BiFunction, long, TimeUnit, long, TimeUnit)
. - computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
-
Overloaded
#computeAsync(K, BiFunction)
, which stores metadata alongside the value. - computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
- computeAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.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
-
Overloaded
AsyncCache.computeAsync(Object, BiFunction)
with InfinispanSerializableBiFunction
. - computeAsync(K, SerializableBiFunction<? super K, ? super V, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.Cache
-
Overloaded
AsyncCache.computeAsync(Object, BiFunction, long, TimeUnit)
with InfinispanSerializableBiFunction
. - computeAsync(K, SerializableBiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
-
Overloaded
AsyncCache.computeAsync(Object, BiFunction, long, TimeUnit, long, TimeUnit)
with InfinispanSerializableBiFunction
. - 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
#computeIfAbsent(K, Function)
, which takes in an instance ofMetadata
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
-
Overloaded
Cache.computeIfAbsent(Object, Function)
with InfinispanSerializableFunction
. - computeIfAbsent(K, SerializableFunction<? super K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.Cache
-
Overloaded
BasicCache.computeIfAbsent(Object, Function, long, TimeUnit)
with InfinispanSerializableFunction
. - computeIfAbsent(K, SerializableFunction<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
-
Overloaded
BasicCache.computeIfAbsent(Object, Function, long, TimeUnit, long, TimeUnit)
with InfinispanSerializableFunction
. - 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
-
Asynchronous version of
ConcurrentMap.computeIfAbsent(Object, Function)
. - 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
-
Asynchronous version of
BasicCache.computeIfAbsent(Object, Function, long, TimeUnit)
. - 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
-
Asynchronous version of
BasicCache.computeIfAbsent(Object, Function, long, TimeUnit, long, TimeUnit)
. - computeIfAbsentAsync(K, Function<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- computeIfAbsentAsync(K, Function<? super K, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
-
Overloaded
#computeIfAbsentAsync(K, Function)
, which takes in an instance ofMetadata
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
-
Overloaded
AsyncCache.computeIfAbsentAsync(Object, Function)
with InfinispanSerializableFunction
. - computeIfAbsentAsync(K, SerializableFunction<? super K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.Cache
-
Overloaded
AsyncCache.computeIfAbsentAsync(Object, Function, long, TimeUnit)
with InfinispanSerializableFunction
. - computeIfAbsentAsync(K, SerializableFunction<? super K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
-
Overloaded
AsyncCache.computeIfAbsentAsync(Object, Function, long, TimeUnit, long, TimeUnit)
with InfinispanSerializableFunction
. - 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
#computeIfPresent(K, BiFunction)
, which takes in an instance ofMetadata
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 InfinispanSerializableBiFunction
The compiler will pick this overload for lambda parameters, making themSerializable
- 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
-
Asynchronous version of
ConcurrentMap.computeIfPresent(Object, BiFunction)
. - 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
-
Asynchronous version of
BasicCache.computeIfPresent(Object, BiFunction, long, TimeUnit)
. - 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
-
Asynchronous version of
BasicCache.computeIfPresent(Object, BiFunction, long, TimeUnit, long, TimeUnit)
. - computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- computeIfPresentAsync(K, BiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
-
Overloaded
#computeIfPresentAsync(K, BiFunction)
, which takes in an instance ofMetadata
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 InfinispanSerializableBiFunction
The compiler will pick this overload for lambda parameters, making themSerializable
- 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 toStatus.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 aCondition
. - 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 theRemoteCacheManager(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 extends ConfigurationElement> - 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 in org.infinispan.commons.configuration.io
- ConfigurationReaderException(String, Location) - Constructor for exception org.infinispan.commons.configuration.io.ConfigurationReaderException
- ConfigurationReaderException(Throwable, Location) - Constructor for exception 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
-
Returns the
LocalConfigurationStorage
Supplier
- configurationStorageSupplier(Supplier<? extends LocalConfigurationStorage>) - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
-
Defines the @
LocalConfigurationStorage
. - 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 in org.infinispan.commons.configuration.io
- ConfigurationWriterException(String) - Constructor for exception org.infinispan.commons.configuration.io.ConfigurationWriterException
- ConfigurationWriterException(Throwable) - Constructor for exception 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 topologytopologyId
. - 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 extends ConnectionFactoryConfiguration> - 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 extends ConsistentHash> - 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
- 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
- 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
- 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
ContainerResource
s 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. - 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
-
Utility methods to convert
CounterConfiguration
to and fromStrongCounterConfiguration
andWeakCounterConfiguration
- 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.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 extends AbstractCounterConfiguration,
S extends CounterConfigurationBuilder<T, S>> - Interface in org.infinispan.counter.configuration -
Base counter configuration builder.
- CounterConfigurationException - Exception in org.infinispan.counter.exception
-
Signals a missing configuration or an invalid configuration.
- CounterConfigurationException() - Constructor for exception org.infinispan.counter.exception.CounterConfigurationException
- CounterConfigurationException(String) - Constructor for exception org.infinispan.counter.exception.CounterConfigurationException
- CounterConfigurationException(String, Throwable) - Constructor for exception org.infinispan.counter.exception.CounterConfigurationException
- CounterConfigurationException(Throwable) - Constructor for exception org.infinispan.counter.exception.CounterConfigurationException
- CounterConfigurationMetaParam - Class in org.infinispan.functional.impl
-
Stores the
CounterConfiguration
. - 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 in org.infinispan.counter.exception
-
A
RuntimeException
related to counters. - CounterException() - Constructor for exception org.infinispan.counter.exception.CounterException
- CounterException(String) - Constructor for exception org.infinispan.counter.exception.CounterException
- CounterException(String, Throwable) - Constructor for exception org.infinispan.counter.exception.CounterException
- CounterException(String, Throwable, boolean, boolean) - Constructor for exception org.infinispan.counter.exception.CounterException
- CounterException(Throwable) - Constructor for exception 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 eachEmbeddedCacheManager
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 in org.infinispan.counter.exception
-
Signal that an attempt to access a counter has failed.
- CounterNotFoundException() - Constructor for exception org.infinispan.counter.exception.CounterNotFoundException
- CounterNotFoundException(String) - Constructor for exception org.infinispan.counter.exception.CounterNotFoundException
- CounterNotFoundException(String, Throwable) - Constructor for exception org.infinispan.counter.exception.CounterNotFoundException
- CounterNotFoundException(String, Throwable, boolean, boolean) - Constructor for exception org.infinispan.counter.exception.CounterNotFoundException
- CounterNotFoundException(Throwable) - Constructor for exception org.infinispan.counter.exception.CounterNotFoundException
- CounterOperationFactory - Class in org.infinispan.client.hotrod.counter.impl
-
A operation factory that builds counter operations.
- CounterOutOfBoundsException - Exception in org.infinispan.counter.exception
-
A
CounterException
signalling that theStrongCounter
has reached its bounds. - CounterOutOfBoundsException(String) - Constructor for exception 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
-
ContainerResource
implementation forBackupManager.Resources.Type.COUNTERS
. - 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 nullcreated
defaults to -1lastUsed
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
- create(Object, MarshalledValue) - Method in interface org.infinispan.persistence.spi.MarshallableEntryFactory
-
Creates a
MarshallableEntry
using a KeyMarshalledValue
. - 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 theCacheEntry
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 nullcreated
defaults to -1lastUsed
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 theCacheEntry
instance passed in. - create(InternalCacheEntry<K, V>) - Method in interface org.infinispan.persistence.spi.MarshallableEntryFactory
-
Creates a
MarshallableEntry
instance from anInternalCacheEntry
. - 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
-
Will create an
ClearInvocationContext
with theAbstractInvocationContext.isOriginLocal()
returning true. - 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
-
Will create an
NonTxInvocationContext
with theAbstractInvocationContext.isOriginLocal()
returning true. - 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
-
Returns an
NonTxInvocationContext
whoseAbstractInvocationContext.isOriginLocal()
flag will be true. - 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
-
Returns an
RemoteTxInvocationContext
. - 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
-
Will create an
NonTxInvocationContext
with theAbstractInvocationContext.isOriginLocal()
returning true. - 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 withNonBlockingStore
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
-
Returns a
LocalTxInvocationContext
. - 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 theInternalCacheEntry
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 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 org.infinispan.commons.CrossSiteIllegalLifecycleStateException
- CrossSiteIllegalLifecycleStateException(String) - Constructor for exception org.infinispan.commons.CrossSiteIllegalLifecycleStateException
- CrossSiteIllegalLifecycleStateException(String, Throwable) - Constructor for exception org.infinispan.commons.CrossSiteIllegalLifecycleStateException
- CrossSiteIllegalLifecycleStateException(Throwable) - Constructor for exception 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.Since 14.0, please use
ServerStatistics.APPROXIMATE_ENTRIES
- 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 thanSystem.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.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.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 in org.infinispan.util
-
Thrown when a cyclic dependency exist
- CyclicDependencyException(String) - Constructor for exception org.infinispan.util.CyclicDependencyException
- CyclicDependencyException(String, Throwable) - Constructor for exception org.infinispan.util.CyclicDependencyException
D
- data - Variable in class org.infinispan.io.GridFilesystem
-
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 in org.infinispan.util.concurrent.locks
-
Exception signaling detected deadlocks.
- DeadlockDetectedException(String) - Constructor for exception 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
Flag
s. - 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.ClusterContainerStatsImpl
- 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
- 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.Since 11.0, please use
DefaultCacheManager(ConfigurationBuilderHolder, boolean)
instead. - DefaultCacheManager(Configuration, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 11.0, please use
DefaultCacheManager(ConfigurationBuilderHolder, boolean)
instead. - 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.Since 11.0, please use
DefaultCacheManager(ConfigurationBuilderHolder, boolean)
instead. - 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.Since 11.0, please use
DefaultCacheManager(ConfigurationBuilderHolder, boolean)
instead. - 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.ScheduledExecutorFactoryConfigurationBuilder
- 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
andCounterConfiguration
. - DefineCounterOperation - Class in org.infinispan.client.hotrod.counter.operation
-
A counter define operation for
CounterManager.defineCounter(String, CounterConfiguration)
. - 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 aInvocationFinallyFunction
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 theFilterIndexingServiceProvider
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 implementsObjectInput
. - DelegatingObjectInput(ObjectInput) - Constructor for class org.infinispan.commons.marshall.DelegatingObjectInput
- DelegatingObjectOutput - Class in org.infinispan.commons.marshall
-
Class that extends
OutputStream
and implementsObjectOutput
. - 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.
- 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 thisFactoryBean
. - destroy() - Method in class org.infinispan.spring.embedded.provider.SpringEmbeddedCacheManagerFactoryBean
-
Shuts down the
SpringEmbeddedCacheManager
instance created by thisFactoryBean
. - destroy() - Method in class org.infinispan.spring.embedded.support.InfinispanEmbeddedCacheManagerFactoryBean
-
Shuts down the
EmbeddedCacheManager
instance created by thisFactoryBean
. - destroy() - Method in class org.infinispan.spring.embedded.support.InfinispanNamedEmbeddedCacheFactoryBean
-
Shuts down the
org.infinispan.Cache
created by thisFactoryBean
. - destroy() - Method in class org.infinispan.spring.remote.provider.SpringRemoteCacheManagerFactoryBean
-
thestop
RemoteCacheManager
created by this factory. - destroy() - Method in class org.infinispan.spring.remote.support.InfinispanRemoteCacheManagerFactoryBean
-
thestop
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 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.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 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 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 ThreadLocalSubject
instead of modifying the currentAccessControlContext
. - doAs(Subject, PrivilegedExceptionAction<T>) - Static method in class org.infinispan.security.Security
-
A "lightweight" implementation of
Subject.doAs(Subject, PrivilegedExceptionAction)
which uses a ThreadLocalSubject
instead of modifying the currentAccessControlContext
. - 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
- 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 in org.infinispan.manager
-
An exception to encapsulate an error when starting up a cache manager
- EmbeddedCacheManagerStartupException() - Constructor for exception org.infinispan.manager.EmbeddedCacheManagerStartupException
- EmbeddedCacheManagerStartupException(String) - Constructor for exception org.infinispan.manager.EmbeddedCacheManagerStartupException
- EmbeddedCacheManagerStartupException(String, Throwable) - Constructor for exception org.infinispan.manager.EmbeddedCacheManagerStartupException
- EmbeddedCacheManagerStartupException(Throwable) - Constructor for exception org.infinispan.manager.EmbeddedCacheManagerStartupException
- 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 usesCacheContainerAdmin
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 byEmbeddedBaseTransactionManager
. - 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 usesEmbeddedTransactionManager
. - 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.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.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()
orSitesConfiguration.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()
orSitesConfiguration.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.ReadWriteMapImpl
- encodeKeys(Set<? extends K>) - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
- 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 - EncoderCache(AdvancedCache<K, V>, InternalEntryFactory, BasicComponentRegistry, DataConversion, DataConversion) - Constructor for class org.infinispan.cache.impl.EncoderCache
- EncoderEntryMapper<K,
V, T extends Map.Entry<K, V>> - Class in org.infinispan.cache.impl -
Function
that uses an encoder to converter entries from the configured storage format to the requested format. - EncoderEntryMapper.Externalizer - Class in org.infinispan.cache.impl
- 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
- 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 theCounterType
. - 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.AbstractModuleConfigurationBuilder
- 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 in org.infinispan.commons.dataconversion
- EncodingException(String) - Constructor for exception org.infinispan.commons.dataconversion.EncodingException
- EncodingException(String, Throwable) - Constructor for exception 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 theInvocationContext
. - 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 theDataContainer
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 allowsEntryMergePolicy
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 ofMap.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 ofMap.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.Alias for
FilterConditionEndContext.eq(Object)
- 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 ", <, >, 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 aEntryView.WriteEntryView
of the value associated with the key, and return aCompletableFuture
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 implementSerializable
- 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 implementSerializable
- 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 implementSerializable
- 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 aEntryView.WriteEntryView
of the value associated with the key, and return aCompletableFuture
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 aCompletableFuture
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 implementSerializable
- 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 implementSerializable
- evalAll(Consumer<EntryView.WriteEntryView<K, V>>) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
-
Evaluate a write-only
Consumer
operation with theEntryView.WriteEntryView
of the value associated with the key, for all existing keys in functional map, and returns aCompletableFuture
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 theEntryView.ReadWriteEntryView
of the value associated with the key, for all existing keys, and returns aTraversable
to navigate each of theFunction
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 implementSerializable
- 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 implementSerializable
- 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 aEntryView.WriteEntryView
of the value associated with the key, for each of the keys in the set passed in, and returns aCompletableFuture
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 aEntryView.ReadWriteEntryView
of the value associated with the key, for each of the keys in the set passed in, and returns anTraversable
to navigate each of theBiFunction
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 implementSerializable
- 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 implementSerializable
- evalMany(Set<? extends K>, Consumer<EntryView.WriteEntryView<K, V>>) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
-
Evaluate a write-only
Consumer
operation with theEntryView.WriteEntryView
of the value associated with the key, for each of the keys in the set passed in, and returns aCompletableFuture
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 theEntryView.ReadWriteEntryView
of the value associated with the key, for each of the keys in the set passed in, and returns aTraversable
to navigate each of theFunction
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 implementSerializable
- 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 implementSerializable
- 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 implementSerializable
- 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 extends Event<K, V>> - 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 - 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.Since 11.0, use
MemoryConfiguration.whenFull()
- 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.Since 11.0, use
MemoryConfigurationBuilder.whenFull(EvictionStrategy)
instead. - 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()
orMemoryConfiguration.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.since 11.0, @see
MemoryConfigurationBuilder.evictionType(EvictionType)
- 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)
orMemoryConfigurationBuilder.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()
andMemoryConfiguration.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
- 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
-
A sync
InvocationStage
forThrowable
. - 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 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
- 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.AbstractModuleConfigurationBuilder
- 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)
orNonBlockingStore.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.ScheduledExecutorFactoryConfigurationBuilder
- 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 in org.infinispan.extendedstats
- ExtendedStatisticNotFoundException(String) - Constructor for exception 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 customMarshaller
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
- 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
- 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 implementingCustomFailurePolicy
- 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 implementingCustomFailurePolicy
- 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 ...
- 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.GetCounterNamesOperation
- 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 anInputStream
- 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
- fillBuf() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- fillInStackTrace() - Method in exception 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 implementSerializable
- 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 implementSerializable
- 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 implementSerializable
- filter(SerializablePredicate<? super R>) - Method in interface org.infinispan.CacheStream
-
Same as
CacheStream.filter(Predicate)
except that the Predicate must also implementSerializable
- 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
- 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
- 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)
returnsnull
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 implementSerializable
- 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 implementSerializable
- flatMap(SerializableIntFunction<? extends IntStream>) - Method in interface org.infinispan.IntCacheStream
-
Same as
IntCacheStream.flatMap(IntFunction)
except that the IntFunction must also implementSerializable
- 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 implementSerializable
- 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 implementSerializable
- 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 implementSerializable
- 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.ReadWriteMapImpl
- 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 aBiConsumer
that provides access to the underlyingCache
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 anObjDoubleConsumer
that provides access to the underlyingCache
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 anObjIntConsumer
that provides access to the underlyingCache
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 anObjLongConsumer
that provides access to the underlyingCache
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 implementSerializable
- forEach(SerializableBiConsumer<Cache<K, V>, ? super R>) - Method in interface org.infinispan.CacheStream
- forEach(SerializableConsumer<? super R>) - Method in interface org.infinispan.CacheStream
-
Same as
CacheStream.forEach(Consumer)
except that the Consumer must also implementSerializable
- forEach(SerializableDoubleConsumer) - Method in interface org.infinispan.DoubleCacheStream
-
Same as
DoubleStream.forEach(DoubleConsumer)
except that the DoubleConsumer must also implementSerializable
- 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 implementSerializable
- 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 theBiConsumer
must also implementSerializable
- 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 theBiConsumer
must also implementSerializable
- 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 theBiConsumer
must also implementSerializable
- 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 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
- 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 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 as
XAResource
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>, TimeUnit) - 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 givensegment
. - 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 givensegment
. - 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 thanversionSeen
. - 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 aTransactionManager
. - 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 itsPersistentUUID
- 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 asMap
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.AbstractModuleConfigurationBuilder
- 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 bymetadata
. - 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 thenRemoteCacheContainer.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 thenRemoteCacheContainer.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 thenRemoteCacheContainer.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 thenRemoteCacheContainer.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 thenRemoteCacheContainer.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 thenRemoteCacheContainer.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 thenRemoteCacheContainer.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 thenRemoteCacheContainer.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
#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.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.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
- 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 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 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
-
Exposes
CommandsFactory
toXSiteStatePushTask
. - 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 throwsClusteredLockException
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 sitesiteName
. - 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.Since 14.0, please use
Stats.getApproximateEntries()
orStats.getApproximateEntriesUnique()
instead. - 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.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 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.since 9.3 please use
LocalizedCacheTopology.getSegmentDistribution(int)
instead. - 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.
- 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 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.since 11.0 - Please use
InitializationContext.getBlockingManager()
()} orInitializationContext.getNonBlockingExecutor()
instead - 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
toXSiteStatePushTask
. - 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.ScheduledExecutorFactoryConfigurationBuilder
- 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.
- 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 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.ReadWriteMapImpl
- 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
-
Exposes
IracManager
toXSiteStatePushTask
. - 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 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 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 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(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.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.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.ReadWriteMapImpl
- 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
that backs thisorg.infinispan.manager.EmbeddedCacheManager
CacheManager
. - getNativeCacheManager() - Method in class org.infinispan.spring.remote.provider.SpringRemoteCacheManager
-
Return the
that backs thisorg.infinispan.client.hotrod.RemoteCacheManager
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.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 itsAddress
- 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()
ornull
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 thekey
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
- 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 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
-
Exposes
RpcManager
toXSiteStatePushTask
. - 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
SaslClientFactory
s 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
SaslServerFactory
s 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
-
Exposes timeout
ScheduledExecutorService
toXSiteStatePushTask
. - 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.use
AbstractSchemaJdbcConfiguration.schema()
instead. - 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 theProtoStreamMarshaller
configured on the providedRemoteCacheManager
. - 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 org.infinispan.client.hotrod.exceptions.RemoteIllegalLifecycleStateException
- getServerAddress() - Method in exception 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 leastnumOwners
owners for each segment is installed, and the cache isAvailabilityMode.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.ClusterContainerStats
- 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.ClusterContainerStatsImpl
- 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.ClusterContainerStatsImpl
- 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.ReadWriteMapImpl
- 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 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)
orSecurity.doAs(Subject, PrivilegedExceptionAction)
, returns theSubject
associated with the current thread otherwise it returns theSubject
associated with the currentAccessControlContext
- 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 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.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 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.FunctionTimerMetricInfo
- 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
ornull
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.Since 10.0, please use
EmbeddedCacheManager.getAddress()
,EmbeddedCacheManager.getMembers()
,EmbeddedCacheManager.getCoordinator()
- 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 extends Cache<K,
V>, 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 providedInvocationContext
if anInternalCacheEntry
exists, otherwise createInternalCacheEntry
from the context'sCacheEntry
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
-
Module initialization happens in
ModuleLifecycle.cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration)
. - 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.
- globalJmxStatistics() - Method in class org.infinispan.configuration.global.GlobalConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 10.1.3. Use
GlobalConfiguration.jmx()
instead. This will be removed in next major version. - globalJmxStatistics() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 10.1.3. Use
GlobalConfigurationChildBuilder.jmx()
instead. This will be removed in next major version. - GlobalJmxStatisticsConfiguration - Class in org.infinispan.configuration.global
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.1.3 Use
GlobalJmxConfiguration
instead. This will be removed in next major version. - GlobalJmxStatisticsConfiguration() - Constructor for class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
-
Deprecated.
- GlobalJmxStatisticsConfigurationBuilder - Class in org.infinispan.configuration.global
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.1.3. Use
GlobalJmxConfigurationBuilder
instead. This will be removed in next major version. - GlobalMarshaller - Class in org.infinispan.marshall.core
-
A globally-scoped marshaller.
- GlobalMarshaller() - Constructor for class org.infinispan.marshall.core.GlobalMarshaller
- GlobalMarshallerEncoder - Class in org.infinispan.commons.dataconversion
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 11.0, will be removed with ISPN-9622
- GlobalMarshallerEncoder(Marshaller) - Constructor for class org.infinispan.commons.dataconversion.GlobalMarshallerEncoder
-
Deprecated.
- GlobalMetricsConfiguration - Class in org.infinispan.configuration.global
-
Configuration for metrics.
- GlobalMetricsConfigurationBuilder - Class in org.infinispan.configuration.global
-
Configures the types of metrics gathered and exported via Micrometer metrics for all caches owned by this Cache Manager.
- GlobalRoleConfigurationBuilder - Class in org.infinispan.configuration.global
-
GlobalRoleConfigurationBuilder.
- GlobalRoleConfigurationBuilder(String, GlobalAuthorizationConfigurationBuilder) - Constructor for class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
- GlobalRolesConfigurationChildBuilder - Interface in org.infinispan.configuration.global
- GlobalRpcCommand - Interface in org.infinispan.commands
-
Commands correspond to specific areas of functionality in the cluster, and can be replicated using the
GlobalInboundInvocationHandler
. - GlobalSecurityConfiguration - Class in org.infinispan.configuration.global
-
GlobalSecurityConfiguration.
- GlobalSecurityConfiguration(GlobalAuthorizationConfiguration, AttributeSet) - Constructor for class org.infinispan.configuration.global.GlobalSecurityConfiguration
- GlobalSecurityConfigurationBuilder - Class in org.infinispan.configuration.global
-
GlobalSecurityConfigurationBuilder.
- GlobalSecurityConfigurationBuilder(GlobalConfigurationBuilder) - Constructor for class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
- GlobalSecurityConfigurationChildBuilder - Interface in org.infinispan.configuration.global
-
GlobalSecurityConfigurationChildBuilder.
- GlobalSecurityManager - Interface in org.infinispan.security
-
GlobalSecurityManager.
- GlobalSecurityManagerFactory - Class in org.infinispan.security.impl
-
Factory for GlobalSecurityManager implementations
- GlobalSecurityManagerFactory() - Constructor for class org.infinispan.security.impl.GlobalSecurityManagerFactory
- GlobalSecurityManagerImpl - Class in org.infinispan.security.impl
-
GlobalSecurityManagerImpl.
- GlobalSecurityManagerImpl() - Constructor for class org.infinispan.security.impl.GlobalSecurityManagerImpl
- globalState() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
- globalState() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
- globalState() - Method in class org.infinispan.configuration.global.GlobalConfiguration
- globalState() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- globalState() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Global state configuration
- GlobalStateConfiguration - Class in org.infinispan.configuration.global
-
GlobalStateConfiguration.
- GlobalStateConfiguration(AttributeSet, GlobalStatePathConfiguration, GlobalStatePathConfiguration, TemporaryGlobalStatePathConfiguration, GlobalStorageConfiguration) - Constructor for class org.infinispan.configuration.global.GlobalStateConfiguration
- GlobalStateConfigurationBuilder - Class in org.infinispan.configuration.global
-
GlobalStateConfigurationBuilder.
- GlobalStateManager - Interface in org.infinispan.globalstate
-
GlobalStateManager.
- GlobalStateManagerImpl - Class in org.infinispan.globalstate.impl
-
GlobalStateManagerImpl.
- GlobalStateManagerImpl() - Constructor for class org.infinispan.globalstate.impl.GlobalStateManagerImpl
- GlobalStatePathConfiguration - Class in org.infinispan.configuration.global
- GlobalStatePathConfiguration(AttributeSet, String) - Constructor for class org.infinispan.configuration.global.GlobalStatePathConfiguration
- GlobalStatePathConfigurationBuilder - Class in org.infinispan.configuration.global
- GlobalStateProvider - Interface in org.infinispan.globalstate
-
GlobalStateProvider.
- globalStorageConfiguration() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
- GlobalStorageConfiguration - Class in org.infinispan.configuration.global
- GlobalStorageConfigurationBuilder - Class in org.infinispan.configuration.global
- GlobalTransaction - Class in org.infinispan.transaction.xa
-
Uniquely identifies a transaction that spans all JVMs in a cluster.
- GlobalTransaction(Address, boolean) - Constructor for class org.infinispan.transaction.xa.GlobalTransaction
- GlobalTransaction.Externalizer - Class in org.infinispan.transaction.xa
- GlobalTxTable - Class in org.infinispan.server.hotrod.tx.table
-
It is a transaction log that registers all the transaction decisions before changing the cache.
- GlobalTxTable(Cache<CacheXid, TxState>, GlobalComponentRegistry) - Constructor for class org.infinispan.server.hotrod.tx.table.GlobalTxTable
- globToRegex(String) - Static method in class org.infinispan.commons.util.GlobUtils
- GlobUtils - Class in org.infinispan.commons.util
-
Utility functions for globs
- GlobUtils() - Constructor for class org.infinispan.commons.util.GlobUtils
- GOOGLE(Properties) - Static method in class org.infinispan.remoting.transport.jgroups.BuiltinJGroupsChannelConfigurator
- grant(String, String) - Method in class org.infinispan.security.mappers.ClusterRoleMapper
- grant(String, String) - Method in interface org.infinispan.security.MutablePrincipalRoleMapper
- greaterThanZero(Enum<?>) - Static method in interface org.infinispan.commons.configuration.attributes.AttributeValidator
- GridFile - Class in org.infinispan.io
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.0
- GridFile.Metadata - Class in org.infinispan.io
-
Deprecated.
- GridFilesystem - Class in org.infinispan.io
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.0
- GridFilesystem(Cache<String, byte[]>, Cache<String, GridFile.Metadata>) - Constructor for class org.infinispan.io.GridFilesystem
-
Deprecated.
- GridFilesystem(Cache<String, byte[]>, Cache<String, GridFile.Metadata>, int) - Constructor for class org.infinispan.io.GridFilesystem
-
Deprecated.Creates an instance.
- GridInputStream - Class in org.infinispan.io
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.0
- GridOutputStream - Class in org.infinispan.io
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.0
- Group - Annotation Type in org.infinispan.distribution.group
-
Identifies the key for a group.
- GROUP_NAME - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- groupAggregationsNotSupported() - Method in interface org.infinispan.query.logging.Log
- groupBy(String...) - Method in interface org.infinispan.query.dsl.QueryBuilder
-
Deprecated.
- Grouper<T> - Interface in org.infinispan.distribution.group
-
User applications may implement this interface in order to customize the compution of groups in cases when the modifying the key is not possible, or when the value determined by the
Group
annotation needs customizing. - GROUPER - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- GROUPER - Enum constant in enum org.infinispan.configuration.parsing.Element
- groupers() - Method in class org.infinispan.configuration.cache.GroupsConfiguration
-
Get the current groupers in use
- GROUPERS - Static variable in class org.infinispan.configuration.cache.GroupsConfiguration
- GroupFilter<K> - Class in org.infinispan.distribution.group.impl
-
A key filter that accepts keys which belongs to the group.
- GroupFilter(Object, GroupManager) - Constructor for class org.infinispan.distribution.group.impl.GroupFilter
- GroupingPartitioner - Class in org.infinispan.distribution.group.impl
-
Key partitioner that uses
Group
annotations to map grouped keys to the same segment. - GroupingPartitioner(KeyPartitioner, GroupManager) - Constructor for class org.infinispan.distribution.group.impl.GroupingPartitioner
- GroupManager - Interface in org.infinispan.distribution.group.impl
-
Control's key grouping.
- GroupManagerFactory - Class in org.infinispan.distribution.group.impl
- GroupManagerFactory() - Constructor for class org.infinispan.distribution.group.impl.GroupManagerFactory
- GroupManagerImpl - Class in org.infinispan.distribution.group.impl
- GroupManagerImpl(Configuration) - Constructor for class org.infinispan.distribution.group.impl.GroupManagerImpl
- groupName() - Method in class org.infinispan.configuration.global.ThreadFactoryConfigurationBuilder
- groupName(String) - Method in class org.infinispan.configuration.global.ThreadFactoryConfigurationBuilder
- groups() - Method in class org.infinispan.configuration.cache.HashConfiguration
-
Configuration for various grouper definitions.
- groups() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
- GROUPS - Enum constant in enum org.infinispan.configuration.parsing.Element
- GroupsConfiguration - Class in org.infinispan.configuration.cache
-
Configuration for various grouper definitions.
- GroupsConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Configuration for various grouper definitions.
- GroupsConfigurationBuilder(ClusteringConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.GroupsConfigurationBuilder
- gt(Object) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
-
Deprecated.Checks that the left argument is greater than the given value.
- gtConnectionPoolMinIdle() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- gte(Object) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
-
Deprecated.Checks that the left argument is greater than or equal to the given value.
- guessDialect(String) - Static method in enum org.infinispan.persistence.jdbc.common.DatabaseType
H
- H2 - Enum constant in enum org.infinispan.persistence.jdbc.common.DatabaseType
- handle(Callback[]) - Method in class org.infinispan.client.hotrod.security.BasicCallbackHandler
- handle(Callback[]) - Method in class org.infinispan.client.hotrod.security.TokenCallbackHandler
- handle(Callback[]) - Method in class org.infinispan.client.hotrod.security.VoidCallbackHandler
- Handle<T extends CounterListener> - Interface in org.infinispan.counter.api
-
As a return of
StrongCounter.addListener(CounterListener)
, it is used to un-register theCounterListener
. - handleAndCompose(CompletionStage<T>, BiFunction<T, Throwable, CompletionStage<U>>) - Static method in class org.infinispan.util.concurrent.CompletionStages
-
Extend
CompletionStage.thenCompose(Function)
to also handle exceptions. - handleAndComposeAsync(CompletionStage<T>, BiFunction<T, Throwable, CompletionStage<U>>, Executor) - Static method in class org.infinispan.util.concurrent.CompletionStages
- handleAny(ConfigurationReaderContext) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationReader
- handleAny(ConfigurationReaderContext) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
- handleAnyAttribute(ConfigurationReader, int) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReaderContext
- handleAnyAttribute(ConfigurationReader, int) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
- handleAnyElement(ConfigurationReader) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReaderContext
- handleAnyElement(ConfigurationReader) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
- handleAttribute(ConfigurationReaderContext, int) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationReader
- handleAttribute(ConfigurationReaderContext, int) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
- handleBlocking(CompletionStage<? extends I>, BiFunction<? super I, Throwable, ? extends O>, Object) - Method in interface org.infinispan.util.concurrent.BlockingManager
-
Replacement for
CompletionStage.handleAsync()
that invokes theBiFunction
in a blocking thread (if the current thread is non-blocking) or in the current thread (if the current thread is blocking and the stage is completed). - handleBlocking(CompletionStage<? extends I>, BiFunction<? super I, Throwable, ? extends O>, Object) - Method in class org.infinispan.util.concurrent.BlockingManagerImpl
- handleCacheShutdown(String) - Method in interface org.infinispan.topology.LocalTopologyManager
-
Handles the local operations related to gracefully shutting down a cache
- handleCacheShutdown(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- handleCacheStopped(CacheStoppedEvent) - Method in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
- handleCacheStopped(CacheStoppedEvent) - Method in class org.infinispan.affinity.ListenerRegistration
- handleClearFailure(String) - Method in interface org.infinispan.configuration.cache.CustomFailurePolicy
- handleClusterEvents(CacheEntryEvent) - Method in class org.infinispan.notifications.cachelistener.cluster.RemoteClusterListener
- handleCommitFailure(String, Transaction) - Method in interface org.infinispan.configuration.cache.CustomFailurePolicy
- handleCommonAttributes(ConfigurationReader, AbstractJdbcStoreConfigurationBuilder<?, ?>, Attribute, String) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationParser
- handleCommonElement(AbstractJdbcStoreConfigurationBuilder<?, ?>, Element, ConfigurationReader) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationParser
- handleCompose(Supplier<CompletionStage<T>>) - Method in interface org.infinispan.scattered.BiasManager.Revocation
-
Similar to
CompletableFuture.thenCompose(Function)
, returns future provided by the supplier after the current revocation has been finished - handleComputeFailure(String, K, BiFunction<? super K, ? super V, ? extends V>, boolean) - Method in interface org.infinispan.configuration.cache.CustomFailurePolicy
- handleComputeIfAbsentFailure(String, K, Function<? super K, ? extends V>) - Method in interface org.infinispan.configuration.cache.CustomFailurePolicy
- handleCreate(CacheEntryCreatedEvent<ScopedState, CacheState>) - Method in class org.infinispan.globalstate.impl.GlobalConfigurationStateListener
- handleDefault(InvocationContext, VisitableCommand) - Method in class org.infinispan.commands.AbstractVisitor
-
A default handler for all commands visited.
- handleDefault(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- handleEvent(EventWrapper<K, V, E>, ListenerInvocation<Event<K, V>>) - Method in interface org.infinispan.notifications.cachelistener.QueueingSegmentListener
-
This should be called by any listener when an event is generated to possibly queue it.
- handleEviction(InternalCacheEntry<K, V>, DataOperationOrderer, PassivationManager, EvictionManager<K, V>, DataContainer<K, V>, Executor, CompletionStage<Void>) - Static method in class org.infinispan.container.impl.AbstractInternalDataContainer
-
Performs the eviction logic, except it doesn't actually remove the entry from the data container.
- handleException(Throwable) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
- handleException(Throwable) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
- handleException(Throwable, Channel, SocketAddress) - Method in class org.infinispan.client.hotrod.counter.operation.RemoveListenerOperation
- handleInitialResponse(InitialResponse, Target) - Method in class org.infinispan.commons.reactive.AbstractAsyncPublisherHandler
- handleInjection(ComponentRegistry) - Method in interface org.infinispan.stream.impl.TerminalOperation
-
Handles injection of components for various intermediate and this operation.
- handleInStoreExpirationInternal(K) - Method in class org.infinispan.expiration.impl.ClusterExpirationManager
- handleInStoreExpirationInternal(K) - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
- handleInStoreExpirationInternal(K) - Method in interface org.infinispan.expiration.impl.InternalExpirationManager
-
This is to be invoked when a store entry expires.
- handleInStoreExpirationInternal(MarshallableEntry<K, V>) - Method in class org.infinispan.expiration.impl.ClusterExpirationManager
- handleInStoreExpirationInternal(MarshallableEntry<K, V>) - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
- handleInStoreExpirationInternal(MarshallableEntry<K, V>) - Method in interface org.infinispan.expiration.impl.InternalExpirationManager
-
This is to be invoked when a store entry expires and the value and/or metadata is available to be used.
- handleJoin(String, Address, CacheJoinInfo, int) - Method in interface org.infinispan.topology.ClusterTopologyManager
-
Signals that a new member is joining the cache.
- handleJoin(String, Address, CacheJoinInfo, int) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- handleLeave(String, Address, int) - Method in interface org.infinispan.topology.ClusterTopologyManager
-
Signals that a member is leaving the cache.
- handleLeave(String, Address, int) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- handleLostSegments(CompletionStage<R>, LocalPublisherManagerImpl.SegmentListener) - Method in class org.infinispan.reactive.publisher.impl.LocalPublisherManagerImpl
- handleMarshallingException(Throwable, Object) - Method in class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller.DebuggingExceptionListener
- handleNextResponse(NextResponse, Target) - Method in class org.infinispan.commons.reactive.AbstractAsyncPublisherHandler
- handleObject(Object) - Method in class org.infinispan.container.entries.PrimitiveEntrySizeCalculator
- handlePossibleExpiration(InternalCacheEntry<K, V>, int, boolean) - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
- handlePossibleExpiration(InternalCacheEntry<K, V>, int, boolean) - Method in interface org.infinispan.expiration.impl.InternalExpirationManager
-
Handles processing for an entry that may be expired.
- handlePrepareFailure(String, Transaction) - Method in interface org.infinispan.configuration.cache.CustomFailurePolicy
- handlePutAllFailure(String, Map<K, V>) - Method in interface org.infinispan.configuration.cache.CustomFailurePolicy
- handlePutFailure(String, K, V, boolean) - Method in interface org.infinispan.configuration.cache.CustomFailurePolicy
- handler() - Method in class org.infinispan.rest.framework.impl.InvocationImpl
- handler() - Method in interface org.infinispan.rest.framework.Invocation
-
Return the function to execute the invocation.
- handlerAdded(ChannelHandlerContext) - Method in class org.infinispan.server.hotrod.HotRodDecoder
- handleReadWriteKeyFailure(String, K) - Method in interface org.infinispan.configuration.cache.CustomFailurePolicy
- handleReadWriteKeyValueFailure(String, K) - Method in interface org.infinispan.configuration.cache.CustomFailurePolicy
- handleReadWriteManyEntriesFailure(String, Map<? extends K, ? extends V>) - Method in interface org.infinispan.configuration.cache.CustomFailurePolicy
- handleReadWriteManyFailure(String, Collection<? extends K>) - Method in interface org.infinispan.configuration.cache.CustomFailurePolicy
- handleRebalance(String, CacheTopology, int, Address) - Method in interface org.infinispan.topology.LocalTopologyManager
-
Performs the state transfer.
- handleRebalance(String, CacheTopology, int, Address) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- handleRebalancePhaseConfirm(String, Address, int, Throwable, int) - Method in interface org.infinispan.topology.ClusterTopologyManager
-
Marks the rebalance as complete on the sender.
- handleRebalancePhaseConfirm(String, Address, int, Throwable, int) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- handleRemove(CacheEntryRemovedEvent<ScopedState, CacheState>) - Method in class org.infinispan.globalstate.impl.GlobalConfigurationStateListener
- handleRemoveFailure(String, K, V) - Method in interface org.infinispan.configuration.cache.CustomFailurePolicy
- handleReplaceFailure(String, K, V, V) - Method in interface org.infinispan.configuration.cache.CustomFailurePolicy
- handleRollbackFailure(String, Transaction) - Method in interface org.infinispan.configuration.cache.CustomFailurePolicy
- handlerRemoved0(ChannelHandlerContext) - Method in class org.infinispan.server.core.transport.SaslQopHandler
- handles(String) - Method in class org.infinispan.server.core.admin.AdminOperationsHandler
- handleSegments(boolean, IntSet, IntSet) - Method in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
- handleShutdownRequest(String) - Method in interface org.infinispan.topology.ClusterTopologyManager
- handleShutdownRequest(String) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- handleSingleWrite(InvocationContext, DataWriteCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
- handleStableTopologyUpdate(String, CacheTopology, Address, int) - Method in interface org.infinispan.topology.LocalTopologyManager
-
Update the stable cache topology.
- handleStableTopologyUpdate(String, CacheTopology, Address, int) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- handleStatusRequest(int) - Method in interface org.infinispan.topology.LocalTopologyManager
-
Recovers the current topology information for all running caches and returns it to the coordinator.
- handleStatusRequest(int) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- handleStream(BaseCacheStream) - Method in enum org.infinispan.stream.impl.IntermediateType
- handleThrowableInResponse(Throwable, Target) - Method in class org.infinispan.commons.reactive.AbstractAsyncPublisherHandler
-
Allows any implementor to handle what happens when a Throwable is encountered.
- handleTopologyUpdate(String, CacheTopology, AvailabilityMode, int, Address) - Method in interface org.infinispan.topology.LocalTopologyManager
-
Updates the current and/or pending consistent hash, without transferring any state.
- handleTopologyUpdate(String, CacheTopology, AvailabilityMode, int, Address) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- handleUnmarshallingException(Throwable) - Method in class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller.DebuggingExceptionListener
- handleUnmarshallingException(Throwable, Class<?>) - Method in class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller.DebuggingExceptionListener
- handleUpdate(CacheEntryModifiedEvent<ScopedState, CacheState>) - Method in class org.infinispan.globalstate.impl.GlobalConfigurationStateListener
- handleViewChange(TopologyChangedEvent<?, ?>) - Method in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
- handleViewChange(TopologyChangedEvent<?, ?>) - Method in class org.infinispan.affinity.ListenerRegistration
- handleViewChange(ViewChangedEvent) - Method in class org.infinispan.topology.EventLoggerViewListener
- handleWith(Function<RestRequest, CompletionStage<RestResponse>>) - Method in class org.infinispan.rest.framework.impl.InvocationImpl.Builder
- handleWriteOnlyKeyFailure(String, K) - Method in interface org.infinispan.configuration.cache.CustomFailurePolicy
- handleWriteOnlyKeyValueFailure(String, K) - Method in interface org.infinispan.configuration.cache.CustomFailurePolicy
- handleWriteOnlyManyEntriesFailure(String, Map<? extends K, ? extends V>) - Method in interface org.infinispan.configuration.cache.CustomFailurePolicy
- handleWriteOnlyManyFailure(String, Collection<? extends K>) - Method in interface org.infinispan.configuration.cache.CustomFailurePolicy
- has(String) - Method in class org.infinispan.commons.dataconversion.internal.Json
-
Return true if this
Json
object has the specified property and false otherwise. - hasAllFlags(long) - Method in interface org.infinispan.commands.FlagAffectedCommand
-
Check whether all of the flags in the
flagsBitSet
parameter are present in the command. - hasAnyFlag(long) - Method in interface org.infinispan.commands.FlagAffectedCommand
-
Check whether any of the flags in the
flagsBitSet
parameter is present in the command. - hasAsyncEnabledBackups() - Method in class org.infinispan.configuration.cache.SitesConfiguration
- hasBackups() - Method in class org.infinispan.configuration.cache.SitesConfiguration
- hasCharacteristics(int) - Method in class org.infinispan.commons.util.SpliteratorMapper
- hasComponentAccessor(String) - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
-
Check if a component accessor has been registered for class
componentClassName
- hasComponentAccessor(String) - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
- hasDefaultCache() - Method in class org.infinispan.server.hotrod.HotRodServer
- hasDependent(T) - Method in class org.infinispan.util.DependencyGraph
-
Check if an element is depended on
- hasEnabledBackups() - Method in class org.infinispan.configuration.cache.SitesConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.since 14.0. To be removed without replacement. Use
SitesConfiguration.hasBackups()
instead. - hasEnum(long, Enum<?>) - Static method in class org.infinispan.commons.util.EnumUtil
- hasExpirable() - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- hasExpirable() - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
- hasExpirable() - Method in interface org.infinispan.container.impl.InternalDataContainer
-
Verify if the container has entries that can expire.
- hasFeature(ConfigurationFormatFeature) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
- hasFeature(ConfigurationFormatFeature) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- hasFeature(ConfigurationFormatFeature) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationReader
- hasFeature(ConfigurationFormatFeature) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- hasFeature(ConfigurationFormatFeature) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationReader
- hasFeature(ConfigurationFormatFeature) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- hasFeature(ConfigurationFormatFeature) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader
- hasFeature(ConfigurationFormatFeature) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- hasFiles() - Method in class org.infinispan.persistence.sifs.FileProvider
- hasFlag(byte) - Method in enum org.infinispan.server.hotrod.tx.ControlByte
- hasFlag(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.hasAnyFlag(long)
with aFlagBitSets
constant instead. - hasFlag(ProtocolFlag) - Method in class org.infinispan.server.hotrod.HotRodHeader
- hasForceReturnFlag() - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- hasForceReturnFlag() - Method in interface org.infinispan.client.hotrod.impl.InternalRemoteCache
- hasForceReturnFlag() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- hash() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
- hash() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
-
Configure hash sub element
- hash() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
-
Configure hash sub element
- hash() - Method in interface org.infinispan.configuration.cache.ClusteringConfigurationChildBuilder
-
Allows fine-tuning of rehashing characteristics.
- hash(byte[]) - Method in interface org.infinispan.commons.hash.Hash
-
Hashes a byte array efficiently.
- hash(byte[]) - Method in class org.infinispan.commons.hash.MurmurHash3
- hash(int) - Method in interface org.infinispan.commons.hash.Hash
-
An incremental version of the hash function, that spreads a pre-calculated hash code, such as one derived from
Object.hashCode()
. - hash(int) - Method in class org.infinispan.commons.hash.MurmurHash3
- hash(long[]) - Static method in class org.infinispan.commons.hash.MurmurHash3
-
Hashes a byte array efficiently.
- hash(Object) - Method in interface org.infinispan.commons.hash.Hash
-
A helper that calculates the hashcode of an object, choosing the optimal mechanism of hash calculation after considering the type of the object (byte array, String or Object).
- hash(Object) - Method in class org.infinispan.commons.hash.MurmurHash3
- hash(Object) - Static method in class org.infinispan.commons.util.AbstractMap
- Hash - Interface in org.infinispan.commons.hash
-
Interface that governs implementations
- HASH - Enum constant in enum org.infinispan.configuration.parsing.Element
- HASH_DISTRIBUTION_AWARE - Enum constant in enum org.infinispan.client.hotrod.configuration.ClientIntelligence
- HASH_FUNCTION_PREFIX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- hashCode() - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
- hashCode() - Method in class org.infinispan.client.hotrod.impl.ClientTopology
- hashCode() - Method in class org.infinispan.commands.CommandInvocationId
- hashCode() - Method in class org.infinispan.commons.configuration.AbstractTypedPropertiesConfiguration
- hashCode() - Method in class org.infinispan.commons.configuration.attributes.Attribute
- hashCode() - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
- hashCode() - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
- hashCode() - Method in class org.infinispan.commons.configuration.attributes.ConfigurationElement
- hashCode() - Method in class org.infinispan.commons.dataconversion.MediaType
- hashCode() - Method in class org.infinispan.commons.hash.MurmurHash3
- hashCode() - Method in class org.infinispan.commons.io.ByteBufferImpl
- hashCode() - Method in class org.infinispan.commons.marshall.WrappedByteArray
- hashCode() - Method in class org.infinispan.commons.tx.TransactionImpl
-
Must be defined for increased performance
- hashCode() - Method in class org.infinispan.commons.tx.XidImpl
- hashCode() - Method in class org.infinispan.commons.util.AbstractMap
- hashCode() - Method in class org.infinispan.commons.util.AbstractMap.SimpleEntry
- hashCode() - Method in class org.infinispan.commons.util.ForwardingList
- hashCode() - Method in class org.infinispan.commons.util.ImmutableListCopy
- hashCode() - Method in class org.infinispan.commons.util.KeyValueWithPrevious
- hashCode() - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- hashCode() - Method in class org.infinispan.commons.util.SegmentAwareKey
- hashCode() - Method in class org.infinispan.commons.util.SimpleImmutableEntry
- hashCode() - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- hashCode() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.Configuration
- hashCode() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfiguration
-
Deprecated.
- hashCode() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.MemoryStorageConfiguration
-
Deprecated.
- hashCode() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.SecurityConfiguration
- hashCode() - Method in class org.infinispan.configuration.global.AllowListConfiguration
- hashCode() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
- hashCode() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- hashCode() - Method in class org.infinispan.configuration.global.GlobalJmxConfiguration
- hashCode() - Method in class org.infinispan.configuration.global.GlobalMetricsConfiguration
- hashCode() - Method in class org.infinispan.configuration.global.GlobalSecurityConfiguration
- hashCode() - Method in class org.infinispan.configuration.global.SerializationConfiguration
- hashCode() - Method in class org.infinispan.configuration.global.ShutdownConfiguration
- hashCode() - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
- hashCode() - Method in class org.infinispan.configuration.global.SiteConfiguration
-
Deprecated.
- hashCode() - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
-
Deprecated.
- hashCode() - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
- hashCode() - Method in class org.infinispan.configuration.global.WhiteListConfiguration
-
Deprecated.
- hashCode() - Method in class org.infinispan.configuration.parsing.ParserRegistry.QName
- hashCode() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
- hashCode() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
- hashCode() - Method in class org.infinispan.container.entries.ImmortalCacheValue
- hashCode() - Method in class org.infinispan.container.entries.MortalCacheValue
- hashCode() - Method in class org.infinispan.container.entries.TransientCacheValue
- hashCode() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
- hashCode() - Method in class org.infinispan.container.versioning.irac.IracEntryVersion
- hashCode() - Method in class org.infinispan.container.versioning.irac.IracEntryVersion.MapEntry
- hashCode() - Method in class org.infinispan.container.versioning.irac.IracTombstoneInfo
- hashCode() - Method in class org.infinispan.container.versioning.irac.TopologyIracVersion
- hashCode() - Method in class org.infinispan.container.versioning.NumericVersion
- hashCode() - Method in class org.infinispan.container.versioning.SimpleClusteredVersion
- hashCode() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
- hashCode() - Method in class org.infinispan.counter.api.CounterConfiguration
- hashCode() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
- hashCode() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
- hashCode() - Method in class org.infinispan.distribution.ch.impl.HashFunctionPartitioner
- hashCode() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
- hashCode() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory
- hashCode() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
- hashCode() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory
- hashCode() - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory
- hashCode() - Method in class org.infinispan.encoding.DataConversion
- hashCode() - Method in class org.infinispan.extendedstats.topK.StreamSummaryContainer
- hashCode() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
- hashCode() - Method in class org.infinispan.functional.MetaParam.MetaBoolean
- hashCode() - Method in class org.infinispan.functional.MetaParam.MetaEntryVersion
- hashCode() - Method in class org.infinispan.functional.MetaParam.MetaLong
- hashCode() - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
- hashCode() - Method in class org.infinispan.globalstate.ScopedState
- hashCode() - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
-
Deprecated.
- hashCode() - Method in class org.infinispan.io.GridFile
-
Deprecated.
- hashCode() - Method in class org.infinispan.io.ImmutableMarshalledValueByteStream
-
Deprecated.
- hashCode() - Method in class org.infinispan.jmx.ResourceDMBean
- hashCode() - Method in class org.infinispan.metadata.EmbeddedMetadata.EmbeddedExpirableMetadata
- hashCode() - Method in class org.infinispan.metadata.EmbeddedMetadata.EmbeddedLifespanExpirableMetadata
- hashCode() - Method in class org.infinispan.metadata.EmbeddedMetadata.EmbeddedMaxIdleExpirableMetadata
- hashCode() - Method in class org.infinispan.metadata.EmbeddedMetadata
- hashCode() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
-
Deprecated.
- hashCode() - Method in class org.infinispan.metadata.impl.IracMetadata
- hashCode() - Method in class org.infinispan.metadata.impl.PrivateMetadata
- hashCode() - Method in class org.infinispan.metrics.config.MicrometerMeterRegisterConfigurationBuilder
- hashCode() - Method in class org.infinispan.metrics.config.MicrometerMeterRegistryConfiguration
- hashCode() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
- hashCode() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- hashCode() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
- hashCode() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfiguration
- hashCode() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractUnmanagedConnectionFactoryConfiguration
- hashCode() - Method in class org.infinispan.persistence.jdbc.common.configuration.ManagedConnectionFactoryConfiguration
- hashCode() - Method in class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfiguration
- hashCode() - Method in class org.infinispan.persistence.jdbc.configuration.DataColumnConfiguration
- hashCode() - Method in class org.infinispan.persistence.jdbc.configuration.IdColumnConfiguration
- hashCode() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfiguration
- hashCode() - Method in class org.infinispan.persistence.jdbc.configuration.SegmentColumnConfiguration
- hashCode() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- hashCode() - Method in class org.infinispan.persistence.jdbc.configuration.TimestampColumnConfiguration
- hashCode() - Method in class org.infinispan.persistence.modifications.ModificationsList
- hashCode() - Method in class org.infinispan.persistence.modifications.Remove
- hashCode() - Method in class org.infinispan.persistence.modifications.Store
- hashCode() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
- hashCode() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
- hashCode() - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfiguration
- hashCode() - Method in class org.infinispan.persistence.remote.configuration.MechanismConfiguration
- hashCode() - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfiguration
- hashCode() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfiguration
- hashCode() - Method in class org.infinispan.persistence.remote.configuration.TrustStoreConfiguration
- hashCode() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBExpirationConfiguration
- hashCode() - Method in class org.infinispan.persistence.sifs.configuration.DataConfiguration
- hashCode() - Method in class org.infinispan.persistence.sifs.configuration.IndexConfiguration
- hashCode() - Method in class org.infinispan.persistence.sifs.EntryInfo
- hashCode() - Method in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.Parameter
- hashCode() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfiguration
- hashCode() - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfiguration
- hashCode() - Method in class org.infinispan.query.impl.EntityLoader
- hashCode() - Method in class org.infinispan.remoting.LocalInvocation
- hashCode() - Method in class org.infinispan.remoting.responses.SuccessfulResponse
- hashCode() - Method in class org.infinispan.remoting.responses.UnsuccessfulResponse
- hashCode() - Method in class org.infinispan.remoting.rpc.RpcOptions
- hashCode() - Method in class org.infinispan.remoting.transport.AggregateBackupResponse
- hashCode() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
- hashCode() - Method in class org.infinispan.remoting.transport.SiteAddress
- hashCode() - Method in class org.infinispan.search.mapper.common.impl.EntityReferenceImpl
- hashCode() - Method in class org.infinispan.security.CachePermission
- hashCode() - Method in class org.infinispan.security.impl.CacheRoleImpl
- hashCode() - Method in class org.infinispan.security.impl.CacheSubjectPair
- hashCode() - Method in class org.infinispan.security.impl.SecureCacheImpl
- hashCode() - Method in class org.infinispan.server.core.security.InetAddressPrincipal
- hashCode() - Method in class org.infinispan.server.core.security.simple.SimpleUserPrincipal
- hashCode() - Method in class org.infinispan.server.hotrod.MultiHomedServerAddress
- hashCode() - Method in class org.infinispan.server.hotrod.SingleHomedServerAddress
- hashCode() - Method in class org.infinispan.server.hotrod.tx.table.CacheXid
- hashCode() - Method in class org.infinispan.server.hotrod.tx.table.ClientAddress
- hashCode() - Method in class org.infinispan.server.hotrod.tx.table.TxState
- hashCode() - Method in class org.infinispan.topology.CacheJoinInfo
- hashCode() - Method in class org.infinispan.topology.CacheTopology
- hashCode() - Method in class org.infinispan.topology.PersistentUUID
- hashCode() - Method in class org.infinispan.transaction.impl.AbstractEnlistmentAdapter
-
Invoked by TransactionManagers, make sure it's an efficient implementation.
- hashCode() - Method in class org.infinispan.transaction.impl.LocalTransaction
- hashCode() - Method in class org.infinispan.transaction.impl.RemoteTransaction
- hashCode() - Method in class org.infinispan.transaction.xa.GlobalTransaction
- hashCode() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfo
- hashCode() - Method in class org.infinispan.transaction.xa.recovery.RecoveryInfoKey
- hashCode() - Method in class org.infinispan.util.ByteString
- hashCode() - Method in class org.infinispan.util.KeyValuePair
- hashCode() - Method in class org.infinispan.xsite.events.XSiteEvent
- hashCode() - Method in class org.infinispan.xsite.irac.IracManagerKeyInfoImpl
- hashCode() - Method in class org.infinispan.xsite.spi.SiteEntry
- hashCode() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferCollector
- hashCode(byte[], int) - Static method in class org.infinispan.commons.util.Util
-
A function that calculates hash code of a byte array based on its contents but using the given size parameter as deliminator for the content.
- HashConfiguration - Class in org.infinispan.configuration.cache
-
Allows fine-tuning of rehashing characteristics.
- HashConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Allows fine-tuning of rehashing characteristics.
- HashFunctionPartitioner - Class in org.infinispan.distribution.ch.impl
-
Key partitioner that computes a key's segment based on a hash function.
- HashFunctionPartitioner() - Constructor for class org.infinispan.distribution.ch.impl.HashFunctionPartitioner
- HashFunctionPartitioner(int) - Constructor for class org.infinispan.distribution.ch.impl.HashFunctionPartitioner
- hashToSegment(T) - Method in class org.infinispan.util.StripedHashFunction
-
It calculates the segment in which the object belongs.
- hasInUseBackup(String) - Method in class org.infinispan.configuration.cache.SitesConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.since 14.0. To be removed without replacement
- hasIracMetadata(Object) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
- hasIracMetadata(Object) - Method in class org.infinispan.transaction.impl.LocalTransaction
- hasLeader(String) - Method in enum org.infinispan.remoting.transport.impl.EmptyRaftManager
- hasLifespan() - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
- hasListener(Class<? extends Annotation>) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
-
Returns whether there is at least one listener regitstered for the given annotation
- hasListener(Class<? extends Annotation>) - Method in interface org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifier
-
Returns whether there is at least one listener registered for the given annotation
- hasListener(Class<? extends Annotation>) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
- hasLocalBias(Object) - Method in interface org.infinispan.scattered.BiasManager
-
Check if we can read local data and update last-read timestamp for this key.
- hasLocalBias(Object) - Method in class org.infinispan.scattered.impl.BiasManagerImpl
- hasLockedKey(Object) - Method in class org.infinispan.context.impl.AbstractInvocationContext
- hasLockedKey(Object) - Method in class org.infinispan.context.impl.ClearInvocationContext
- hasLockedKey(Object) - Method in class org.infinispan.context.impl.ImmutableContext
- hasLockedKey(Object) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
- hasLockedKey(Object) - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
- hasLockedKey(Object) - Method in interface org.infinispan.context.InvocationContext
-
Returns true if the lock being tested is already held in the current scope, false otherwise.
- hasMaxIdle() - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
- hasMechanisms() - Method in class org.infinispan.rest.configuration.AuthenticationConfigurationBuilder
- hasMechanisms() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
- hasMechanisms() - Method in class org.infinispan.server.hotrod.configuration.SaslConfigurationBuilder
- hasModification(Class<?>) - Method in interface org.infinispan.transaction.xa.CacheTransaction
-
Deprecated, for removal: This API element is subject to removal in a future version.since 14.0. To be removed without replacement.
- hasModifications() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
- hasModifications() - Method in interface org.infinispan.context.impl.TxInvocationContext
-
Checks if there are modifications performed within the tx's scope.
- hasModifications() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
- hasNext() - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
- hasNext() - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationReader
- hasNext() - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationReader
- hasNext() - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader
- hasNext() - Method in class org.infinispan.commons.util.AbstractIterator
- hasNext() - Method in class org.infinispan.commons.util.Immutables.ImmutableIteratorWrapper
- hasNext() - Method in class org.infinispan.commons.util.IteratorMapper
- hasNext() - Method in class org.infinispan.commons.util.RemovableIterator
- hasNext() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator
- hasNext() - Method in class org.infinispan.query.impl.ScrollerIteratorAdaptor
- hasNext() - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
- hasNext() - Method in class org.infinispan.util.CloseableSuppliedIterator
- hasNext() - Method in class org.infinispan.util.DataContainerRemoveIterator
- hasNext() - Method in class org.infinispan.util.LazyConcatIterator
- hasNonLocalModifications() - Method in class org.infinispan.transaction.impl.ModificationList
- hasParameters() - Method in class org.infinispan.commons.dataconversion.MediaType
- hasPendingBackupAcks(long) - Method in class org.infinispan.util.concurrent.CommandAckCollector
- hasPendingTransactions() - Method in class org.infinispan.extendedstats.CacheStatisticManager
- hasProjections() - Method in interface org.infinispan.query.dsl.Query
-
Indicates if the parsed query has projections (a SELECT clause) and consequently the returned results will actually be
Object[]
containing the projected values rather than the target entity. - hasRole(String) - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
- hasRole(String) - Method in class org.infinispan.security.mappers.ClusterPermissionMapper
- hasRole(String) - Method in interface org.infinispan.security.RolePermissionMapper
- hasSameFlags(FlagAffectedCommand) - Method in class org.infinispan.commands.AbstractFlagAffectedCommand
- hasSecurityRealm() - Method in class org.infinispan.rest.configuration.AuthenticationConfigurationBuilder
- hasSecurityRealm() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
- hasSkipLocking() - Method in interface org.infinispan.util.concurrent.locks.RemoteLockCommand
-
It checks if this command should acquire locks.
- hasStack(String) - Method in class org.infinispan.configuration.global.JGroupsConfigurationBuilder
- hasStore(Predicate<StoreConfiguration>) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- hasStringType() - Method in class org.infinispan.commons.dataconversion.MediaType
- hasSyncEnabledBackups() - Method in class org.infinispan.configuration.cache.SitesConfiguration
- hasTimedOut() - Method in interface org.infinispan.util.concurrent.locks.PendingLockPromise
- hasTimedOut(long) - Method in class org.infinispan.server.hotrod.tx.table.TxState
- hasTopologyInfo() - Method in class org.infinispan.configuration.global.TransportConfiguration
- hasWriter() - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- hasZeroLockAcquisition() - Method in interface org.infinispan.util.concurrent.locks.RemoteLockCommand
- having(String) - Method in interface org.infinispan.query.dsl.FilterConditionBeginContext
-
Deprecated.
- having(String) - Method in interface org.infinispan.query.dsl.QueryFactory
-
Deprecated.since 10.1. See deprecation note on
QueryBuilder
. - having(Expression) - Method in interface org.infinispan.query.dsl.FilterConditionBeginContext
-
Deprecated.
- having(Expression) - Method in interface org.infinispan.query.dsl.QueryFactory
-
Deprecated.since 10.1. See deprecation note on
QueryBuilder
. - HEAD - Enum constant in enum org.infinispan.rest.framework.Method
- header - Variable in class org.infinispan.server.memcached.MemcachedDecoder
- header(String) - Method in interface org.infinispan.rest.framework.RestRequest
- header(String) - Method in class org.infinispan.rest.NettyRestRequest
- header(String, Object) - Method in interface org.infinispan.rest.framework.impl.RestResponseBuilder
- header(String, Object) - Method in class org.infinispan.rest.framework.impl.SimpleRestResponse.Builder
- header(String, Object) - Method in class org.infinispan.rest.NettyRestResponse.Builder
- HEADER_AND_CLASS_REFERENCE - Static variable in class org.infinispan.commons.util.AbstractEntrySizeCalculatorHelper
- headers(String) - Method in interface org.infinispan.rest.framework.RestRequest
- headers(String) - Method in class org.infinispan.rest.NettyRestRequest
- headersKeys() - Method in interface org.infinispan.rest.framework.RestRequest
- headersKeys() - Method in class org.infinispan.rest.NettyRestRequest
- Health - Interface in org.infinispan.health
-
An entry point for checking health status.
- HealthImpl - Class in org.infinispan.health.impl
- HealthImpl(EmbeddedCacheManager, InternalCacheRegistry) - Constructor for class org.infinispan.health.impl.HealthImpl
- HealthJMXExposer - Interface in org.infinispan.health.jmx
-
A Contract for exposing Health API over the JMX.
- HealthStatus - Enum in org.infinispan.health
-
General Health status.
- HEALTHY - Enum constant in enum org.infinispan.health.HealthStatus
-
Given entity is healthy.
- HEALTHY_REBALANCING - Enum constant in enum org.infinispan.health.HealthStatus
-
Given entity is healthy but a rebalance is in progress.
- HEAP - Enum constant in enum org.infinispan.configuration.cache.StorageType
-
Objects are stored on heap.
- HEAP - Enum constant in enum org.infinispan.configuration.parsing.Element
- heapConfiguration() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.
- heapDump(Path, boolean) - Method in class org.infinispan.commons.util.JVMMemoryInfoInfo
- heapDumpFailed(IOException) - Method in interface org.infinispan.rest.logging.Log
- HeartBeatCommand - Class in org.infinispan.topology
-
A hear-beat command used to ping members in
ClusterTopologyManagerImpl.confirmMembersAvailable()
. - HeartBeatCommand() - Constructor for class org.infinispan.topology.HeartBeatCommand
- help() - Constructor for class org.infinispan.commons.dataconversion.internal.Json.help
- HEX - Static variable in class org.infinispan.commons.dataconversion.MediaType
- HEX_DUMP_LIMIT - Static variable in class org.infinispan.commons.util.Util
- hexDump(byte[]) - Static method in class org.infinispan.commons.util.Util
- hexDump(byte[], int, int) - Static method in class org.infinispan.commons.util.Util
- hexDump(ByteBuf) - Static method in class org.infinispan.server.core.transport.ExtendedByteBuf
- hexDump(ByteBuffer) - Static method in class org.infinispan.commons.util.Util
- hexDump(Util.ByteGetter, int, int) - Static method in class org.infinispan.commons.util.Util
- hexIdHashCode(Object) - Static method in class org.infinispan.commons.util.Util
-
Prints the identity hash code of the object passed as parameter in an hexadecimal format in order to safe space.
- hexToBytes(String) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
-
Deprecated, for removal: This API element is subject to removal in a future version.Use
Base16Codec.decode(String)
instead. - HIGH - Enum constant in enum org.infinispan.client.hotrod.configuration.SaslStrength
- HIGH - Enum constant in enum org.infinispan.server.hotrod.configuration.Strength
- HIGHEST_PROTOCOL_VERSION - Static variable in enum org.infinispan.client.hotrod.ProtocolVersion
- histograms() - Method in class org.infinispan.configuration.global.GlobalMetricsConfiguration
-
Are histograms enabled?
- histograms() - Method in class org.infinispan.configuration.global.GlobalMetricsConfigurationBuilder
-
Are histograms enabled?
- histograms(boolean) - Method in class org.infinispan.configuration.global.GlobalMetricsConfigurationBuilder
-
Enables or disables histograms.
- HISTOGRAMS - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- HISTOGRAMS - Static variable in class org.infinispan.configuration.global.GlobalMetricsConfiguration
- Hit - Class in org.infinispan.query.remote.json
-
Represents each of the search results.
- Hit(Object) - Constructor for class org.infinispan.query.remote.json.Hit
- HIT - Static variable in class org.infinispan.functional.impl.StatsEnvelope
- HIT - Static variable in interface org.infinispan.query.remote.json.JSONConstants
- HIT_COUNT_ACCURACY - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- HIT_COUNT_ACCURACY - Static variable in class org.infinispan.configuration.cache.QueryConfiguration
- HIT_COUNT_ACCURACY - Static variable in interface org.infinispan.query.remote.json.JSONConstants
- hitCount() - Method in interface org.infinispan.query.dsl.QueryResult
- hitCountAccuracy() - Method in class org.infinispan.configuration.cache.QueryConfiguration
-
Limit the required accuracy of the hit count for the indexed queries to an upper-bound.
- hitCountAccuracy() - Method in class org.infinispan.configuration.cache.QueryConfigurationBuilder
- hitCountAccuracy() - Method in interface org.infinispan.query.dsl.Query
- hitCountAccuracy(int) - Method in class org.infinispan.configuration.cache.QueryConfigurationBuilder
-
Limit the required accuracy of the hit count for the indexed queries to an upper-bound.
- hitCountAccuracy(int) - Method in interface org.infinispan.query.dsl.Query
-
Limit the required accuracy of the hit count for the indexed queries to an upper-bound.
- hitCountAccuracy(int) - Method in interface org.infinispan.query.impl.IndexedQuery
-
Limit the required accuracy of the hit count for the indexed queries to an upper-bound.
- hitCountAccuracy(int) - Method in class org.infinispan.query.impl.IndexedQueryImpl
- HITS - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
-
Number of get hits.
- HITS - Static variable in interface org.infinispan.query.remote.json.JSONConstants
- hookBehavior() - Method in class org.infinispan.configuration.global.ShutdownConfiguration
- hookBehavior(ShutdownHookBehavior) - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
- HopscotchHashMap<K,
V> - Class in org.infinispan.commons.util -
Lookup on a table without collisions will require only single access, if there are collisions it will be limited to (number of collisions to particular bin + 1) and all those will lie in proximity (32 * reference size).
- HopscotchHashMap(int) - Constructor for class org.infinispan.commons.util.HopscotchHashMap
- host() - Method in class org.infinispan.client.hotrod.configuration.ServerConfiguration
- host() - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfiguration
- host() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- host() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- host() - Method in class org.infinispan.server.core.configuration.SniConfiguration
- host(String) - Method in class org.infinispan.client.hotrod.configuration.ServerConfigurationBuilder
- host(String) - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfigurationBuilder
- host(String) - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
- host(String) - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- host(String) - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
-
Specifies the host or IP address on which this server will listen
- host(String) - Method in class org.infinispan.server.core.configuration.SniConfigurationBuilder
- HOST - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- HOST - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- HOST_NAME - Enum constant in enum org.infinispan.server.hotrod.configuration.Attribute
- HostInfo - Interface in org.infinispan.health
-
Information about the host.
- hostnameValidation() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
- hostnameValidation() - Method in class org.infinispan.persistence.remote.configuration.SslConfiguration
- hostnameValidation(boolean) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
-
Configures whether to enable hostname validation according to RFC 2818.
- hostnameValidation(boolean) - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
-
Enables or disables SSL hostname validation
- HOT_ROD_VERSION_GENERATOR - Static variable in class org.infinispan.factories.KnownComponentNames
- HOTROD - Static variable in interface org.infinispan.client.hotrod.logging.Log
- HOTROD_20 - Enum constant in enum org.infinispan.server.hotrod.HotRodVersion
- HOTROD_21 - Enum constant in enum org.infinispan.server.hotrod.HotRodVersion
- HOTROD_22 - Enum constant in enum org.infinispan.server.hotrod.HotRodVersion
- HOTROD_23 - Enum constant in enum org.infinispan.server.hotrod.HotRodVersion
- HOTROD_24 - Enum constant in enum org.infinispan.server.hotrod.HotRodVersion
- HOTROD_25 - Enum constant in enum org.infinispan.server.hotrod.HotRodVersion
- HOTROD_26 - Enum constant in enum org.infinispan.server.hotrod.HotRodVersion
- HOTROD_27 - Enum constant in enum org.infinispan.server.hotrod.HotRodVersion
- HOTROD_28 - Enum constant in enum org.infinispan.server.hotrod.HotRodVersion
- HOTROD_29 - Enum constant in enum org.infinispan.server.hotrod.HotRodVersion
- HOTROD_30 - Enum constant in enum org.infinispan.server.hotrod.HotRodVersion
- HOTROD_31 - Enum constant in enum org.infinispan.server.hotrod.HotRodVersion
- HOTROD_40 - Enum constant in enum org.infinispan.server.hotrod.HotRodVersion
- HOTROD_CLIENT_PROPERTIES - Static variable in class org.infinispan.client.hotrod.RemoteCacheManager
- HOTROD_CONNECTOR - Enum constant in enum org.infinispan.server.hotrod.configuration.Element
- HOTROD_SASL_PROTOCOL - Static variable in class org.infinispan.server.hotrod.Authentication
- HOTROD_WRAPPING - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- HotRodAccessLogging - Class in org.infinispan.server.hotrod.logging
-
Logging handler for Hot Rod to log what requests have come into the server
- HotRodAccessLogging() - Constructor for class org.infinispan.server.hotrod.logging.HotRodAccessLogging
- HotRodClientException - Exception in org.infinispan.client.hotrod.exceptions
-
Base class for exceptions reported by the hot rod client.
- HotRodClientException() - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodClientException
- HotRodClientException(String) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodClientException
- HotRodClientException(String, long, int) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodClientException
- HotRodClientException(String, Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodClientException
- HotRodClientException(Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodClientException
- HotRodConstants - Interface in org.infinispan.server.hotrod
-
Defines constants defined by Hot Rod specifications.
- HotRodCounterEvent - Class in org.infinispan.client.hotrod.counter.impl
-
A
CounterEvent
implementation for the Hot Rod client. - HotRodCounterEvent(byte[], String, long, CounterState, long, CounterState) - Constructor for class org.infinispan.client.hotrod.counter.impl.HotRodCounterEvent
- HotRodDecoder - Class in org.infinispan.server.hotrod
- HotRodDecoder(EmbeddedCacheManager, Executor, HotRodServer) - Constructor for class org.infinispan.server.hotrod.HotRodDecoder
- HotRodDecoderState - Enum in org.infinispan.server.hotrod
-
Protocol decoding state
- HotRodEntryMarshaller - Class in org.infinispan.persistence.remote.wrapper
-
Deprecated, for removal: This API element is subject to removal in a future version.Use
IdentityMarshaller
instead. - HotRodEntryMarshaller(ByteBufferFactory) - Constructor for class org.infinispan.persistence.remote.wrapper.HotRodEntryMarshaller
-
Deprecated.
- HotRodHeader - Class in org.infinispan.server.hotrod
- HotRodHeader(HotRodHeader) - Constructor for class org.infinispan.server.hotrod.HotRodHeader
- HotRodHeader(HotRodOperation, byte, long, String, int, short, int, MediaType, MediaType, Map<String, byte[]>) - Constructor for class org.infinispan.server.hotrod.HotRodHeader
- HotRodMigratorHelper - Class in org.infinispan.persistence.remote.upgrade
- HotRodMigratorHelper() - Constructor for class org.infinispan.persistence.remote.upgrade.HotRodMigratorHelper
- HotRodModuleCommandExtensions - Class in org.infinispan.server.hotrod.command
-
It register the
HotRodCommandFactory
to handle theCacheRpcCommand
used by this module. - HotRodModuleCommandExtensions() - Constructor for class org.infinispan.server.hotrod.command.HotRodModuleCommandExtensions
- HotRodOperation - Enum in org.infinispan.server.hotrod
-
Enumeration defining all of the possible hotrod operations
- HotRodServer - Class in org.infinispan.server.hotrod
-
Hot Rod server, in charge of defining its encoder/decoder and, if clustered, update the topology information on startup and shutdown.
- HotRodServer() - Constructor for class org.infinispan.server.hotrod.HotRodServer
- HotRodServer.ExtendedCacheInfo - Class in org.infinispan.server.hotrod
- HotRodServerChildConfigurationBuilder - Interface in org.infinispan.server.hotrod.configuration
-
HotRodServerChildConfigurationBuilder.
- HotRodServerConfiguration - Class in org.infinispan.server.hotrod.configuration
- HotRodServerConfigurationBuilder - Class in org.infinispan.server.hotrod.configuration
-
HotRodServerConfigurationBuilder.
- HotRodServerConfigurationBuilder() - Constructor for class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
- HotRodTargetMigrator - Class in org.infinispan.persistence.remote.upgrade
- HotRodTargetMigrator() - Constructor for class org.infinispan.persistence.remote.upgrade.HotRodTargetMigrator
- HotRodTelemetryService - Class in org.infinispan.server.hotrod.tracing
- HotRodTelemetryService(TelemetryService) - Constructor for class org.infinispan.server.hotrod.tracing.HotRodTelemetryService
- HotRodTimeoutException - Exception in org.infinispan.client.hotrod.exceptions
-
Signals an remote timeout(due to locking) in the infinispan server.
- HotRodTimeoutException() - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodTimeoutException
- HotRodTimeoutException(String) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodTimeoutException
- HotRodTimeoutException(String, long, int) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodTimeoutException
- HotRodTimeoutException(String, Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodTimeoutException
- HotRodTimeoutException(Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.HotRodTimeoutException
- HotRodURI - Class in org.infinispan.client.hotrod.impl
- HotRodVersion - Enum in org.infinispan.server.hotrod
-
The various Hot Rod versions
- hotRodWrapping() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.since 12.0 - Automatic media type detection in remote store makes this option redundant
- hotRodWrapping(boolean) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- hotRodWrapping(boolean) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.
- hotRodWrapping(boolean) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
-
Configures this RemoteStore so that it enables all settings needed to create entries to be served by a HotRod endpoint, for example when performing rolling upgrades.
- HOURS - Enum constant in enum org.infinispan.server.hotrod.TimeUnitValue
- HSQL - Enum constant in enum org.infinispan.persistence.jdbc.common.DatabaseType
I
- ICKLE_CONTINUOUS_QUERY_RESULT - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- ICKLE_FILTER_RESULT - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- id() - Method in class org.infinispan.commons.dataconversion.ByteArrayWrapper
- id() - Method in interface org.infinispan.commons.dataconversion.Encoder
-
Deprecated.Each encoder is associated with an unique id in order to optimize serialization.
- id() - Method in class org.infinispan.commons.dataconversion.GlobalMarshallerEncoder
-
Deprecated.
- id() - Method in class org.infinispan.commons.dataconversion.IdentityEncoder
-
Deprecated.
- id() - Method in class org.infinispan.commons.dataconversion.IdentityWrapper
- id() - Method in class org.infinispan.commons.dataconversion.JavaSerializationEncoder
-
Deprecated.
- id() - Method in class org.infinispan.commons.dataconversion.UTF8Encoder
-
Deprecated.
- id() - Method in interface org.infinispan.commons.dataconversion.Wrapper
- id() - Method in enum org.infinispan.functional.Param.ExecutionMode
- id() - Method in interface org.infinispan.functional.Param
-
A parameter's identifier.
- id() - Method in enum org.infinispan.functional.Param.LockingMode
- id() - Method in enum org.infinispan.functional.Param.PersistenceMode
- id() - Method in enum org.infinispan.functional.Param.ReplicationMode
- id() - Method in enum org.infinispan.functional.Param.StatisticsMode
- id() - Method in class org.infinispan.jboss.marshalling.dataconversion.GenericJbossMarshallerEncoder
-
Deprecated.
- ID - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- ID - Static variable in enum org.infinispan.functional.Param.ExecutionMode
- ID - Static variable in enum org.infinispan.functional.Param.LockingMode
- ID - Static variable in enum org.infinispan.functional.Param.PersistenceMode
- ID - Static variable in enum org.infinispan.functional.Param.ReplicationMode
- ID - Static variable in enum org.infinispan.functional.Param.StatisticsMode
- ID_ANNOTATED - Static variable in class org.infinispan.marshall.core.GlobalMarshaller
- ID_COLUMN - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
- ID_COLUMN_NAME - Static variable in class org.infinispan.persistence.jdbc.configuration.IdColumnConfiguration
- ID_COLUMN_TYPE - Static variable in class org.infinispan.persistence.jdbc.configuration.IdColumnConfiguration
- ID_EXTERNAL - Static variable in class org.infinispan.marshall.core.GlobalMarshaller
- ID_INTERNAL - Static variable in class org.infinispan.marshall.core.GlobalMarshaller
- ID_NULL - Static variable in class org.infinispan.marshall.core.GlobalMarshaller
- ID_PRIMITIVE - Static variable in class org.infinispan.marshall.core.GlobalMarshaller
- ID_UNKNOWN - Static variable in class org.infinispan.marshall.core.GlobalMarshaller
- idColumnConfiguration() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- IdColumnConfiguration - Class in org.infinispan.persistence.jdbc.configuration
- IdColumnConfiguration(AttributeSet) - Constructor for class org.infinispan.persistence.jdbc.configuration.IdColumnConfiguration
- IdColumnConfigurationBuilder - Class in org.infinispan.persistence.jdbc.configuration
- idColumnName() - Method in class org.infinispan.persistence.jdbc.configuration.IdColumnConfiguration
- idColumnName() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- idColumnName(String) - Method in class org.infinispan.persistence.jdbc.configuration.IdColumnConfigurationBuilder
- idColumnName(String) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
-
The name of the database column used to store the keys
- idColumnType() - Method in class org.infinispan.persistence.jdbc.configuration.IdColumnConfiguration
- idColumnType() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- idColumnType(String) - Method in class org.infinispan.persistence.jdbc.configuration.IdColumnConfigurationBuilder
- idColumnType(String) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
-
The type of the database column used to store the keys
- identifier - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
- identifierMapping() - Method in interface org.infinispan.search.mapper.session.impl.InfinispanIndexedTypeContext
- identity() - Static method in class org.infinispan.commons.util.concurrent.CompletableFutures
- identity() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- identity() - Static method in class org.infinispan.reactive.publisher.PublisherTransformers
- identity() - Static method in class org.infinispan.stream.StreamMarshalling
-
Same as
Function.identity()
except that this instance is also able to be marshalled by Infinispan. - IDENTITY - Enum constant in enum org.infinispan.commons.configuration.io.NamingStrategy
- IDENTITY - Static variable in interface org.infinispan.commons.dataconversion.EncoderIds
-
Deprecated.
- IDENTITY_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. For internal use only.
- IDENTITY_ROLE_MAPPER - Enum constant in enum org.infinispan.configuration.parsing.Element
- IDENTITY_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. For internal use only.
- IDENTITY_WRAPPER - Static variable in interface org.infinispan.commons.dataconversion.WrapperIds
- IdentityAttributeCopier<T> - Class in org.infinispan.commons.configuration.attributes
-
IdentityAttributeCopier.
- IdentityAttributeCopier() - Constructor for class org.infinispan.commons.configuration.attributes.IdentityAttributeCopier
- identityCopier() - Static method in class org.infinispan.commons.configuration.attributes.IdentityAttributeCopier
- IdentityEncoder - Class 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.
- IdentityEncoder() - Constructor for class org.infinispan.commons.dataconversion.IdentityEncoder
-
Deprecated.
- identityFunction() - Static method in class org.infinispan.commons.reactive.RxJavaInterop
- IdentityMarshaller - Class in org.infinispan.commons.marshall
-
A marshaller that does not transform the content, only applicable to byte[] payloads.
- IdentityMarshaller() - Constructor for class org.infinispan.commons.marshall.IdentityMarshaller
- IdentityRoleMapper - Class in org.infinispan.security.impl
-
Deprecated, for removal: This API element is subject to removal in a future version.use
IdentityRoleMapper
instead - IdentityRoleMapper - Class in org.infinispan.security.mappers
-
IdentityRoleMapper.
- IdentityRoleMapper() - Constructor for class org.infinispan.security.impl.IdentityRoleMapper
-
Deprecated.
- IdentityRoleMapper() - Constructor for class org.infinispan.security.mappers.IdentityRoleMapper
- IdentityWrapper - Class in org.infinispan.commons.dataconversion
-
A wrapper that does not change the content.
- idFromBaseType() - Method in class org.infinispan.server.core.dataconversion.json.SecureTypeIdResolver
-
Deprecated.
- idFromValue(Object) - Method in class org.infinispan.server.core.dataconversion.json.SecureTypeIdResolver
-
Deprecated.
- idFromValueAndType(Object, Class<?>) - Method in class org.infinispan.server.core.dataconversion.json.SecureTypeIdResolver
-
Deprecated.
- IDLE - Enum constant in enum org.infinispan.xsite.statetransfer.StateTransferStatus
- IDLE_TIMEOUT - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- IdleStateHandlerProvider - Class in org.infinispan.server.core.transport
-
A Netty channel handler that allows idle channels to be closed.
- IdleStateHandlerProvider() - Constructor for class org.infinispan.server.core.transport.IdleStateHandlerProvider
- idleTimeout() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- idleTimeout(int) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- idleTimeout(int) - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
- idleTimeout(int) - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- idleTimeout(int) - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
-
Specifies the maximum time that connections from client will be kept open without activity
- idResolver(MapperConfig<?>, JavaType, PolymorphicTypeValidator, Collection<NamedType>, boolean, boolean) - Method in class org.infinispan.server.core.dataconversion.json.SecureTypeResolverBuilder
-
Deprecated.
- Ids - Class in org.infinispan.xsite.commands.remote
- Ids - Interface in org.infinispan.commons.marshall
-
Internal marshalling identifiers.
- Ids - Interface in org.infinispan.marshall.core
-
Indexes for object types.
- Ids - Interface in org.infinispan.server.hotrod.command
-
The ids of the
ReplicableCommand
used by this module. - IF_MODIFIED_SINCE - Enum constant in enum org.infinispan.rest.RequestHeader
- IF_NONE_MATCH - Enum constant in enum org.infinispan.rest.RequestHeader
- IF_UNMODIFIED_SINCE - Enum constant in enum org.infinispan.rest.RequestHeader
- ifUnmodifiedIsBeforeModificationDate(String, Long) - Static method in class org.infinispan.rest.DateUtils
- IGNORABLE_WHITESPACE - Static variable in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
-
Ignorable whitespace was just read.
- ignore(BackupManager.Resources.Type...) - Method in class org.infinispan.server.core.backup.BackupManagerResources.Builder
- IGNORE - Enum constant in enum org.infinispan.configuration.cache.BackupFailurePolicy
- IGNORE_DUPLICATES - Static variable in class org.infinispan.configuration.parsing.CacheParser
- IGNORE_RETURN_VALUES - Enum constant in enum org.infinispan.context.Flag
-
Signals that a write operation's return value will be ignored, so reading the existing value from a store or from a remote node is not necessary.
- IGNORE_RETURN_VALUES - Static variable in class org.infinispan.context.impl.FlagBitSets
- IGNORE_TRANSACTION - Enum constant in enum org.infinispan.context.Flag
-
Flag that is used by keySet, entrySet and values methods so that they do not return transactional values.
- IGNORE_TRANSACTION - Static variable in class org.infinispan.context.impl.FlagBitSets
- ignoreAttribute(ConfigurationReader, int) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- ignoreAttribute(ConfigurationReader, Enum<?>) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- ignoreAttribute(ConfigurationReader, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- ignoreCache - Variable in class org.infinispan.server.memcached.MemcachedDecoder
- ignoreCache(String) - Method in interface org.infinispan.server.core.ServerStateManager
- ignoreCommandWithFlags(long) - Method in class org.infinispan.persistence.remote.RemoteStore
- ignoreCommandWithFlags(long) - Method in interface org.infinispan.persistence.spi.NonBlockingStore
-
Some stores may not want to perform operations based on if a command has certain flags.
- ignoreCommandWithFlags(long) - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
- ignoreCommandWithFlags(long) - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
- IGNORED_CACHES - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- IGNORED_CACHES - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- ignoreElement(ConfigurationReader, Enum<?>) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- IgnoreExtraResponsesValidityFilter - Class in org.infinispan.remoting.responses
-
A filter that only expects responses from an initial set of targets.
- IgnoreExtraResponsesValidityFilter(Collection<Address>, Address, boolean) - Constructor for class org.infinispan.remoting.responses.IgnoreExtraResponsesValidityFilter
- ignoreLeavers() - Static method in class org.infinispan.remoting.transport.impl.MapResponseCollector
- ignoreLeavers() - Static method in class org.infinispan.remoting.transport.impl.SingletonMapResponseCollector
- ignoreLeavers() - Static method in class org.infinispan.remoting.transport.impl.VoidResponseCollector
- ignoreLeavers(boolean) - Static method in class org.infinispan.remoting.transport.impl.MapResponseCollector
- ignoreLeavers(boolean, int) - Static method in class org.infinispan.remoting.transport.impl.MapResponseCollector
- ignoreLeavers(int) - Static method in class org.infinispan.remoting.transport.impl.MapResponseCollector
- ignoreModifications() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
-
If true, any operation that modifies the cache (put, remove, clear, store...etc) won't be applied to the cache store.
- ignoreModifications() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
-
If true, any operation that modifies the cache (put, remove, clear, store...etc) won't be applied to the cache store.
- ignoreModifications(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
-
If true, any operation that modifies the cache (put, remove, clear, store...etc) won't be applied to the cache store.
- ignoreModifications(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
- ignoreModifications(boolean) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
-
If true, any operation that modifies the cache (put, remove, clear, store...etc) won't be applied to the cache store.
- ignoreValue(CompletionStage<?>) - Static method in class org.infinispan.util.concurrent.CompletionStages
- ignoreXmlAttribute(Object) - Method in interface org.infinispan.persistence.remote.logging.Log
- ignoringBooleanQueryMaxClauseCount(String, int, int) - Method in interface org.infinispan.query.logging.Log
- ignoringErrorDuringIterationClose(String, Throwable) - Method in interface org.infinispan.client.hotrod.logging.Log
- illegalArgument(String, Object) - Method in interface org.infinispan.rest.logging.Log
- illegalCompressionLevel(int) - Method in interface org.infinispan.rest.logging.Log
- illegalFilterConverterEventFactory(String) - Method in interface org.infinispan.server.hotrod.logging.Log
- illegalIdleTimeout(int) - Method in interface org.infinispan.server.core.logging.Log
- illegalIOThreads(int) - Method in interface org.infinispan.server.core.logging.Log
- IllegalLifecycleState - Enum constant in enum org.infinispan.server.hotrod.OperationStatus
- IllegalLifecycleStateException - Exception in org.infinispan.commons
-
This exception is thrown when the cache or cache manager does not have the right lifecycle state for operations to be called on it.
- IllegalLifecycleStateException - Exception in org.infinispan
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.1 please use
IllegalLifecycleStateException
instead - IllegalLifecycleStateException() - Constructor for exception org.infinispan.commons.IllegalLifecycleStateException
- IllegalLifecycleStateException() - Constructor for exception org.infinispan.IllegalLifecycleStateException
-
Deprecated.
- IllegalLifecycleStateException(String) - Constructor for exception org.infinispan.commons.IllegalLifecycleStateException
- IllegalLifecycleStateException(String) - Constructor for exception org.infinispan.IllegalLifecycleStateException
-
Deprecated.
- IllegalLifecycleStateException(String, Throwable) - Constructor for exception org.infinispan.commons.IllegalLifecycleStateException
- IllegalLifecycleStateException(String, Throwable) - Constructor for exception org.infinispan.IllegalLifecycleStateException
-
Deprecated.
- IllegalLifecycleStateException(Throwable) - Constructor for exception org.infinispan.commons.IllegalLifecycleStateException
- IllegalLifecycleStateException(Throwable) - Constructor for exception org.infinispan.IllegalLifecycleStateException
-
Deprecated.
- illegalParameterType(String, Class<?>) - Method in interface org.infinispan.server.core.logging.Log
- illegalReceiveBufferSize(int) - Method in interface org.infinispan.server.core.logging.Log
- illegalSendBufferSize(int) - Method in interface org.infinispan.server.core.logging.Log
- illegalWorkerThreads(int) - Method in interface org.infinispan.server.core.logging.Log
- IMAGE_GIF - Static variable in class org.infinispan.commons.dataconversion.MediaType
- IMAGE_GIF_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- IMAGE_JPEG - Static variable in class org.infinispan.commons.dataconversion.MediaType
- IMAGE_JPEG_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- IMAGE_PNG - Static variable in class org.infinispan.commons.dataconversion.MediaType
- IMAGE_PNG_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- IMMORTAL_ENTRY - Static variable in interface org.infinispan.commons.marshall.Ids
- IMMORTAL_VALUE - Static variable in interface org.infinispan.commons.marshall.Ids
- ImmortalCacheEntry - Class in org.infinispan.container.entries
-
A cache entry that is immortal/cannot expire
- ImmortalCacheEntry(Object, Object) - Constructor for class org.infinispan.container.entries.ImmortalCacheEntry
- ImmortalCacheEntry(Object, Object, PrivateMetadata) - Constructor for class org.infinispan.container.entries.ImmortalCacheEntry
- ImmortalCacheEntry.Externalizer - Class in org.infinispan.container.entries
- ImmortalCacheValue - Class in org.infinispan.container.entries
-
An immortal cache value, to correspond with
ImmortalCacheEntry
- ImmortalCacheValue(Object) - Constructor for class org.infinispan.container.entries.ImmortalCacheValue
- ImmortalCacheValue(Object, PrivateMetadata) - Constructor for class org.infinispan.container.entries.ImmortalCacheValue
- ImmortalCacheValue.Externalizer - Class in org.infinispan.container.entries
- immutable() - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition.Builder
- IMMUTABLE - Enum constant in enum org.infinispan.globalstate.ConfigurationStorage
-
Prevents the creation or removal of caches.
- IMMUTABLE_CONFIGURATION_STORAGE - Enum constant in enum org.infinispan.configuration.parsing.Element
- IMMUTABLE_LIST_COPY - Static variable in interface org.infinispan.commons.marshall.Ids
- IMMUTABLE_MAP - Static variable in interface org.infinispan.commons.marshall.Ids
- IMMUTABLE_SET - Static variable in interface org.infinispan.commons.marshall.Ids
- immutableAttribute(String) - Method in interface org.infinispan.rest.logging.Log
- immutableCollectionCopy(Collection<T>) - Static method in class org.infinispan.commons.util.Immutables
-
Creates a new immutable copy of the specified Collection.
- immutableCollectionWrap(Collection<? extends T>) - Static method in class org.infinispan.commons.util.Immutables
-
Wraps a collection with an immutable collection.
- ImmutableContext - Class in org.infinispan.context.impl
-
This context is a non-context for operations such as eviction which are not related to the method invocation which caused them.
- immutableEmptySet() - Static method in class org.infinispan.commons.util.IntSets
-
Returns an immutable IntSet containing no values
- immutableEntry(Map.Entry<K, V>) - Static method in class org.infinispan.commons.util.Immutables
- immutableEntry(K, V) - Static method in class org.infinispan.commons.util.Immutables
-
Wraps a key and value with an immutable
Map.Entry
}. - ImmutableHopscotchHashSet<E> - Class in org.infinispan.commons.util
-
Wrap a
HopscotchHashMap
and allow using it as aSet
. - ImmutableHopscotchHashSet(Collection<E>) - Constructor for class org.infinispan.commons.util.ImmutableHopscotchHashSet
- immutableInternalCacheEntry(InternalCacheEntry<K, V>) - Static method in class org.infinispan.util.CoreImmutables
-
Wraps a
InternalCacheEntry
} with an immutableInternalCacheEntry
}. - ImmutableIntSet - Class in org.infinispan.commons.util
-
Deprecated, for removal: This API element is subject to removal in a future version.since 9.3 This class will no longer be public, please use
IntSets.immutableSet(IntSet)
- ImmutableIntSet(IntSet) - Constructor for class org.infinispan.commons.util.ImmutableIntSet
-
Deprecated.
- ImmutableIteratorWrapper(Iterator<? extends E>) - Constructor for class org.infinispan.commons.util.Immutables.ImmutableIteratorWrapper
- immutableListAdd(List<T>, int, T) - Static method in class org.infinispan.commons.util.Immutables
- immutableListConvert(Collection<? extends T>) - Static method in class org.infinispan.commons.util.Immutables
-
Converts a Collection to an immutable List by copying it.
- immutableListCopy(List<T>) - Static method in class org.infinispan.commons.util.Immutables
-
Creates an immutable copy of the list.
- ImmutableListCopy<E> - Class in org.infinispan.commons.util
-
A lightweight, read-only copy of a List.
- ImmutableListCopy() - Constructor for class org.infinispan.commons.util.ImmutableListCopy
-
Constructs an empty ImmutableListCopy.
- ImmutableListCopy(E[]) - Constructor for class org.infinispan.commons.util.ImmutableListCopy
-
Assumes that the array passed in is "safe", i.e., is not referenced from elsewhere.
- ImmutableListCopy(Collection<? extends E>) - Constructor for class org.infinispan.commons.util.ImmutableListCopy
-
Only one copy constructor since the list is immutable.
- ImmutableListCopy(Collection<? extends E>, Collection<? extends E>) - Constructor for class org.infinispan.commons.util.ImmutableListCopy
-
Utility constructors to allow combining collections
- ImmutableListCopy.Externalizer - Class in org.infinispan.commons.util
- ImmutableListCopy.ImmutableSubList - Class in org.infinispan.commons.util
- immutableListMerge(List<? extends T>, List<? extends T>) - Static method in class org.infinispan.commons.util.Immutables
-
Creates a new immutable list containing the union (combined entries) of both lists.
- immutableListRemove(List<T>, int) - Static method in class org.infinispan.commons.util.Immutables
- immutableListReplace(List<T>, int, T) - Static method in class org.infinispan.commons.util.Immutables
- immutableListWrap(T...) - Static method in class org.infinispan.commons.util.Immutables
-
Wraps an array with an immutable list.
- ImmutableLocalConfigurationStorage - Class in org.infinispan.globalstate.impl
-
An immutable implementation of
LocalConfigurationStorage
which does not allow cache creation/removal. - ImmutableLocalConfigurationStorage() - Constructor for class org.infinispan.globalstate.impl.ImmutableLocalConfigurationStorage
- immutableMapCopy(Map<K, V>) - Static method in class org.infinispan.commons.util.Immutables
-
Creates an immutable copy of the specified map.
- immutableMapWrap(Map<? extends K, ? extends V>) - Static method in class org.infinispan.commons.util.Immutables
-
Wraps a map with an immutable map.
- ImmutableMapWrapperExternalizer() - Constructor for class org.infinispan.commons.util.Immutables.ImmutableMapWrapperExternalizer
- ImmutableMarshalledValueByteStream - Class in org.infinispan.io
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.0
- ImmutableMarshalledValueByteStream(byte[]) - Constructor for class org.infinispan.io.ImmutableMarshalledValueByteStream
-
Deprecated.
- ImmutableProtoStreamMarshaller - Class in org.infinispan.commons.marshall
-
A ProtoStream
Marshaller
implementation that uses Protobuf encoding. - ImmutableProtoStreamMarshaller(ImmutableSerializationContext) - Constructor for class org.infinispan.commons.marshall.ImmutableProtoStreamMarshaller
- immutableRangeSet(int) - Static method in class org.infinispan.commons.util.IntSets
-
Returns an immutable IntSet containing all values from
0
toendExclusive - 1
. - Immutables - Class in org.infinispan.commons.util
-
Factory for generating immutable type wrappers.
- Immutables() - Constructor for class org.infinispan.commons.util.Immutables
- Immutables.Immutable - Interface in org.infinispan.commons.util
- Immutables.ImmutableIteratorWrapper<E> - Class in org.infinispan.commons.util
- Immutables.ImmutableMapWrapperExternalizer - Class in org.infinispan.commons.util
- Immutables.ImmutableSetWrapperExternalizer - Class in org.infinispan.commons.util
- immutableSet(int) - Static method in class org.infinispan.commons.util.IntSets
-
Returns an immutable IntSet containing a single value
- immutableSet(IntSet) - Static method in class org.infinispan.commons.util.IntSets
-
Returns an immutable IntSet that wraps the given IntSet to prevent modifications.
- immutableSetConvert(Collection<? extends T>) - Static method in class org.infinispan.commons.util.Immutables
-
Converts a Collections into an immutable Set by copying it.
- immutableSetCopy(Set<T>) - Static method in class org.infinispan.commons.util.Immutables
-
Creates an immutable copy of the specified set.
- immutableSetWrap(Set<? extends T>) - Static method in class org.infinispan.commons.util.Immutables
-
Wraps a set with an immutable set.
- ImmutableSetWrapperExternalizer() - Constructor for class org.infinispan.commons.util.Immutables.ImmutableSetWrapperExternalizer
- immutableTypedProperties(TypedProperties) - Static method in class org.infinispan.commons.util.Immutables
-
Creates an immutable copy of the properties.
- IMPLEMENTATION_TYPE - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.Attribute
- IMPLICIT_CONNECTOR - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- implicitConnector() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- implicitConnector(boolean) - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
- implicitConnector(boolean) - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- implicitConnector(boolean) - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
-
Indicates whether this connector was added implicitly
- implies(Permission) - Method in class org.infinispan.security.CachePermission
- implies(Permission) - Method in class org.infinispan.security.CachePermissionCollection
- implies(AuthorizationPermission) - Method in enum org.infinispan.security.AuthorizationPermission
- in(Object...) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
-
Deprecated.Checks that the left operand is equal to one of the (fixed) list of values given as argument.
- in(Collection) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
-
Deprecated.Checks that the left operand is equal to one of the elements from the Collection of values given as argument.
- IN_DOUBT_TX_INFO - Static variable in interface org.infinispan.commons.marshall.Ids
- IN_PROGRESS - Enum constant in enum org.infinispan.server.core.BackupManager.Status
- IN_PROGRESS - Enum constant in enum org.infinispan.topology.RebalancingStatus
- InboundInvocationHandlerFactory - Class in org.infinispan.factories
-
Factory class that creates instances of
PerCacheInboundInvocationHandler
. - InboundInvocationHandlerFactory() - Constructor for class org.infinispan.factories.InboundInvocationHandlerFactory
- inboundSegments - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
- inc() - Method in class org.infinispan.commons.util.ByRef.Integer
- inc() - Method in class org.infinispan.commons.util.ByRef.Long
- include(TopologyAwareAddress, TopologyAwareAddress) - Method in enum org.infinispan.manager.ClusterExecutionPolicy
- includeAll() - Method in class org.infinispan.server.core.backup.BackupManagerResources.Builder
- includeAll(BackupManager.Resources.Type...) - Method in class org.infinispan.server.core.backup.BackupManagerResources.Builder
- includeCurrentState() - Element in annotation type org.infinispan.client.hotrod.annotation.ClientListener
-
This flag enables cached state to be sent back to remote clients when either adding a cache listener for the first time, or when the node where a remote listener is registered changes.
- includeCurrentState() - Element in annotation type org.infinispan.notifications.Listener
-
If set to true then the entire existing state within the cluster is evaluated.
- includeLower(boolean) - Method in interface org.infinispan.query.dsl.RangeConditionContext
-
Deprecated.
- includeTypes() - Method in class org.infinispan.server.core.backup.BackupManagerResources
- includeTypes() - Method in interface org.infinispan.server.core.BackupManager.Resources
- includeUpper(boolean) - Method in interface org.infinispan.query.dsl.RangeConditionContext
-
Deprecated.
- incorrectClientListener(String) - Method in interface org.infinispan.client.hotrod.logging.Log
- incorrectClientListener(String, Collection<?>) - Method in interface org.infinispan.client.hotrod.logging.Log
- IncorrectClientListenerException - Exception in org.infinispan.client.hotrod.event
- IncorrectClientListenerException(String) - Constructor for exception org.infinispan.client.hotrod.event.IncorrectClientListenerException
- IncorrectListenerException - Exception in org.infinispan.notifications
-
Thrown when an incorrectly annotated class is added as a cache listener using the
Listenable.addListener(Object)
API. - IncorrectListenerException(String) - Constructor for exception org.infinispan.notifications.IncorrectListenerException
- incOwned(int) - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
- incOwned(int, boolean) - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
- incOwned(Address) - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
- incPrimaryOwned(int) - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
- incPrimaryOwned(Address) - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
- increment() - Method in interface org.infinispan.commons.stat.CounterTracker
-
Update the counter by one.
- increment() - Method in interface org.infinispan.counter.api.SyncWeakCounter
- increment() - Method in interface org.infinispan.counter.api.WeakCounter
-
Increments the counter.
- increment() - Method in class org.infinispan.util.concurrent.CountDownRunnable
- increment(double) - Method in interface org.infinispan.commons.stat.CounterTracker
-
Update the counter by
amount
. - increment(int) - Method in class org.infinispan.container.versioning.irac.TopologyIracVersion
- increment(AtomicLongFieldUpdater<T>, T) - Method in class org.infinispan.commons.util.concurrent.StripedCounters
- increment(IncrementableEntryVersion) - Method in class org.infinispan.container.versioning.NumericVersionGenerator
- increment(IncrementableEntryVersion) - Method in class org.infinispan.container.versioning.SimpleClusteredVersionGenerator
- increment(IncrementableEntryVersion) - Method in interface org.infinispan.container.versioning.VersionGenerator
- increment(ExtendedStatistic, GlobalTransaction, boolean) - Method in class org.infinispan.extendedstats.CacheStatisticManager
-
Increments the statistic value.
- increment(ByteString, int) - Method in class org.infinispan.container.versioning.irac.IracEntryVersion
- IncrementableEntryVersion - Interface in org.infinispan.container.versioning
-
An interface indicating that a version of this type can be incremented.
- incrementAndGet() - Method in interface org.infinispan.counter.api.StrongCounter
-
Atomically increments the counter and returns the new value.
- incrementAndGet() - Method in interface org.infinispan.counter.api.SyncStrongCounter
- incrementNearCacheHits() - Method in class org.infinispan.client.hotrod.impl.ClientStatistics
- incrementNearCacheInvalidations() - Method in class org.infinispan.client.hotrod.impl.ClientStatistics
- incrementNearCacheMisses() - Method in class org.infinispan.client.hotrod.impl.ClientStatistics
- incrementNumberOfConflictLocalWins() - Method in class org.infinispan.xsite.irac.DefaultIracManager
- incrementNumberOfConflictLocalWins() - Method in interface org.infinispan.xsite.irac.IracManager
-
Increase the count of conflicts if merge policy discard update (local value wins)
- incrementNumberOfConflictLocalWins() - Method in enum org.infinispan.xsite.irac.NoOpIracManager
- incrementNumberOfConflictMerged() - Method in class org.infinispan.xsite.irac.DefaultIracManager
- incrementNumberOfConflictMerged() - Method in interface org.infinispan.xsite.irac.IracManager
-
Increase the count of conflicts if merge policy created a new value (merge remote value with local value)
- incrementNumberOfConflictMerged() - Method in enum org.infinispan.xsite.irac.NoOpIracManager
- incrementNumberOfConflictRemoteWins() - Method in class org.infinispan.xsite.irac.DefaultIracManager
- incrementNumberOfConflictRemoteWins() - Method in interface org.infinispan.xsite.irac.IracManager
-
Increase the count of conflicts if merge policy applies update (remote value wins)
- incrementNumberOfConflictRemoteWins() - Method in enum org.infinispan.xsite.irac.NoOpIracManager
- incrementNumberOfDiscards() - Method in class org.infinispan.xsite.irac.DefaultIracManager
- incrementNumberOfDiscards() - Method in interface org.infinispan.xsite.irac.IracManager
-
Increase the count of discards.
- incrementNumberOfDiscards() - Method in enum org.infinispan.xsite.irac.NoOpIracManager
- IncrementRequest - Enum constant in enum org.infinispan.server.memcached.MemcachedOperation
- incrementValue(ExtendedStatistic) - Method in class org.infinispan.extendedstats.TransactionStatistics
-
Increments a statistic value.
- incrementVersion(int) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
- incrementVersion(int) - Method in interface org.infinispan.scattered.ScatteredVersionManager
-
Generates a new version for an entry in given segment.
- incrementVersion(CacheEntry<?, ?>, VersionGenerator) - Static method in class org.infinispan.transaction.impl.WriteSkewHelper
- indent() - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- INDENT - Static variable in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- index - Variable in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
- index() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 11. This configuration will be removed in next major version as the index mode is calculated automatically.
- index() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
- index() - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfiguration
- index(int) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
-
Deprecated.Specifies a position in the interceptor chain to place the new interceptor.
- index(Index) - 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. This configuration will be removed in next major version as the index mode is calculated automatically.
- Index - Enum in org.infinispan.configuration.cache
-
Deprecated, for removal: This API element is subject to removal in a future version.since 11.0. The indexing mode is automatically detected and not configurable anymore (ignored) and will be completely removed in next major version.
- INDEX - Enum constant in enum org.infinispan.configuration.parsing.Attribute
-
Deprecated, for removal: This API element is subject to removal in a future version.
- INDEX - Enum constant in enum org.infinispan.configuration.parsing.Element
- INDEX - 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
- INDEX - Static variable in class org.infinispan.configuration.cache.InterceptorConfiguration
- INDEX_COMMIT_INTERVAL - Static variable in class org.infinispan.configuration.cache.IndexWriterConfiguration
- INDEX_INFO - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- INDEX_INFO_ENTRY - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- INDEX_LOCATION - Static variable in class org.infinispan.persistence.sifs.configuration.IndexConfiguration
- INDEX_LOW_LEVEL_TRACE - Static variable in class org.infinispan.configuration.cache.IndexWriterConfiguration
- INDEX_MAX_BUFFERED_ENTRIES - Static variable in class org.infinispan.configuration.cache.IndexWriterConfiguration
- INDEX_MERGE - Enum constant in enum org.infinispan.configuration.parsing.Element
- INDEX_QUEUE_COUNT - Static variable in class org.infinispan.configuration.cache.IndexWriterConfiguration
- INDEX_QUEUE_LENGTH - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- INDEX_QUEUE_LENGTH - Static variable in class org.infinispan.persistence.sifs.configuration.IndexConfiguration
- INDEX_QUEUE_SIZE - Static variable in class org.infinispan.configuration.cache.IndexWriterConfiguration
- INDEX_RAM_BUFFER_SIZE - Static variable in class org.infinispan.configuration.cache.IndexWriterConfiguration
- INDEX_READER - Enum constant in enum org.infinispan.configuration.parsing.Element
- INDEX_SEGMENTS - Static variable in class org.infinispan.persistence.sifs.configuration.IndexConfiguration
- INDEX_THREAD_POOL_SIZE - Static variable in class org.infinispan.configuration.cache.IndexWriterConfiguration
- INDEX_WRITER - Enum constant in enum org.infinispan.configuration.parsing.Element
- IndexConfiguration - Class in org.infinispan.persistence.sifs.configuration
- IndexConfiguration(AttributeSet) - Constructor for class org.infinispan.persistence.sifs.configuration.IndexConfiguration
- IndexConfigurationBuilder - Class in org.infinispan.persistence.sifs.configuration
- IndexConfigurationBuilder() - Constructor for class org.infinispan.persistence.sifs.configuration.IndexConfigurationBuilder
- INDEXED_ENTITIES - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- INDEXED_ENTITIES - Enum constant in enum org.infinispan.configuration.parsing.Element
- INDEXED_ENTITIES - Static variable in class org.infinispan.configuration.cache.IndexingConfiguration
- INDEXED_ENTITY - Enum constant in enum org.infinispan.configuration.parsing.Element
- indexedEntities() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.since 11. Usages should be converted to
IndexingConfiguration.indexedEntityTypes()
as this method will be removed in next major version. - indexedEntities() - Method in class org.infinispan.query.stats.impl.LocalIndexStatistics
- indexedEntitiesCount() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
- indexedEntitiesForStatistics() - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
- indexedEntity(Class<?>) - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
- indexedEntity(Class<?>) - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
- indexedEntity(String) - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
- indexedEntity(String) - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
- indexedEntityTypes() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
-
The set of fully qualified names of indexed entity types, either Java classes or protobuf type names.
- IndexedFilter<K,
V, C> - Interface in org.infinispan.notifications.cachelistener.filter -
A marker interface for filters that can be handled efficiently by a
FilterIndexingServiceProvider
. - indexedForEntityName(String) - Method in interface org.infinispan.search.mapper.session.impl.InfinispanTypeContextProvider
- indexedForExactType(Class<E>) - Method in interface org.infinispan.search.mapper.session.impl.InfinispanTypeContextProvider
- IndexedQuery<E> - Interface in org.infinispan.query.impl
-
A query that uses indexing.
- IndexedQueryImpl<E> - Class in org.infinispan.query.impl
-
Lucene based indexed query implementation.
- IndexedQueryImpl(String, IckleParsingResult.StatementType, SearchQueryBuilder, AdvancedCache<?, ?>, LocalQueryStatistics, int) - Constructor for class org.infinispan.query.impl.IndexedQueryImpl
-
Create a IndexedQueryImpl based on a SearchQuery.
- IndexedQueryImpl(QueryDefinition, AdvancedCache<?, ?>, LocalQueryStatistics) - Constructor for class org.infinispan.query.impl.IndexedQueryImpl
- Indexer - Interface in org.infinispan.query
-
Interacts directly with cache indexes.
- indexing() - Method in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
- indexing() - Method in class org.infinispan.configuration.cache.Configuration
- indexing() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- indexing() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- INDEXING - Enum constant in enum org.infinispan.configuration.parsing.Element
- IndexingConfiguration - Class in org.infinispan.configuration.cache
-
Configures indexing of entries in the cache for searching.
- IndexingConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Configures indexing of entries in the cache for searching.
- IndexingConfigurationChildBuilder - Interface in org.infinispan.configuration.cache
- indexingDocumentsCompleted(long, long) - Method in interface org.infinispan.query.logging.Log
- indexingEntitiesCompleted(long, long) - Method in interface org.infinispan.query.logging.Log
- IndexingOperation - Class in org.infinispan.search.mapper.work.impl
- IndexingOperation(PojoIndexer, Object, String) - Constructor for class org.infinispan.search.mapper.work.impl.IndexingOperation
- indexingStarting() - Method in interface org.infinispan.query.logging.Log
- indexLocation() - Method in class org.infinispan.persistence.sifs.configuration.IndexConfiguration
- indexLocation() - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfiguration
- indexLocation(String) - Method in class org.infinispan.persistence.sifs.configuration.IndexConfigurationBuilder
- indexLocation(String) - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
-
The path where the Soft-Index store will keep its index files.
- indexLooksCorrupt(Exception) - Method in interface org.infinispan.persistence.sifs.Log
- indexManager() - Method in interface org.infinispan.search.mapper.mapping.SearchIndexedEntity
- IndexMergeConfiguration - Class in org.infinispan.configuration.cache
- IndexMergeConfigurationBuilder - Class in org.infinispan.configuration.cache
- IndexMetamodel - Class in org.infinispan.search.mapper.mapping.metamodel
- IndexMetamodel(SearchIndexedEntity) - Constructor for class org.infinispan.search.mapper.mapping.metamodel.IndexMetamodel
- indexOf(Object) - Method in class org.infinispan.commons.util.ForwardingList
- indexOf(Object) - Method in class org.infinispan.commons.util.ImmutableListCopy
- IndexProperties - Class in org.infinispan.search.mapper.mapping.impl
- IndexProperties() - Constructor for class org.infinispan.search.mapper.mapping.impl.IndexProperties
- indexQueueLength() - Method in class org.infinispan.persistence.sifs.configuration.IndexConfiguration
- indexQueueLength() - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfiguration
- indexQueueLength(int) - Method in class org.infinispan.persistence.sifs.configuration.IndexConfigurationBuilder
- indexQueueLength(int) - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
-
Sets the maximum number of entry writes that are waiting to be written to the index, per index segment.
- IndexReaderConfiguration - Class in org.infinispan.configuration.cache
- IndexReaderConfigurationBuilder - Class in org.infinispan.configuration.cache
- indexResolver - Variable in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository
- indexSegments() - Method in class org.infinispan.persistence.sifs.configuration.IndexConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.
- indexSegments() - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.
- indexSegments(int) - Method in class org.infinispan.persistence.sifs.configuration.IndexConfigurationBuilder
-
Deprecated.
- indexSegments(int) - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
-
Deprecated.
- indexShareable() - 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; to be removed in next major version.
- indexSizes() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
- IndexStartupMode - Enum in org.infinispan.configuration.cache
-
Allows to define some mass indexing operations (e.g.: purge or reindex) to trigger when the cache starts.
- IndexStartupRunner - Class in org.infinispan.query.impl
- IndexStorage - Enum in org.infinispan.configuration.cache
- IndexWriterConfiguration - Class in org.infinispan.configuration.cache
- IndexWriterConfigurationBuilder - Class in org.infinispan.configuration.cache
- InDoubtTxInfo - Class in org.infinispan.transaction.xa.recovery
-
An object describing in doubt transaction's state.
- InDoubtTxInfo(XidImpl, long) - Constructor for class org.infinispan.transaction.xa.recovery.InDoubtTxInfo
- InDoubtTxInfo(XidImpl, long, int) - Constructor for class org.infinispan.transaction.xa.recovery.InDoubtTxInfo
- InequalVersionComparisonResult - Enum in org.infinispan.container.versioning
-
Versions can be compared to each other to result in one version being before, after or at the same time as another version.
- inetAddressMatchesInterfaceAddress(byte[], byte[], int) - Static method in class org.infinispan.server.hotrod.MultiHomedServerAddress
-
Checks whether the supplied network address matches the interfaceAddress.
- InetAddressPrincipal - Class in org.infinispan.server.core.security
-
InetAddressPrincipal.
- InetAddressPrincipal(InetAddress) - Constructor for class org.infinispan.server.core.security.InetAddressPrincipal
- InetAddressWithNetMask(InetAddress, short) - Constructor for class org.infinispan.server.hotrod.MultiHomedServerAddress.InetAddressWithNetMask
- InetAddressWithNetMask(InetAddress, short, boolean) - Constructor for class org.infinispan.server.hotrod.MultiHomedServerAddress.InetAddressWithNetMask
- INFINISPAN_BRAND_NAME - Static variable in class org.infinispan.commons.util.Version
- INFINISPAN_BRAND_VERSION - Static variable in class org.infinispan.commons.util.Version
- INFINISPAN_CODENAME - Static variable in class org.infinispan.commons.util.Version
- INFINISPAN_CORE_SCHEMA_VERSION - Static variable in class org.infinispan.commons.util.Version
- INFINISPAN_MODULE_SLOT_PREFIX - Static variable in class org.infinispan.commons.util.Version
- INFINISPAN_MODULE_SLOT_VERSION - Static variable in class org.infinispan.commons.util.Version
- INFINISPAN_VERSION - Static variable in class org.infinispan.commons.util.Version
- InfinispanBootstrapIntrospector - Class in org.infinispan.search.mapper.model.impl
-
A very simple introspector roughly following Java Beans conventions.
- InfinispanBootstrapIntrospector(ValueReadHandleFactory) - Constructor for class org.infinispan.search.mapper.model.impl.InfinispanBootstrapIntrospector
- infinispanClasses() - Static method in class org.infinispan.commons.util.ClassFinder
- infinispanClasses(String) - Static method in class org.infinispan.commons.util.ClassFinder
- InfinispanCollections - Class in org.infinispan.commons.util
-
Static helpers for Infinispan-specific collections
- InfinispanCollections.Function<E,
T> - Interface in org.infinispan.commons.util -
A function that converts a type into another one.
- InfinispanCollections.MapMakerFunction<K,
V, E> - Interface in org.infinispan.commons.util -
A function that converts an entry into a key/value pair for use in a map.
- InfinispanContainerCacheManagerBeanDefinitionParser - Class in org.infinispan.spring.common.config
- InfinispanContainerCacheManagerBeanDefinitionParser() - Constructor for class org.infinispan.spring.common.config.InfinispanContainerCacheManagerBeanDefinitionParser
- InfinispanDefaultCacheFactoryBean<K,
V> - Class in org.infinispan.spring.embedded -
A
for creating a native default InfinispanFactoryBean
, delegating to aorg.infinispan.Cache
configurable
.org.infinispan.manager.CacheContainer
- InfinispanDefaultCacheFactoryBean() - Constructor for class org.infinispan.spring.embedded.InfinispanDefaultCacheFactoryBean
- InfinispanEmbeddedCacheManagerBeanDefinitionParser - Class in org.infinispan.spring.common.config
- InfinispanEmbeddedCacheManagerBeanDefinitionParser() - Constructor for class org.infinispan.spring.common.config.InfinispanEmbeddedCacheManagerBeanDefinitionParser
- InfinispanEmbeddedCacheManagerFactoryBean - Class in org.infinispan.spring.embedded.support
-
A
for creating anFactoryBean
instance.Infinispan EmbeddedCacheManager
- InfinispanEmbeddedCacheManagerFactoryBean() - Constructor for class org.infinispan.spring.embedded.support.InfinispanEmbeddedCacheManagerFactoryBean
- InfinispanEmbeddedHttpSessionConfiguration - Class in org.infinispan.spring.embedded.session.configuration
- InfinispanEmbeddedHttpSessionConfiguration() - Constructor for class org.infinispan.spring.embedded.session.configuration.InfinispanEmbeddedHttpSessionConfiguration
- InfinispanEmbeddedSessionRepository - Class in org.infinispan.spring.embedded.session
-
Session Repository for Infinispan in Embedded mode.
- InfinispanEmbeddedSessionRepository(SpringCache) - Constructor for class org.infinispan.spring.embedded.session.InfinispanEmbeddedSessionRepository
-
Creates new repository based on
SpringCache
- InfinispanEventContextMessages - Interface in org.infinispan.search.mapper.log.impl
-
Message bundle for event contexts in the Infinispan Search mapper.
- InfinispanEventContextMessages_$bundle - Class in org.infinispan.search.mapper.log.impl
-
Warning this class consists of generated code.
- InfinispanEventContextMessages_$bundle() - Constructor for class org.infinispan.search.mapper.log.impl.InfinispanEventContextMessages_$bundle
- InfinispanIndexedTypeContext<E> - Interface in org.infinispan.search.mapper.session.impl
- InfinispanLoadingContext<E> - Class in org.infinispan.search.mapper.search.loading.context.impl
- InfinispanLoadingContext(PojoSelectionEntityLoader<E>) - Constructor for class org.infinispan.search.mapper.search.loading.context.impl.InfinispanLoadingContext
- InfinispanLoadingContext.Builder<E> - Class in org.infinispan.search.mapper.search.loading.context.impl
- InfinispanLock - Class in org.infinispan.util.concurrent.locks.impl
-
A special lock for Infinispan cache.
- InfinispanLock(Executor, TimeService) - Constructor for class org.infinispan.util.concurrent.locks.impl.InfinispanLock
-
Creates a new instance.
- InfinispanLock(Executor, TimeService, Runnable) - Constructor for class org.infinispan.util.concurrent.locks.impl.InfinispanLock
-
Creates a new instance.
- InfinispanMapperDelegate - Class in org.infinispan.search.mapper.mapping.impl
- InfinispanMapperDelegate(PojoSelectionEntityLoader<?>, EntityConverter, BlockingManager, NonBlockingManager) - Constructor for class org.infinispan.search.mapper.mapping.impl.InfinispanMapperDelegate
- InfinispanMapping - Class in org.infinispan.search.mapper.mapping.impl
- InfinispanMappingInitiator - Class in org.infinispan.search.mapper.impl
- InfinispanMappingInitiator(PojoBootstrapIntrospector, Collection<ProgrammaticSearchMappingProvider>, BlockingManager, NonBlockingManager) - Constructor for class org.infinispan.search.mapper.impl.InfinispanMappingInitiator
- InfinispanMappingKey - Class in org.infinispan.search.mapper.mapping.impl
- InfinispanMappingKey() - Constructor for class org.infinispan.search.mapper.mapping.impl.InfinispanMappingKey
- InfinispanMappingPartialBuildState - Class in org.infinispan.search.mapper.mapping.impl
- InfinispanModule - Annotation Type in org.infinispan.factories.annotations
-
Mechanism for specifying the name and dependencies of Infinispan modules.
- InfinispanNamedEmbeddedCacheFactoryBean<K,
V> - Class in org.infinispan.spring.embedded.support -
A
for creating a nativeFactoryBean
named
Infinispan
, delegating to aorg.infinispan.Cache
configurable
.org.infinispan.manager.EmbeddedCacheManager
- InfinispanNamedEmbeddedCacheFactoryBean() - Constructor for class org.infinispan.spring.embedded.support.InfinispanNamedEmbeddedCacheFactoryBean
- InfinispanNamedRemoteCacheFactoryBean<K,
V> - Class in org.infinispan.spring.remote.support -
A
for creating a nativeFactoryBean
named
Infinispan
, delegating to aorg.infinispan.Cache
configurable
.oorg.infinispan.client.hotrod.RemoteCacheManagerr
- InfinispanNamedRemoteCacheFactoryBean() - Constructor for class org.infinispan.spring.remote.support.InfinispanNamedRemoteCacheFactoryBean
- InfinispanNamespaceHandler - Class in org.infinispan.spring.common.config
-
NamespaceHandler
for Infinispan-based caches. - InfinispanNamespaceHandler() - Constructor for class org.infinispan.spring.common.config.InfinispanNamespaceHandler
- InfinispanNamespaceUtils - Class in org.infinispan.spring.common.config
- InfinispanNamespaceUtils() - Constructor for class org.infinispan.spring.common.config.InfinispanNamespaceUtils
- InfinispanQueryStatisticsInfo - Class in org.infinispan.query.impl
-
This MBean exposes the query statistics from the Hibernate Search's SearchIntegrator Statistics object via delegation.
- InfinispanRemoteCacheManagerBeanDefinitionParser - Class in org.infinispan.spring.common.config
- InfinispanRemoteCacheManagerBeanDefinitionParser() - Constructor for class org.infinispan.spring.common.config.InfinispanRemoteCacheManagerBeanDefinitionParser
- InfinispanRemoteCacheManagerFactoryBean - Class in org.infinispan.spring.remote.support
-
A
for creating anFactoryBean
instance.Infinispan RemoteCacheManager
- InfinispanRemoteCacheManagerFactoryBean() - Constructor for class org.infinispan.spring.remote.support.InfinispanRemoteCacheManagerFactoryBean
- InfinispanRemoteHttpSessionConfiguration - Class in org.infinispan.spring.remote.session.configuration
- InfinispanRemoteHttpSessionConfiguration() - Constructor for class org.infinispan.spring.remote.session.configuration.InfinispanRemoteHttpSessionConfiguration
- InfinispanRemoteSessionRepository - Class in org.infinispan.spring.remote.session
-
Session Repository for Infinispan in client/server mode.
- InfinispanRemoteSessionRepository(SpringCache) - Constructor for class org.infinispan.spring.remote.session.InfinispanRemoteSessionRepository
-
Creates new repository based on
SpringCache
- InfinispanRuntimeIntrospector - Class in org.infinispan.search.mapper.model.impl
- InfinispanRuntimeIntrospector() - Constructor for class org.infinispan.search.mapper.model.impl.InfinispanRuntimeIntrospector
- InfinispanSearchSession - Class in org.infinispan.search.mapper.session.impl
- InfinispanSearchSession(InfinispanSearchSessionMappingContext, PojoSelectionEntityLoader<?>, InfinispanTypeContextProvider) - Constructor for class org.infinispan.search.mapper.session.impl.InfinispanSearchSession
- InfinispanSearchSessionMappingContext - Interface in org.infinispan.search.mapper.session.impl
- InfinispanSession(MapSession, boolean) - Constructor for class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository.InfinispanSession
- InfinispanSimpleStringSetPojoPathFilterFactory - Class in org.infinispan.search.mapper.model.impl
-
A factory for filters expecting a simple string representation of dirty paths, in the form "propertyA.propertyB.propertyC".
- InfinispanSimpleStringSetPojoPathFilterFactory() - Constructor for class org.infinispan.search.mapper.model.impl.InfinispanSimpleStringSetPojoPathFilterFactory
- InfinispanTypeContextProvider - Interface in org.infinispan.search.mapper.session.impl
- INFINITE - Enum constant in enum org.infinispan.server.hotrod.TimeUnitValue
- INFINITE_LIFESPAN - Static variable in class org.infinispan.server.hotrod.Constants
- INFINITE_MAXIDLE - Static variable in class org.infinispan.server.hotrod.Constants
- INFO - Enum constant in enum org.infinispan.security.AuditResponse
- INFORMIX - Enum constant in enum org.infinispan.persistence.jdbc.common.DatabaseType
- inheritable(boolean) - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
-
Whether this role should be implicitly inherited by secure caches which don't define their roles.
- inheritable(boolean) - Method in interface org.infinispan.configuration.global.GlobalRolesConfigurationChildBuilder
- init() - Static method in class org.infinispan.commons.maven.MavenSettings
- init() - Method in class org.infinispan.container.impl.EntryFactoryImpl
- init() - Method in class org.infinispan.server.core.backup.BackupManagerImpl
- init() - Method in interface org.infinispan.server.core.BackupManager
-
Performs initialisation of all resources required by the implementation before backup files can be created or restored.
- init() - Method in class org.infinispan.spring.common.config.InfinispanNamespaceHandler
- init(boolean, boolean, boolean, boolean) - Method in class org.infinispan.transaction.xa.TransactionFactory
- init(JavaType) - Method in class org.infinispan.server.core.dataconversion.json.SecureTypeIdResolver
-
Deprecated.
- init(String, GlobalConfiguration, Configuration, GlobalSecurityManager) - Method in class org.infinispan.security.impl.AuthorizationManagerImpl
- init(Path) - Static method in class org.infinispan.commons.maven.MavenSettings
- init(Cache<K, V>) - Method in interface org.infinispan.configuration.cache.CustomFailurePolicy
-
Invoked during the initialization phase.
- init(OperationsFactory, Configuration) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- init(OperationsFactory, Configuration) - Method in interface org.infinispan.client.hotrod.impl.InternalRemoteCache
- init(OperationsFactory, Configuration) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
-
Inititalize without mbeans
- init(OperationsFactory, Configuration, ObjectName) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- init(OperationsFactory, Configuration, ObjectName) - Method in interface org.infinispan.client.hotrod.impl.InternalRemoteCache
- init(OperationsFactory, Configuration, ObjectName) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- init(HashConfiguration) - Method in class org.infinispan.distribution.ch.impl.HashFunctionPartitioner
- init(HashConfiguration) - Method in interface org.infinispan.distribution.ch.KeyPartitioner
-
Initialization.
- init(GlobalConfiguration) - Method in class org.infinispan.stats.impl.LocalContainerStatsImpl
- init(GlobalConfiguration) - Method in class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
- init(GlobalConfiguration) - Method in class org.infinispan.transaction.lookup.WildflyTransactionManagerLookup
- init(GlobalConfiguration, EmbeddedCacheManager, Authorizer) - Method in class org.infinispan.security.impl.GlobalSecurityManagerImpl
- init(KeyPartitioner) - Method in class org.infinispan.distribution.ch.impl.HashFunctionPartitioner
- init(KeyPartitioner) - Method in interface org.infinispan.distribution.ch.KeyPartitioner
- init(ComponentRegistry) - Method in interface org.infinispan.commands.VisitableCommand
- init(ComponentRegistry, boolean) - Method in interface org.infinispan.commands.InitializableCommand
-
Deprecated.
- init(EmbeddedCacheManager, GlobalConfiguration) - Method in class org.infinispan.stats.impl.ClusterContainerStatsImpl
- init(InitializationContext) - Method in class org.infinispan.persistence.cluster.ClusterLoader
-
Deprecated.
- init(InitializationContext) - Method in interface org.infinispan.persistence.spi.CacheLoader
-
Deprecated.Used to initialize a cache loader.
- init(InitializationContext) - Method in interface org.infinispan.persistence.spi.CacheWriter
-
Deprecated.Used to initialize a cache loader.
- init(InitializationContext) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- init(InitializationContext) - Method in class org.infinispan.persistence.support.DelegatingCacheLoader
- init(InitializationContext) - Method in class org.infinispan.persistence.support.DelegatingCacheWriter
- init(RpcManager, CommandsFactory, ComponentRef<TransactionTable>, TransactionCoordinator, TransactionFactory) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
- init(RestServer) - Method in interface org.infinispan.rest.authentication.Authenticator
-
Invoked by the
RestServer
on startup. - init(RestServer) - Method in class org.infinispan.rest.authentication.impl.BasicAuthenticator
- initChannel() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- initChannel(Channel) - Method in class org.infinispan.server.core.transport.NettyInitializers
- initChunkSizeFromMetadata() - Method in class org.infinispan.io.GridFile
-
Deprecated.
- initGroup() - Method in class org.infinispan.jmx.CacheJmxRegistration
- initGroup() - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
- INITIAL_CLUSTER_SIZE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- INITIAL_CLUSTER_SIZE - Static variable in class org.infinispan.configuration.global.TransportConfiguration
- INITIAL_CLUSTER_TIMEOUT - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- INITIAL_CLUSTER_TIMEOUT - Static variable in class org.infinispan.configuration.global.TransportConfiguration
- INITIAL_CONNECTION_ATTEMPTS - Static variable in class org.infinispan.topology.ClusterTopologyManagerImpl
- INITIAL_REBALANCE_ID - Static variable in class org.infinispan.topology.ClusterCacheStatus
- INITIAL_SIZE - Static variable in class org.infinispan.container.offheap.OffHeapConcurrentMap
- INITIAL_STATE_REQUEST - Enum constant in enum org.infinispan.xsite.events.XSiteEventType
-
When a cache 'c' starts in site A and has site B as asynchronous backup, this event is sent from site A to site B to notify site B to send state (automatic cross-site state transfer must be enabled).
- INITIAL_TOPOLOGY_ID - Static variable in class org.infinispan.topology.ClusterCacheStatus
- INITIAL_VALUE - Enum constant in enum org.infinispan.counter.configuration.Attribute
- initialClusterSize() - Method in class org.infinispan.configuration.global.TransportConfiguration
- initialClusterSize(int) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
-
Sets the number of nodes that need to join before the cache container can start.
- initialClusterTimeout() - Method in class org.infinispan.configuration.global.TransportConfiguration
- initialClusterTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
-
Sets the timeout for the initial cluster to form.
- InitializableCommand - Interface in org.infinispan.commands
-
Deprecated, for removal: This API element is subject to removal in a future version.since 11.0, please implement
ReplicableCommand#invokeAsync(ComponentRegistry)
instead - InitializationContext - Interface in org.infinispan.persistence.spi
-
Aggregates the initialisation state needed by either a
CacheLoader
or aCacheWriter
. - InitializationContextImpl - Class in org.infinispan.persistence
- InitializationContextImpl(StoreConfiguration, Cache, KeyPartitioner, PersistenceMarshaller, TimeService, ByteBufferFactory, MarshallableEntryFactory, Executor, GlobalConfiguration, BlockingManager, NonBlockingManager) - Constructor for class org.infinispan.persistence.InitializationContextImpl
- initialize() - Method in interface org.infinispan.commons.configuration.attributes.AttributeInitializer
- initialize(AdvancedCache<?, ?>) - Method in class org.infinispan.query.impl.QueryDefinition
- initialize(RemoteCacheManager, boolean) - Method in class org.infinispan.client.hotrod.DataFormat
-
Deprecated, for removal: This API element is subject to removal in a future version.
- initialize(RemoteCacheManager, String, boolean) - Method in class org.infinispan.client.hotrod.DataFormat
- initialize(ClassAllowList) - Method in class org.infinispan.commons.marshall.JavaSerializationMarshaller
- initialize(ClassAllowList) - Method in interface org.infinispan.commons.marshall.Marshaller
-
An optional method which allows an implementation to respect the
ClassAllowList
associated with the context, for example the EmbeddedCacheManager or RemoteCacheManager. - initialize(ClassAllowList) - Method in class org.infinispan.jboss.marshalling.commons.GenericJBossMarshaller
- initialize(GlobalComponentRegistry) - Method in class org.infinispan.jboss.marshalling.core.JBossUserMarshaller
- initialize(EmbeddedCacheManager, ConfigurationManager, BlockingManager) - Method in class org.infinispan.globalstate.impl.ImmutableLocalConfigurationStorage
- initialize(EmbeddedCacheManager, ConfigurationManager, BlockingManager) - Method in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
- initialize(EmbeddedCacheManager, ConfigurationManager, BlockingManager) - Method in interface org.infinispan.globalstate.LocalConfigurationStorage
-
Initialization entry point for the
LocalConfigurationStorage
- initializeChannel(Channel) - Method in class org.infinispan.rest.RestChannelInitializer
- initializeChannel(Channel) - Method in class org.infinispan.server.core.transport.NettyChannelInitializer
- initializeChannel(Channel) - Method in interface org.infinispan.server.core.transport.NettyInitializer
-
Initialize netty channel
- initializeChannel(Channel) - Method in class org.infinispan.server.hotrod.transport.TimeoutEnabledChannelInitializer
- initializeHandler(ChannelInitializer<Channel>) - Method in class org.infinispan.server.core.transport.NettyTransport
- initializer() - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
- initializer(AttributeInitializer<? extends T>) - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition.Builder
- initializeReplicableCommand(ReplicableCommand, boolean) - Method in interface org.infinispan.commands.CommandsFactory
-
Deprecated, for removal: This API element is subject to removal in a future version.since 11.0, please use
CacheRpcCommand.invokeAsync(ComponentRegistry)
orGlobalRpcCommand.invokeAsync(GlobalComponentRegistry)
instead. to access any components required at invocation time. - initializeReplicableCommand(ReplicableCommand, boolean) - Method in class org.infinispan.commands.CommandsFactoryImpl
- INITIALIZING - Enum constant in enum org.infinispan.health.HealthStatus
-
The given entity is still initializing.
- INITIALIZING - Enum constant in enum org.infinispan.lifecycle.ComponentStatus
-
The
start()
method has been called but not yet completed. - INITIALIZING - Enum constant in enum org.infinispan.topology.ClusterTopologyManager.ClusterManagerStatus
- initialPriority() - Method in class org.infinispan.factories.threads.DefaultThreadFactory
- initialValue() - Method in class org.infinispan.counter.api.CounterConfiguration
- initialValue() - Method in class org.infinispan.counter.configuration.AbstractCounterConfiguration
- initialValue(long) - Method in class org.infinispan.counter.api.CounterConfiguration.Builder
-
Sets the initial value.
- initialValue(long) - Method in class org.infinispan.counter.configuration.StrongCounterConfigurationBuilder
- initialValue(long) - Method in interface org.infinispan.counter.configuration.CounterConfigurationBuilder
-
Sets the counter's initial value.
- initiatingBackup(String) - Method in interface org.infinispan.server.core.logging.Log
- initiatingRestore(String, Path) - Method in interface org.infinispan.server.core.logging.Log
- initTime - Variable in class org.infinispan.extendedstats.TransactionStatistics
- inject(ExecutorService) - Method in class org.infinispan.reactive.publisher.impl.LocalPublisherManagerImpl
-
Injects the cache - unfortunately this cannot be in start.
- inject(ScheduledExecutorService, Executor) - Method in class org.infinispan.xsite.irac.DefaultIracManager
- inject(ComponentRegistry) - Method in class org.infinispan.distribution.group.impl.CacheEntryGroupPredicate
- inject(ComponentRegistry) - Method in class org.infinispan.server.hotrod.tx.table.functions.TxFunction
- inject(ComponentRegistry) - Method in class org.infinispan.stream.impl.CacheIntermediatePublisher
- inject(ComponentRegistry) - Method in class org.infinispan.stream.impl.CacheStreamIntermediateReducer
- Inject - Annotation Type in org.infinispan.factories.annotations
-
Used to annotate a method or field as an injection point.
- injectCache(Cache<K, V>) - Method in interface org.infinispan.stream.CacheAware
-
Method that is invoked when a cache is to be injected.
- injectDependencies(Cache, EncoderRegistry) - Method in class org.infinispan.server.hotrod.iteration.IterationFilter
- injectDependencies(ComponentRegistry) - Method in class org.infinispan.cache.impl.BiFunctionMapper
- injectDependencies(ComponentRegistry) - Method in class org.infinispan.cache.impl.EncoderEntryMapper
- injectDependencies(ComponentRegistry) - Method in class org.infinispan.cache.impl.EncoderKeyMapper
- injectDependencies(ComponentRegistry) - Method in class org.infinispan.cache.impl.EncoderValueMapper
- injectDependencies(ComponentRegistry) - Method in class org.infinispan.cache.impl.FunctionMapper
- injectDependencies(ComponentRegistry) - Method in class org.infinispan.filter.CompositeKeyValueFilter
- injectDependencies(ComponentRegistry) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventConverterAsConverter
- injectDependencies(ComponentRegistry) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterAsKeyValueFilter
- injectDependencies(ComponentRegistry) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverterAsKeyValueFilterConverter
- injectDependencies(ComponentRegistry) - Method in class org.infinispan.notifications.cachelistener.filter.CompositeCacheEventFilter
- injectDependencies(ComponentRegistry) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterAsCacheEventFilter
- injectDependencies(ComponentRegistry) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter
- InjectiveFunction<T,
R> - Interface in org.infinispan.commons.util -
This is a marker interface to be used with
Function
which signals to some implementors that the function returns distinct values. - injectSpanContext(HeaderParams) - Method in interface org.infinispan.client.hotrod.telemetry.impl.TelemetryService
- injectSpanContext(HeaderParams) - Method in class org.infinispan.client.hotrod.telemetry.impl.TelemetryServiceImpl
- InnerPublisherSubscription<K,
I, R, E> - Class in org.infinispan.reactive.publisher.impl -
Handles the submission and response handling of an arbitrary amount of address segments.
- InnerPublisherSubscription.InnerPublisherSubscriptionBuilder<K,
I, R> - Class in org.infinispan.reactive.publisher.impl - InnerPublisherSubscriptionBuilder(ClusterPublisherManagerImpl.SubscriberHandler<I, R>, int, Supplier<Map.Entry<Address, IntSet>>, Map<Address, Set<K>>, int) - Constructor for class org.infinispan.reactive.publisher.impl.InnerPublisherSubscription.InnerPublisherSubscriptionBuilder
- inputEncoding - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- inputStream - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- inScope(Enum<?>) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
- inScope(String) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
- INSERT_ABOVE - Enum constant in enum org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.StackCombine
- INSERT_AFTER - Enum constant in enum org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.StackCombine
- INSERT_BEFORE - Enum constant in enum org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.StackCombine
- INSERT_BELOW - Enum constant in enum org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.StackCombine
- insertSample(double) - Method in class org.infinispan.extendedstats.percentiles.ReservoirSampler
- instance() - Static method in class org.infinispan.server.hotrod.Encoder4x
- INSTANCE - Enum constant in enum org.infinispan.commons.executors.CachedThreadPoolExecutorFactory
- INSTANCE - Enum constant in enum org.infinispan.commons.executors.ScheduledThreadPoolExecutorFactory
- INSTANCE - Enum constant in enum org.infinispan.commons.tx.DefaultResourceConverter
- INSTANCE - Enum constant in enum org.infinispan.lock.api.OwnershipLevel
- INSTANCE - Enum constant in enum org.infinispan.remoting.transport.impl.EmptyRaftManager
- INSTANCE - Enum constant in enum org.infinispan.xsite.irac.NoOpIracManager
- INSTANCE - Static variable in class org.infinispan.client.hotrod.marshall.BytesOnlyMarshaller
- INSTANCE - Static variable in class org.infinispan.client.hotrod.near.DefaultNearCacheFactory
- INSTANCE - Static variable in class org.infinispan.client.hotrod.telemetry.impl.TelemetryServiceFactory
- INSTANCE - Static variable in class org.infinispan.commons.configuration.attributes.CopyConstructorAttributeCopier
- INSTANCE - Static variable in class org.infinispan.commons.configuration.attributes.SimpleInstanceAttributeCopier
- INSTANCE - Static variable in class org.infinispan.commons.configuration.attributes.TypedPropertiesAttributeCopier
- INSTANCE - Static variable in class org.infinispan.commons.dataconversion.ByteArrayWrapper
- INSTANCE - Static variable in class org.infinispan.commons.dataconversion.IdentityEncoder
-
Deprecated.
- INSTANCE - Static variable in class org.infinispan.commons.dataconversion.IdentityWrapper
- INSTANCE - Static variable in class org.infinispan.commons.dataconversion.UTF8Encoder
-
Deprecated.
- INSTANCE - Static variable in interface org.infinispan.commons.GlobalContextInitializer
- INSTANCE - Static variable in class org.infinispan.commons.marshall.IdentityMarshaller
- INSTANCE - Static variable in class org.infinispan.commons.time.DefaultTimeService
- INSTANCE - Static variable in class org.infinispan.context.impl.ImmutableContext
- INSTANCE - Static variable in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
- INSTANCE - Static variable in class org.infinispan.marshall.exts.EnumExternalizer
- INSTANCE - Static variable in class org.infinispan.marshall.exts.ThrowableExternalizer
- INSTANCE - Static variable in class org.infinispan.remoting.responses.CacheNotFoundResponse
- INSTANCE - Static variable in class org.infinispan.remoting.responses.UnsureResponse
- INSTANCE - Static variable in class org.infinispan.remoting.transport.impl.PassthroughSingleResponseCollector
- INSTANCE - Static variable in class org.infinispan.remoting.transport.jgroups.NoOpJGroupsMetricManager
- INSTANCE - Static variable in class org.infinispan.remoting.transport.LocalModeAddress
- INSTANCE - Static variable in class org.infinispan.rest.logging.Messages_$bundle
- INSTANCE - Static variable in class org.infinispan.scripting.logging.Messages_$bundle
- INSTANCE - Static variable in class org.infinispan.search.mapper.log.impl.InfinispanEventContextMessages_$bundle
- INSTANCE - Static variable in class org.infinispan.topology.HeartBeatCommand
- INSTANCE - Static variable in class org.infinispan.transaction.lookup.GenericTransactionManagerLookup
- INSTANCE - Static variable in class org.infinispan.xsite.commands.remote.XSiteRequestExternalizer
- INSTANCE - Static variable in class org.infinispan.xsite.events.NoOpXSiteEventsManager
- INSTANCE_CLASS_NAME - Static variable in interface org.infinispan.commons.configuration.attributes.AttributeSerializer
- instanceFromString(String, ClassLoader) - Static method in enum org.infinispan.xsite.spi.XSiteMergePolicy
- InstanceReusingAdvancedExternalizer<T> - Class in org.infinispan.commons.marshall
-
An advanced externalizer that when implemented will allow for child instances that also extend this class to use object instances instead of serializing a brand new object.
- InstanceReusingAdvancedExternalizer() - Constructor for class org.infinispan.commons.marshall.InstanceReusingAdvancedExternalizer
- InstanceReusingAdvancedExternalizer(boolean) - Constructor for class org.infinispan.commons.marshall.InstanceReusingAdvancedExternalizer
- InstanceSupplier<T> - Class in org.infinispan.commons.util
- InstanceSupplier(T) - Constructor for class org.infinispan.commons.util.InstanceSupplier
- instant() - Method in class org.infinispan.commons.time.DefaultTimeService
- instant() - Method in interface org.infinispan.commons.time.TimeService
- INSTANTIATED - Enum constant in enum org.infinispan.lifecycle.ComponentStatus
-
Object has been instantiated, but start() has not been called.
- INT - Enum constant in enum org.infinispan.stream.impl.IntermediateType
- INT_32 - Enum constant in enum org.infinispan.persistence.sql.AbstractSchemaJdbcStore.ProtostreamFieldType
- INT_64 - Enum constant in enum org.infinispan.persistence.sql.AbstractSchemaJdbcStore.ProtostreamFieldType
- INT_SET - Static variable in interface org.infinispan.commons.marshall.Ids
- INT_SUMMARY_STATISTICS - Static variable in interface org.infinispan.commons.marshall.Ids
- inTag() - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
- inTag(Enum<?>) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
- inTag(String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
- intCacheStream() - Method in class org.infinispan.stream.impl.DistributedCacheStream
- intCacheStream() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- intCacheStream() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- IntCacheStream - Interface in org.infinispan
-
A
IntStream
that has additional methods to allow for Serializable instances. - Integer(int) - Constructor for class org.infinispan.commons.util.ByRef.Integer
- INTELLIGENCE_BASIC - Static variable in class org.infinispan.server.hotrod.Constants
- INTELLIGENCE_HASH_DISTRIBUTION_AWARE - Static variable in class org.infinispan.server.hotrod.Constants
- INTELLIGENCE_TOPOLOGY_AWARE - Static variable in class org.infinispan.server.hotrod.Constants
- INTERBASE - Enum constant in enum org.infinispan.persistence.jdbc.common.DatabaseType
- interceptListenerInvocation(CacheEntryListenerInvocation<K, V>) - Method in interface org.infinispan.notifications.cachelistener.filter.FilterIndexingServiceProvider
-
Starts handling an invocation that uses an
IndexedFilter
. - interceptor(AsyncInterceptor) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
-
Deprecated.An instance of the new custom interceptor to add to the configuration.
- INTERCEPTOR - Enum constant in enum org.infinispan.configuration.parsing.Element
- INTERCEPTOR - Static variable in class org.infinispan.configuration.cache.InterceptorConfiguration
- INTERCEPTOR_CLASS - Static variable in class org.infinispan.configuration.cache.InterceptorConfiguration
- InterceptorChainFactory - Class in org.infinispan.factories
-
Factory class that builds an interceptor chain based on cache configuration.
- InterceptorChainFactory() - Constructor for class org.infinispan.factories.InterceptorChainFactory
- interceptorClass(Class<? extends AsyncInterceptor>) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
-
Deprecated.Class of the new custom interceptor to add to the configuration.
- InterceptorConfiguration - Class in org.infinispan.configuration.cache
-
Describes a custom interceptor
- InterceptorConfiguration.Position - Enum in org.infinispan.configuration.cache
-
Positional placing of a new custom interceptor
- InterceptorConfigurationBuilder - Class in org.infinispan.configuration.cache
-
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
- interceptors() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfiguration
-
Deprecated.This specifies a list of
InterceptorConfiguration
instances to be referenced when building the interceptor chain. - interceptors(List<InterceptorConfiguration>) - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfiguration
-
Deprecated.
- INTERMEDIATE_OPERATIONS - Static variable in interface org.infinispan.commons.marshall.Ids
- IntermediateCacheStream<Original,
R> - Class in org.infinispan.stream.impl -
An intermediate cache stream used when an intermediate operation that requires both a remote and local portion
- IntermediateCacheStream(BaseCacheStream, IntermediateType, LocalCacheStream<R>, IntermediateCacheStreamSupplier) - Constructor for class org.infinispan.stream.impl.IntermediateCacheStream
- IntermediateCacheStream(DistributedCacheStream<Original, R>) - Constructor for class org.infinispan.stream.impl.IntermediateCacheStream
- IntermediateDoubleCacheStream - Class in org.infinispan.stream.impl
-
An intermediate double cache stream used when an intermediate operation that requires both a remote and local portion
- IntermediateDoubleCacheStream(BaseCacheStream, IntermediateType, LocalDoubleCacheStream, IntermediateCacheStreamSupplier) - Constructor for class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- IntermediateDoubleCacheStream(DistributedDoubleCacheStream) - Constructor for class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- IntermediateIntCacheStream - Class in org.infinispan.stream.impl
-
An intermediate int cache stream used when an intermediate operation that requires both a remote and local portion
- IntermediateIntCacheStream(BaseCacheStream, IntermediateType, LocalIntCacheStream, IntermediateCacheStreamSupplier) - Constructor for class org.infinispan.stream.impl.IntermediateIntCacheStream
- IntermediateIntCacheStream(DistributedIntCacheStream) - Constructor for class org.infinispan.stream.impl.IntermediateIntCacheStream
- IntermediateLongCacheStream - Class in org.infinispan.stream.impl
-
An intermediate long cache stream used when an intermediate operation that requires both a remote and local portion
- IntermediateLongCacheStream(BaseCacheStream, IntermediateType, LocalLongCacheStream, IntermediateCacheStreamSupplier) - Constructor for class org.infinispan.stream.impl.IntermediateLongCacheStream
- IntermediateLongCacheStream(DistributedLongCacheStream) - Constructor for class org.infinispan.stream.impl.IntermediateLongCacheStream
- intermediateOperations - Variable in class org.infinispan.stream.impl.AbstractCacheStream
- IntermediateType - Enum in org.infinispan.stream.impl
-
The various intermediate types.
- INTERNAL_ENUMS - Static variable in interface org.infinispan.commons.marshall.Ids
- INTERNAL_MARSHALLER - Static variable in class org.infinispan.factories.KnownComponentNames
- INTERNAL_METADATA_ID - Static variable in interface org.infinispan.commons.marshall.Ids
- InternalCacheEntry<K,
V> - Interface in org.infinispan.container.entries -
Interface for internal cache entries that expose whether an entry has expired.
- InternalCacheFactory<K,
V> - Class in org.infinispan.factories -
An internal factory for constructing Caches.
- InternalCacheFactory() - Constructor for class org.infinispan.factories.InternalCacheFactory
- internalCacheHasFlag(String, InternalCacheRegistry.Flag) - Method in class org.infinispan.registry.impl.InternalCacheRegistryImpl
- InternalCacheRegistryImpl - Class in org.infinispan.registry.impl
-
InternalCacheRegistryImpl.
- InternalCacheRegistryImpl() - Constructor for class org.infinispan.registry.impl.InternalCacheRegistryImpl
- InternalCacheSet<E> - Class in org.infinispan
-
Base class for internal classes used in cache collections.
- InternalCacheSet() - Constructor for class org.infinispan.InternalCacheSet
- InternalCacheValue<V> - Interface in org.infinispan.container.entries
-
A representation of an InternalCacheEntry that does not have a reference to the key.
- InternalDataContainer<K,
V> - Interface in org.infinispan.container.impl -
Interface describing methods of a data container where operations can be indexed by the segment of the key stored in the map.
- InternalEntryFactory - Interface in org.infinispan.container.impl
-
A factory for
InternalCacheEntry
andInternalCacheValue
instances. - InternalEntryFactoryImpl - Class in org.infinispan.container.impl
-
An implementation that generates non-versioned entries
- InternalEntryFactoryImpl() - Constructor for class org.infinispan.container.impl.InternalEntryFactoryImpl
- InternalExpirationManager<K,
V> - Interface in org.infinispan.expiration.impl -
Interface describing the internal operations for the the ExpirationManager.
- InternalExpirationManager.ExpirationConsumer<T,
U> - Interface in org.infinispan.expiration.impl - internalMetadata - Variable in class org.infinispan.container.entries.AbstractInternalCacheEntry
- internalMetadata - Variable in class org.infinispan.container.entries.ImmortalCacheValue
- internalMetadata - Variable in class org.infinispan.container.entries.ReadCommittedEntry
- internalMetadata() - Method in class org.infinispan.xsite.statetransfer.XSiteState
- InternalMetadata - Interface in org.infinispan.metadata
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.0
- InternalMetadataImpl - Class in org.infinispan.metadata.impl
-
Deprecated, for removal: This API element is subject to removal in a future version.
- InternalMetadataImpl() - Constructor for class org.infinispan.metadata.impl.InternalMetadataImpl
-
Deprecated.
- InternalMetadataImpl(InternalCacheEntry) - Constructor for class org.infinispan.metadata.impl.InternalMetadataImpl
-
Deprecated.
- InternalMetadataImpl(InternalCacheValue) - Constructor for class org.infinispan.metadata.impl.InternalMetadataImpl
-
Deprecated.
- InternalMetadataImpl(Metadata, long, long) - Constructor for class org.infinispan.metadata.impl.InternalMetadataImpl
-
Deprecated.
- InternalMetadataImpl.Externalizer - Class in org.infinispan.metadata.impl
-
Deprecated.
- internalMetadataLength() - Method in class org.infinispan.persistence.sifs.EntryHeader
- InternalRemoteCache<K,
V> - Interface in org.infinispan.client.hotrod.impl - interpretPaths(Set<String>, Set<PojoModelPathValueNode>) - Method in class org.infinispan.search.mapper.model.impl.InfinispanSimpleStringSetPojoPathFilterFactory
- interruptedWhileClearing(InterruptedException) - Method in interface org.infinispan.persistence.sifs.Log
- interruptedWhileStopping(InterruptedException) - Method in interface org.infinispan.persistence.sifs.Log
- interruptedWhileWaitingForRequestCompletion(Exception) - Method in interface org.infinispan.query.logging.Log
- INTERVAL - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- Intrinsics - Class in org.infinispan.server.hotrod
- Intrinsics() - Constructor for class org.infinispan.server.hotrod.Intrinsics
- introspector(MethodHandles.Lookup) - Static method in class org.infinispan.search.mapper.mapping.SearchMappingBuilder
- IntSet - Interface in org.infinispan.commons.util
-
A set that represents primitive ints.
- IntSetExternalizer - Class in org.infinispan.util
-
Externalizer to be used for IntSet implementations
- IntSetExternalizer() - Constructor for class org.infinispan.util.IntSetExternalizer
- IntSets - Class in org.infinispan.commons.util
-
Static utility class for creating various
IntSet
objects. - IntSetsExternalization - Class in org.infinispan.commons.util
-
IntSets externalization mechanism
- intSpliterator() - Method in class org.infinispan.commons.util.ImmutableIntSet
-
Deprecated.
- intSpliterator() - Method in interface org.infinispan.commons.util.IntSet
-
Creates a
Spliterator.OfInt
over the ints in this set. - intSpliterator() - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- intSpliterator() - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- intStream() - Method in class org.infinispan.commons.util.ImmutableIntSet
-
Deprecated.
- intStream() - Method in interface org.infinispan.commons.util.IntSet
-
A stream of ints representing the data in this set
- intStream() - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- intStream() - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- IntSummaryStatisticsExternalizer - Class in org.infinispan.marshall.exts
-
Externalizer used for
IntSummaryStatistics
. - IntSummaryStatisticsExternalizer() - Constructor for class org.infinispan.marshall.exts.IntSummaryStatisticsExternalizer
- inUseBackupSites() - Method in class org.infinispan.configuration.cache.SitesConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.since 14.0. To be removed without replacement.
- INVALID_ACTION - Enum constant in enum org.infinispan.rest.framework.LookupResult.Status
-
A resource was found but the action parameter is missing or incorrect
- INVALID_CHAR - Static variable in class org.infinispan.commons.hash.MurmurHash3
- INVALID_METHOD - Enum constant in enum org.infinispan.rest.framework.LookupResult.Status
-
A resource was found but the Http Method is not allowed
- invalidActiveCountAfterClose(Channel) - Method in interface org.infinispan.client.hotrod.logging.Log
- invalidAllowedMechs(Set<String>, Set<String>) - Method in interface org.infinispan.server.hotrod.logging.Log
- invalidated() - Method in enum org.infinispan.client.hotrod.configuration.NearCacheMode
- INVALIDATED - Enum constant in enum org.infinispan.client.hotrod.configuration.NearCacheMode
-
Near cache is invalidated, so when entries are updated or removed server-side, invalidation messages will be sent to clients to remove them from the near cache.
- InvalidatedNearRemoteCache<K,
V> - Class in org.infinispan.client.hotrod.impl -
Near
RemoteCache
implementation enabling - invalidateNearDefaultMarshallerMismatch(String, Class<?>, MediaType) - Method in interface org.infinispan.client.hotrod.logging.Log
- INVALIDATION - Enum constant in enum org.infinispan.configuration.cache.CacheType
- INVALIDATION - Enum constant in enum org.infinispan.configuration.parsing.ParsedCacheMode
- INVALIDATION_ASYNC - Enum constant in enum org.infinispan.client.hotrod.DefaultTemplate
- INVALIDATION_ASYNC - Enum constant in enum org.infinispan.configuration.cache.CacheMode
-
Data invalidated asynchronously.
- INVALIDATION_BATCH_SIZE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- INVALIDATION_BATCH_SIZE - Static variable in class org.infinispan.configuration.cache.ClusteringConfiguration
- INVALIDATION_CACHE - Enum constant in enum org.infinispan.configuration.parsing.Element
- INVALIDATION_CACHE_CONFIGURATION - Enum constant in enum org.infinispan.configuration.parsing.Element
- INVALIDATION_CLEANUP_TASK_FREQUENCY - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- INVALIDATION_SYNC - Enum constant in enum org.infinispan.client.hotrod.DefaultTemplate
- INVALIDATION_SYNC - Enum constant in enum org.infinispan.configuration.cache.CacheMode
-
Data invalidated synchronously.
- INVALIDATION_THRESHOLD - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- INVALIDATION_THRESHOLD - Static variable in class org.infinispan.configuration.cache.L1Configuration
- invalidationBatchSize() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
-
For scattered cache, the threshold after which batched invalidations are sent
- invalidationBatchSize(int) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
-
For scattered cache, the threshold after which batched invalidations are sent
- invalidations - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
- invalidationThreshold() - Method in class org.infinispan.configuration.cache.L1Configuration
-
Determines whether a multicast or a web of unicasts are used when performing L1 invalidations.
- invalidationThreshold(int) - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
-
Determines whether a multicast or a web of unicasts are used when performing L1 invalidations.
- invalidAttributeValue(ConfigurationReader, int) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Get an exception reporting an invalid XML attribute value.
- invalidAuthenticationConfiguration() - Method in interface org.infinispan.client.hotrod.logging.Log
- InvalidCacheUsageException - Exception in org.infinispan
-
Thrown when client makes cache usage errors.
- InvalidCacheUsageException(String) - Constructor for exception org.infinispan.InvalidCacheUsageException
- InvalidCacheUsageException(String, Throwable) - Constructor for exception org.infinispan.InvalidCacheUsageException
- InvalidCacheUsageException(Throwable) - Constructor for exception org.infinispan.InvalidCacheUsageException
- invalidCharacterInSql(char, int, String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- invalidCompactionThreshold(double) - Method in interface org.infinispan.persistence.sifs.Log
- invalidConcurrencyLevel(int) - Method in interface org.infinispan.counter.logging.Log
- invalidContent() - Method in interface org.infinispan.rest.logging.Log
- invalidCounterType(String, String) - Method in interface org.infinispan.counter.logging.Log
- invalidCreatedCountAfterClose(Channel) - Method in interface org.infinispan.client.hotrod.logging.Log
- invalidEntityName(String) - Method in interface org.infinispan.search.mapper.log.impl.Log
- invalidEntitySuperType(String, Class<?>, Class<?>) - Method in interface org.infinispan.search.mapper.log.impl.Log
- invalidExpiration(String) - Method in interface org.infinispan.server.memcached.logging.Log
- InvalidFlagException - Exception in org.infinispan.rest.operations.exceptions
- InvalidFlagException(Throwable) - Constructor for exception org.infinispan.rest.operations.exceptions.InvalidFlagException
- invalidInitialValueForBoundedCounter(long, long, long) - Method in interface org.infinispan.counter.logging.Log
- InvalidIteration - Enum constant in enum org.infinispan.server.hotrod.OperationStatus
- invalidKey2StringMapper(String, String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- invalidMagicNumber(short, short) - Method in interface org.infinispan.client.hotrod.logging.Log
- InvalidMagicOrMsgId - Enum constant in enum org.infinispan.server.hotrod.OperationStatus
- invalidMaxRetries(int) - Method in interface org.infinispan.client.hotrod.logging.Log
- invalidMech(String) - Method in interface org.infinispan.server.hotrod.logging.Log
- invalidNumOwners(int) - Method in interface org.infinispan.counter.logging.Log
- invalidNumOwners(Integer) - Method in interface org.infinispan.lock.logging.Log
- invalidOperation() - Method in interface org.infinispan.server.hotrod.logging.Log
- invalidOrigin(String, String) - Method in interface org.infinispan.rest.logging.Log
- invalidPath(String) - Method in interface org.infinispan.rest.logging.Log
- invalidPersistentStorageMode() - Method in interface org.infinispan.counter.logging.Log
- invalidPropertyFormat(String) - Method in interface org.infinispan.client.hotrod.logging.Log
- invalidPropertyKey(Object) - Method in interface org.infinispan.query.logging.Log
- invalidReliabilityMode() - Method in interface org.infinispan.counter.logging.Log
- invalidReliabilityMode() - Method in interface org.infinispan.lock.logging.Log
- invalidResponse(String, short, double) - Method in interface org.infinispan.client.hotrod.logging.Log
- InvalidResponse - Class in org.infinispan.remoting.responses
-
An invalid response
- InvalidResponse() - Constructor for class org.infinispan.remoting.responses.InvalidResponse
- InvalidResponseException - Exception in org.infinispan.client.hotrod.exceptions
-
Signals an internal protocol error.
- InvalidResponseException() - Constructor for exception org.infinispan.client.hotrod.exceptions.InvalidResponseException
- InvalidResponseException(String) - Constructor for exception org.infinispan.client.hotrod.exceptions.InvalidResponseException
- InvalidResponseException(String, Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.InvalidResponseException
- InvalidResponseException(Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.InvalidResponseException
- invalidSameLowerAndUpperBound(long, long) - Method in interface org.infinispan.counter.logging.Log
- invalidScope(String) - Method in interface org.infinispan.counter.logging.Log
- invalidScope(String) - Method in interface org.infinispan.lock.logging.Log
- invalidStorageMode() - Method in interface org.infinispan.counter.logging.Log
- InvalidTransactionException - Exception in org.infinispan.transaction.xa
-
Thrown if an operation is to be performed on an invalid transaction context.
- InvalidTransactionException() - Constructor for exception org.infinispan.transaction.xa.InvalidTransactionException
- InvalidTransactionException(String) - Constructor for exception org.infinispan.transaction.xa.InvalidTransactionException
- InvalidTransactionException(String, Throwable) - Constructor for exception org.infinispan.transaction.xa.InvalidTransactionException
- InvalidTransactionException(Throwable) - Constructor for exception org.infinispan.transaction.xa.InvalidTransactionException
- invalidTransactionManagerLookup() - Method in interface org.infinispan.client.hotrod.logging.Log
- invalidTransactionMode() - Method in interface org.infinispan.client.hotrod.logging.Log
- invalidTransactionTimeout() - Method in interface org.infinispan.client.hotrod.logging.Log
- invalidTxServerConfig(String, Throwable) - Method in interface org.infinispan.client.hotrod.logging.Log
- invalidWeakCounter(String) - Method in interface org.infinispan.server.hotrod.logging.Log
- invocation - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
- invocation - Variable in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
- invocation() - Method in class org.infinispan.rest.framework.impl.InvocationImpl.Builder
- invocation() - Method in class org.infinispan.rest.framework.impl.Invocations.Builder
- Invocation - Interface in org.infinispan.rest.framework
-
Defines an invocation to a REST resource.
- invocationBatching() - Method in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
- invocationBatching() - Method in class org.infinispan.configuration.cache.Configuration
- invocationBatching() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- invocationBatching() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- InvocationBatchingConfiguration - Class in org.infinispan.configuration.cache
- InvocationBatchingConfigurationBuilder - Class in org.infinispan.configuration.cache
- InvocationCallback<C extends VisitableCommand> - Interface in org.infinispan.interceptors
-
Base interface for all callbacks used by
BaseAsyncInterceptor
andInvocationStage
methods. - invocationContext - Variable in class org.infinispan.stream.impl.AbstractCacheStream
- InvocationContext - Interface in org.infinispan.context
-
A context that contains information pertaining to a given invocation.
- invocationContextFactory - Variable in class org.infinispan.cache.impl.CacheImpl
- invocationContextFactory - Variable in class org.infinispan.cache.impl.InvocationHelper
- InvocationContextFactory - Interface in org.infinispan.context
-
Factory for
InvocationContext
objects. - InvocationExceptionFunction<C extends VisitableCommand> - Interface in org.infinispan.interceptors
- InvocationFinallyAction<C extends VisitableCommand> - Interface in org.infinispan.interceptors
- InvocationFinallyFunction<C extends VisitableCommand> - Interface in org.infinispan.interceptors
- invocationHandler - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- InvocationHelper - Class in org.infinispan.cache.impl
-
It invokes the
VisitableCommand
through this cacheAsyncInterceptorChain
. - InvocationHelper - Class in org.infinispan.rest
- InvocationHelper() - Constructor for class org.infinispan.cache.impl.InvocationHelper
- InvocationImpl - Class in org.infinispan.rest.framework.impl
- InvocationImpl.Builder - Class in org.infinispan.rest.framework.impl
- Invocations - Class in org.infinispan.rest.framework.impl
-
Aggregator for
Invocation
. - Invocations.Builder - Class in org.infinispan.rest.framework.impl
- InvocationStage - Class in org.infinispan.interceptors
-
A partial command invocation, either completed or in progress.
- InvocationStage() - Constructor for class org.infinispan.interceptors.InvocationStage
- InvocationSuccessAction<C extends VisitableCommand> - Interface in org.infinispan.interceptors
- InvocationSuccessFunction<C extends VisitableCommand> - Interface in org.infinispan.interceptors
- invoke() - Method in interface org.infinispan.commands.ReplicableCommand
-
Deprecated, for removal: This API element is subject to removal in a future version.since 11.0, please use
CacheRpcCommand.invokeAsync(ComponentRegistry)
orGlobalRpcCommand.invokeAsync(GlobalComponentRegistry)
instead. - invoke(A) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.ListenerInvocationImpl
- invoke(String, Object[], String[]) - Method in class org.infinispan.jmx.ResourceDMBean
- invoke(ContextBuilder, VisitableCommand, int) - Method in class org.infinispan.cache.impl.InvocationHelper
-
Same as
InvocationHelper.invoke(InvocationContext, VisitableCommand)
but usingbuilder
to build theInvocationContext
to use. - invoke(VisitableCommand, int) - Method in class org.infinispan.cache.impl.InvocationHelper
-
Same as
InvocationHelper.invoke(ContextBuilder, VisitableCommand, int)
but using the defaultContextBuilder
. - invoke(InvocationContext, VisitableCommand) - Method in class org.infinispan.cache.impl.InvocationHelper
-
Invokes the
command
usingcontext
. - invoke(InvocationContext, VisitableCommand) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
-
Walks the command through the interceptor chain.
- invoke(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
- invoke(Event<K, V>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
- invoke(Event<K, V>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.ClusteredListenerInvocation
- invoke(Event<K, V>) - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
- invoke(EventWrapper<K, V, CacheEntryEvent<K, V>>, boolean) - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
-
Invokes the event
- invoke(EventWrapper<K, V, CacheEntryEvent<K, V>>, boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
-
This is the entry point for local listeners firing events
- invoke(EventWrapper<K, V, CacheEntryEvent<K, V>>, boolean) - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
- invoke(T) - Method in interface org.infinispan.notifications.impl.ListenerInvocation
-
Invokes the event
- invokeAccessibly(Object, Method, Object...) - Static method in class org.infinispan.commons.util.ReflectionUtil
-
Invokes a method using reflection, in an accessible manner (by using
Method.setAccessible(boolean)
- invokeAll(Collection<? extends Callable<T>>) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
- invokeAll(Collection<? extends Callable<T>>) - Method in class org.infinispan.executors.LazyInitializingExecutorService
- invokeAll(Collection<? extends Callable<T>>) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
- invokeAll(Collection<? extends Callable<T>>) - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingExecutorService
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- invokeAll(BiFunction<Cache<K, V>, ? super CacheEntry<K, V>, R>) - Method in interface org.infinispan.LockedStream
-
Performs a BiFunction for each element of this stream on the primary owner of each entry returning a value.
- invokeAll(BiFunction<Cache<K, V>, ? super CacheEntry<K, V>, R>) - Method in class org.infinispan.stream.impl.LockedStreamImpl
- invokeAll(BiFunction<Cache<K, V>, ? super CacheEntry<K, V>, R>) - Method in class org.infinispan.stream.impl.TxLockedStreamImpl
- invokeAll(SerializableBiFunction<Cache<K, V>, ? super CacheEntry<K, V>, R>) - Method in interface org.infinispan.LockedStream
-
Same as
LockedStream.invokeAll(BiFunction)
except that the BiFunction must also implementSerializable
- invokeAny(Collection<? extends Callable<T>>) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
- invokeAny(Collection<? extends Callable<T>>) - Method in class org.infinispan.executors.LazyInitializingExecutorService
- invokeAny(Collection<? extends Callable<T>>) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
- invokeAny(Collection<? extends Callable<T>>) - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingExecutorService
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- invokeAsync() - Method in interface org.infinispan.commands.ReplicableCommand
-
Deprecated, for removal: This API element is subject to removal in a future version.since 11.0, please use
CacheRpcCommand.invokeAsync(ComponentRegistry)
orGlobalRpcCommand.invokeAsync(GlobalComponentRegistry)
instead. - invokeAsync() - Method in class org.infinispan.manager.impl.ReplicableManagerFunctionCommand
- invokeAsync(ContextBuilder, VisitableCommand, int) - Method in class org.infinispan.cache.impl.InvocationHelper
-
Same as
InvocationHelper.invoke(InvocationContext, VisitableCommand)
but using theInvocationContext
created bybuilder
. - invokeAsync(VisitableCommand, int) - Method in class org.infinispan.cache.impl.InvocationHelper
-
Same as
InvocationHelper.invoke(ContextBuilder, VisitableCommand, int)
but using the defaultContextBuilder
. - invokeAsync(InvocationContext, VisitableCommand) - Method in class org.infinispan.cache.impl.InvocationHelper
- invokeAsync(InvocationContext, VisitableCommand) - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
- invokeAsync(InvocationContext, VisitableCommand) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
-
Walks the command through the interceptor chain.
- invokeAsync(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
- invokeAsync(ComponentRegistry) - Method in class org.infinispan.notifications.cachelistener.cluster.MultiClusterEventCommand
- invokeAsync(ComponentRegistry) - Method in class org.infinispan.server.hotrod.command.tx.ForwardCommitCommand
- invokeAsync(ComponentRegistry) - Method in class org.infinispan.server.hotrod.command.tx.ForwardRollbackCommand
- invokeAsync(ComponentRegistry) - Method in class org.infinispan.xsite.commands.XSiteAmendOfflineStatusCommand
- invokeAsync(ComponentRegistry) - Method in class org.infinispan.xsite.commands.XSiteAutoTransferStatusCommand
- invokeAsync(ComponentRegistry) - Method in class org.infinispan.xsite.commands.XSiteBringOnlineCommand
- invokeAsync(ComponentRegistry) - Method in class org.infinispan.xsite.commands.XSiteOfflineStatusCommand
- invokeAsync(ComponentRegistry) - Method in class org.infinispan.xsite.commands.XSiteSetStateTransferModeCommand
- invokeAsync(ComponentRegistry) - Method in class org.infinispan.xsite.commands.XSiteStateTransferCancelSendCommand
- invokeAsync(ComponentRegistry) - Method in class org.infinispan.xsite.commands.XSiteStateTransferClearStatusCommand
- invokeAsync(ComponentRegistry) - Method in class org.infinispan.xsite.commands.XSiteStateTransferFinishReceiveCommand
- invokeAsync(ComponentRegistry) - Method in class org.infinispan.xsite.commands.XSiteStateTransferFinishSendCommand
- invokeAsync(ComponentRegistry) - Method in class org.infinispan.xsite.commands.XSiteStateTransferRestartSendingCommand
- invokeAsync(ComponentRegistry) - Method in class org.infinispan.xsite.commands.XSiteStateTransferStartReceiveCommand
- invokeAsync(ComponentRegistry) - Method in class org.infinispan.xsite.commands.XSiteStateTransferStartSendCommand
- invokeAsync(ComponentRegistry) - Method in class org.infinispan.xsite.commands.XSiteStateTransferStatusRequestCommand
- invokeAsync(ComponentRegistry) - Method in class org.infinispan.xsite.commands.XSiteStatusCommand
- invokeAsync(ComponentRegistry) - Method in class org.infinispan.xsite.commands.XSiteTakeOfflineCommand
- invokeAsync(ComponentRegistry) - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
- invokeAsync(GlobalComponentRegistry) - Method in interface org.infinispan.commands.GlobalRpcCommand
-
Invoke the command asynchronously.
- invokeAsync(GlobalComponentRegistry) - Method in class org.infinispan.manager.impl.ReplicableRunnableCommand
- invokeAsync(GlobalComponentRegistry) - Method in class org.infinispan.xsite.commands.XSiteLocalEventCommand
- invokeCommand(Collection<Address>, ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- invokeCommand(Collection<Address>, ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- invokeCommand(Collection<Address>, ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in interface org.infinispan.remoting.transport.Transport
-
Invoke a command on a collection of node and pass the responses to a
ResponseCollector
. - invokeCommand(Collection<Address>, ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticRpcManager
- invokeCommand(Collection<Address>, ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in interface org.infinispan.remoting.rpc.RpcManager
-
Invoke a command on a collection of node and pass the responses to a
ResponseCollector
. - invokeCommand(Collection<Address>, ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- invokeCommand(Address, ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- invokeCommand(Address, ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- invokeCommand(Address, ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in interface org.infinispan.remoting.transport.Transport
-
Invoke a command on a single node and pass the response to a
ResponseCollector
. - invokeCommand(Address, ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticRpcManager
- invokeCommand(Address, ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in interface org.infinispan.remoting.rpc.RpcManager
-
Invoke a command on a single node and pass the response to a
ResponseCollector
. - invokeCommand(Address, ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- invokeCommandOnAll(Collection<Address>, ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- invokeCommandOnAll(Collection<Address>, ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in interface org.infinispan.remoting.transport.Transport
-
Invoke a command on all the nodes in the cluster and pass the responses to a
ResponseCollector
. - invokeCommandOnAll(ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- invokeCommandOnAll(ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- invokeCommandOnAll(ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in interface org.infinispan.remoting.transport.Transport
-
Invoke a command on all the nodes in the cluster and pass the responses to a
ResponseCollector
. - invokeCommandOnAll(ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticRpcManager
- invokeCommandOnAll(ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in interface org.infinispan.remoting.rpc.RpcManager
-
Invoke a command on all the nodes in the cluster and pass the responses to a
ResponseCollector
. - invokeCommandOnAll(ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- invokeCommands(Collection<Address>, Function<Address, ReplicableCommand>, ResponseCollector<T>, long, DeliverOrder) - Method in interface org.infinispan.remoting.transport.Transport
-
Deprecated, for removal: This API element is subject to removal in a future version.Introduced in 9.1, but replaced in 9.2 with
Transport.invokeCommands(Collection, Function, ResponseCollector, DeliverOrder, long, TimeUnit)
. - invokeCommands(Collection<Address>, Function<Address, ReplicableCommand>, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- invokeCommands(Collection<Address>, Function<Address, ReplicableCommand>, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- invokeCommands(Collection<Address>, Function<Address, ReplicableCommand>, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in interface org.infinispan.remoting.transport.Transport
-
Invoke different commands on a collection of nodes and pass the responses to a
ResponseCollector
. - invokeCommands(Collection<Address>, Function<Address, ReplicableCommand>, ResponseCollector<T>, RpcOptions) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticRpcManager
- invokeCommands(Collection<Address>, Function<Address, ReplicableCommand>, ResponseCollector<T>, RpcOptions) - Method in interface org.infinispan.remoting.rpc.RpcManager
-
Invoke different commands on a collection of nodes and pass the responses to a
ResponseCollector
. - invokeCommands(Collection<Address>, Function<Address, ReplicableCommand>, ResponseCollector<T>, RpcOptions) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- invokeCommandStaggered(Collection<Address>, ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- invokeCommandStaggered(Collection<Address>, ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- invokeCommandStaggered(Collection<Address>, ReplicableCommand, ResponseCollector<T>, DeliverOrder, long, TimeUnit) - Method in interface org.infinispan.remoting.transport.Transport
-
Invoke a command on a collection of nodes and pass the responses to a
ResponseCollector
. - invokeCommandStaggered(Collection<Address>, ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticRpcManager
- invokeCommandStaggered(Collection<Address>, ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in interface org.infinispan.remoting.rpc.RpcManager
-
Invoke a command on a collection of nodes and pass the responses to a
ResponseCollector
. - invokeCommandStaggered(Collection<Address>, ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- invokeEvent(byte[], T) - Method in class org.infinispan.client.hotrod.event.impl.ClientListenerNotifier
- invokeEvent(HotRodCounterEvent) - Method in class org.infinispan.client.hotrod.event.impl.CounterEventDispatcher
- invokeEvent(ClientEvent) - Method in class org.infinispan.client.hotrod.event.impl.ClientEventDispatcher
- invokeEvent(T) - Method in class org.infinispan.client.hotrod.event.impl.EventDispatcher
- invokeFailoverEvent() - Method in class org.infinispan.client.hotrod.event.impl.ClientEventDispatcher
- invokeFailoverEvent() - Method in class org.infinispan.client.hotrod.event.impl.EventDispatcher
- invokeInLocalCache(String, ComponentRegistry) - Method in class org.infinispan.xsite.commands.remote.IracTombstoneCheckRequest
- invokeInLocalCache(String, ComponentRegistry) - Method in class org.infinispan.xsite.commands.remote.IracUpdateKeyRequest
- invokeInLocalCache(String, ComponentRegistry) - Method in class org.infinispan.xsite.commands.remote.XSiteCacheRequest
- invokeInLocalCache(String, ComponentRegistry) - Method in class org.infinispan.xsite.commands.remote.XSiteStatePushRequest
- invokeInLocalCache(String, ComponentRegistry) - Method in class org.infinispan.xsite.commands.remote.XSiteStateTransferControlRequest
- invokeInLocalSite(String, GlobalComponentRegistry) - Method in class org.infinispan.xsite.commands.remote.XSiteCacheRequest
- invokeInLocalSite(String, GlobalComponentRegistry) - Method in class org.infinispan.xsite.commands.remote.XSiteRemoteEventCommand
- invokeInLocalSite(String, GlobalComponentRegistry) - Method in interface org.infinispan.xsite.commands.remote.XSiteRequest
-
This method is invoked by the receiver node.
- invokeListeners(T, Collection<L>) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
- invokeLocal(XSiteStateProvider) - Method in class org.infinispan.xsite.commands.XSiteStateTransferCancelSendCommand
- invokeLocal(XSiteStateProvider) - Method in class org.infinispan.xsite.commands.XSiteStateTransferRestartSendingCommand
- invokeLocal(XSiteStateProvider) - Method in class org.infinispan.xsite.commands.XSiteStateTransferStartSendCommand
- invokeLocal(XSiteStateTransferManager) - Method in class org.infinispan.xsite.commands.XSiteStateTransferClearStatusCommand
- invokeMethod(Object, Method, Object[]) - Static method in class org.infinispan.commons.util.ReflectionUtil
- invokeNext(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
-
Invoke the next interceptor, possibly with a new command.
- invokeNextAndExceptionally(InvocationContext, C, InvocationExceptionFunction<C>) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
-
Invoke the next interceptor, possibly with a new command, and execute an
InvocationCallback
after all the interceptors have finished with an exception. - invokeNextAndFinally(InvocationContext, C, InvocationFinallyAction<C>) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
-
Invoke the next interceptor, possibly with a new command, and execute an
InvocationCallback
after all the interceptors have finished, with or without an exception. - invokeNextAndHandle(InvocationContext, C, InvocationFinallyFunction<C>) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
-
Invoke the next interceptor, possibly with a new command, and execute an
InvocationCallback
after all the interceptors have finished, with or without an exception. - invokeNextThenAccept(InvocationContext, C, InvocationSuccessAction<C>) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
-
Invoke the next interceptor, possibly with a new command, and execute an
InvocationCallback
after all the interceptors have finished successfully. - invokeNextThenApply(InvocationContext, C, InvocationSuccessFunction<C>) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
-
Invoke the next interceptor, possibly with a new command, and execute an
InvocationCallback
after all the interceptors have finished successfully. - invokeNoChecks(EventWrapper<K, V, CacheEntryEvent<K, V>>, boolean, boolean, boolean) - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
-
Invokes the event without applying filters or converters
- invokeNoChecks(EventWrapper<K, V, CacheEntryEvent<K, V>>, boolean, boolean, boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
-
This is the entry point for remote listener events being fired
- invokeNoChecks(EventWrapper<K, V, CacheEntryEvent<K, V>>, boolean, boolean, boolean) - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
- invoker - Variable in class org.infinispan.cache.impl.CacheImpl
- invoker - Variable in class org.infinispan.cache.impl.InvocationHelper
- invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
-
Deprecated, for removal: This API element is subject to removal in a future version.
- invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) - Method in interface org.infinispan.remoting.transport.Transport
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 9.2, please use
Transport.invokeCommand(Collection, ReplicableCommand, ResponseCollector, DeliverOrder, long, TimeUnit)
instead. - invokeRemotely(Map<Address, ReplicableCommand>, ResponseMode, long, boolean, ResponseFilter, boolean, boolean) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
-
Deprecated, for removal: This API element is subject to removal in a future version.
- invokeRemotely(Map<Address, ReplicableCommand>, ResponseMode, long, boolean, ResponseFilter, boolean, boolean) - Method in interface org.infinispan.remoting.transport.Transport
-
Deprecated, for removal: This API element is subject to removal in a future version.
- invokeRemotely(Map<Address, ReplicableCommand>, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
-
Deprecated, for removal: This API element is subject to removal in a future version.
- invokeRemotely(Map<Address, ReplicableCommand>, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
-
Deprecated, for removal: This API element is subject to removal in a future version.
- invokeRemotely(Map<Address, ReplicableCommand>, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) - Method in interface org.infinispan.remoting.transport.Transport
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 9.2, please use
Transport.invokeRemotelyAsync(Collection, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder, boolean)
instead. - invokeRemotelyAsync(Collection<Address>, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- invokeRemotelyAsync(Collection<Address>, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- invokeRemotelyAsync(Collection<Address>, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) - Method in interface org.infinispan.remoting.transport.Transport
- invokeRemotelyAsync(Collection<Address>, ReplicableCommand, RpcOptions) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticRpcManager
- invokeRemotelyAsync(Collection<Address>, ReplicableCommand, RpcOptions) - Method in interface org.infinispan.remoting.rpc.RpcManager
-
Deprecated, for removal: This API element is subject to removal in a future version.
- invokeRemotelyAsync(Collection<Address>, ReplicableCommand, RpcOptions) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- invokeStage(InvocationContext, VisitableCommand) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
-
Walks the command through the interceptor chain.
- invokeStage(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
- invokeXSite(XSiteBackup, XSiteCacheRequest<O>) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticRpcManager
- invokeXSite(XSiteBackup, XSiteCacheRequest<O>) - Method in interface org.infinispan.remoting.rpc.RpcManager
-
Sends the
XSiteCacheRequest
to a remote site. - invokeXSite(XSiteBackup, XSiteCacheRequest<O>) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- IO_THREADS - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- ioErrorUnmarshalling(IOException) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- ioThreads() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- ioThreads(int) - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
- ioThreads(int) - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- ioThreads(int) - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
-
Sets the number of I/O threads
- IOURingNativeTransport - Class in org.infinispan.server.core.transport
- IOURingNativeTransport() - Constructor for class org.infinispan.server.core.transport.IOURingNativeTransport
- ioUringNotAvailable(String) - Method in interface org.infinispan.client.hotrod.logging.Log
- ioUringNotAvailable(String) - Method in interface org.infinispan.server.core.logging.Log
- IP_FILTER_RULE - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- IP_FILTER_RULES - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- ipFilter - Variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- ipFilter - Variable in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- ipFilter() - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
- ipFilter() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- ipFilter() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- ipFilter() - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
-
Configures the IP filter rules
- IpFilterConfiguration - Class in org.infinispan.server.core.configuration
- IpFilterConfiguration(List<IpSubnetFilterRule>) - Constructor for class org.infinispan.server.core.configuration.IpFilterConfiguration
- IpFilterConfigurationBuilder<T extends ProtocolServerConfiguration,
S extends ProtocolServerConfigurationChildBuilder<T, S>> - Class in org.infinispan.server.core.configuration -
IpFilterConfigurationBuilder.
- IpFilterConfigurationBuilder(ProtocolServerConfigurationChildBuilder<T, S>) - Constructor for class org.infinispan.server.core.configuration.IpFilterConfigurationBuilder
- ipFilterConnectionRejection(InetSocketAddress, IpFilterRule) - Method in interface org.infinispan.server.core.logging.Log
- IpFilterRuleChannelMatcher - Class in org.infinispan.server.core.transport
- IpFilterRuleChannelMatcher(Iterable<? extends IpFilterRule>) - Constructor for class org.infinispan.server.core.transport.IpFilterRuleChannelMatcher
- IpSubnetFilterRule - Class in org.infinispan.server.core.transport
-
This differs from Netty's equivalent
IpSubnetFilterRule
in that it parses CIDR addresses - IpSubnetFilterRule(String, IpFilterRuleType) - Constructor for class org.infinispan.server.core.transport.IpSubnetFilterRule
- IRAC_CLEAR - Static variable in class org.infinispan.xsite.commands.remote.Ids
- IRAC_METADATA - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- IRAC_SITE_VERSION - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- IRAC_STATE - Enum constant in enum org.infinispan.context.Flag
-
Signals a
WriteCommand
as state transfer from remote site. - IRAC_STATE - Static variable in class org.infinispan.context.impl.FlagBitSets
- IRAC_TOMBSTONE_CHECK - Static variable in class org.infinispan.xsite.commands.remote.Ids
- IRAC_TOUCH - Static variable in class org.infinispan.xsite.commands.remote.Ids
- IRAC_UPDATE - Enum constant in enum org.infinispan.context.Flag
-
Signals a
WriteCommand
as an update from a remote site (async). - IRAC_UPDATE - Static variable in class org.infinispan.context.impl.FlagBitSets
- IRAC_UPDATE - Static variable in class org.infinispan.xsite.commands.remote.Ids
- IRAC_VERSION - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- IRAC_VERSION_ENTRY - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- IracClearKeysRequest - Class in org.infinispan.xsite.commands.remote
-
A clear request that is sent to the remote site by
IracManager
. - IracClearKeysRequest() - Constructor for class org.infinispan.xsite.commands.remote.IracClearKeysRequest
- IracClearKeysRequest(ByteString) - Constructor for class org.infinispan.xsite.commands.remote.IracClearKeysRequest
- IracClearResponseCollector - Class in org.infinispan.xsite.irac
-
Used by asynchronous cross-site replication, it aggregates response from multiple sites and returns
IracBatchSendResult
. - IracClearResponseCollector(String) - Constructor for class org.infinispan.xsite.irac.IracClearResponseCollector
- IracEntryVersion - Class in org.infinispan.container.versioning.irac
-
An entry version for the IRAC algorithm (async cross site replication).
- IracEntryVersion.MapEntry - Class in org.infinispan.container.versioning.irac
- IracEntryVersion$___Marshaller_1d33e9a17b1520460201f2d05b09e88a3eb2df8efbb49f8a10103069f8b573d5 - Class in org.infinispan.container.versioning.irac
-
WARNING: Generated code! Do not edit!
- IracEntryVersion$___Marshaller_1d33e9a17b1520460201f2d05b09e88a3eb2df8efbb49f8a10103069f8b573d5() - Constructor for class org.infinispan.container.versioning.irac.IracEntryVersion$___Marshaller_1d33e9a17b1520460201f2d05b09e88a3eb2df8efbb49f8a10103069f8b573d5
- IracExecutor - Class in org.infinispan.xsite.irac
-
Executes the "IRAC" sending task in a single thread.
- IracExecutor(Supplier<CompletionStage<Void>>) - Constructor for class org.infinispan.xsite.irac.IracExecutor
- IracManager - Interface in org.infinispan.xsite.irac
-
It manages the keys changed in the local cluster and sends to all asynchronous backup configured.
- IracManagerKeyInfo - Interface in org.infinispan.xsite.irac
-
Basic information about a key stored in
IracManager
. - IracManagerKeyInfoImpl - Class in org.infinispan.xsite.irac
-
Default implementation of
IracManagerKeyInfo
. - IracManagerKeyInfoImpl(int, Object, Object) - Constructor for class org.infinispan.xsite.irac.IracManagerKeyInfoImpl
- iracMetadata() - Method in class org.infinispan.metadata.impl.PrivateMetadata
- iracMetadata(IracMetadata) - Method in class org.infinispan.metadata.impl.PrivateMetadata.Builder
-
Sets the
IracMetadata
to store. - IracMetadata - Class in org.infinispan.metadata.impl
-
The metadata stored for an entry needed for IRAC (async cross-site replication).
- IracMetadata(String, IracEntryVersion) - Constructor for class org.infinispan.metadata.impl.IracMetadata
- IracMetadata(ByteString, IracEntryVersion) - Constructor for class org.infinispan.metadata.impl.IracMetadata
- IracMetadata$___Marshaller_cf0a6ded5e9e5b145ea5821d40d9659677d03a5df3e405762cc053e3bbb15e64 - Class in org.infinispan.metadata.impl
-
WARNING: Generated code! Do not edit!
- IracMetadata$___Marshaller_cf0a6ded5e9e5b145ea5821d40d9659677d03a5df3e405762cc053e3bbb15e64() - Constructor for class org.infinispan.metadata.impl.IracMetadata$___Marshaller_cf0a6ded5e9e5b145ea5821d40d9659677d03a5df3e405762cc053e3bbb15e64
- IracPutManyRequest - Class in org.infinispan.xsite.commands.remote
-
A multi-key cross-site requests.
- IracPutManyRequest() - Constructor for class org.infinispan.xsite.commands.remote.IracPutManyRequest
- IracPutManyRequest(ByteString, int) - Constructor for class org.infinispan.xsite.commands.remote.IracPutManyRequest
- IracResponseCollector - Class in org.infinispan.xsite.irac
-
A response collector for an asynchronous cross site requests.
- IracResponseCollector(String, Collection<IracManagerKeyState>, IracResponseCollector.IracResponseCompleted) - Constructor for class org.infinispan.xsite.irac.IracResponseCollector
- IracResponseCollector.IracResponseCompleted - Interface in org.infinispan.xsite.irac
- IracTombstoneCheckRequest - Class in org.infinispan.xsite.commands.remote
-
A
XSiteCacheRequest
to check tombstones for IRAC algorithm. - IracTombstoneCheckRequest() - Constructor for class org.infinispan.xsite.commands.remote.IracTombstoneCheckRequest
- IracTombstoneCheckRequest(ByteString, List<Object>) - Constructor for class org.infinispan.xsite.commands.remote.IracTombstoneCheckRequest
- IracTombstoneInfo - Class in org.infinispan.container.versioning.irac
-
A data class to store the tombstone information for a key.
- IracTombstoneInfo(Object, int, IracMetadata) - Constructor for class org.infinispan.container.versioning.irac.IracTombstoneInfo
- IracTombstoneManager - Interface in org.infinispan.container.versioning.irac
-
Stores and manages tombstones for removed keys.
- IracTouchKeyRequest - Class in org.infinispan.xsite.commands.remote
-
A request that is sent to the remote site by
IracManager
. - IracTouchKeyRequest() - Constructor for class org.infinispan.xsite.commands.remote.IracTouchKeyRequest
- IracTouchKeyRequest(ByteString, Object) - Constructor for class org.infinispan.xsite.commands.remote.IracTouchKeyRequest
- IracUpdateKeyRequest<T> - Class in org.infinispan.xsite.commands.remote
-
An update request that is sent to the remote site by
IracManager
. - IracUpdateKeyRequest(ByteString) - Constructor for class org.infinispan.xsite.commands.remote.IracUpdateKeyRequest
- IracUtils - Class in org.infinispan.util
-
Utility methods from IRAC (async cross-site replication)
- IracVersionGenerator - Interface in org.infinispan.container.versioning.irac
-
A version generator for the IRAC protocol.
- IracXSiteBackup - Class in org.infinispan.xsite.irac
-
Extends
XSiteBackup
class with logging configuration. - IracXSiteBackup(String, boolean, long, boolean) - Constructor for class org.infinispan.xsite.irac.IracXSiteBackup
- is(int, Object) - Method in class org.infinispan.commons.dataconversion.internal.Json
-
Return
true
if and only if thisJson
array has an element with the specified value at the specified index. - is(String, Object) - Method in class org.infinispan.commons.dataconversion.internal.Json
-
Return
true
if and only if thisJson
object has a property with the specified value. - is1PcForAutoCommitTransaction(LocalTransaction) - Method in class org.infinispan.transaction.impl.TransactionCoordinator
- isAbsolute() - Method in class org.infinispan.io.GridFile
-
Deprecated.
- isAcceptable(Response, Address) - Method in class org.infinispan.remoting.responses.ClusteredGetResponseValidityFilter
- isAcceptable(Response, Address) - Method in class org.infinispan.remoting.responses.IgnoreExtraResponsesValidityFilter
- isAcceptable(Response, Address) - Method in interface org.infinispan.remoting.rpc.ResponseFilter
-
Determines whether a response from a given sender should be added to the response list of the request
- isAffectedByRehash(Object) - Method in interface org.infinispan.distribution.DistributionManager
-
Tests whether a given key is affected by a rehash that may be in progress.
- isAffectedByRehash(Object) - Method in class org.infinispan.distribution.impl.DistributionManagerImpl
- isAggregable() - Method in class org.infinispan.search.mapper.mapping.metamodel.ValueFieldMetamodel
- isAlias() - Method in interface org.infinispan.factories.impl.ComponentRef
- isAlive(Address) - Method in class org.infinispan.server.hotrod.tx.PrepareCoordinator
- isAllCompleted() - Method in class org.infinispan.executors.ExecutorAllCompletionService
- isAnnotationPresent(Class<?>, Class<? extends Annotation>) - Static method in class org.infinispan.commons.util.ReflectionUtil
-
Tests whether an annotation is present on a class.
- isArray() - Method in class org.infinispan.commons.dataconversion.internal.Json
- isAscending() - Method in interface org.infinispan.objectfilter.SortField
-
Indicates if sorting is ascending or descending.
- isAssignableFrom(Class<?>) - Static method in class org.infinispan.commons.util.ClassFinder
- isAssignableFrom(List<Class<?>>, Class<?>) - Static method in class org.infinispan.commons.util.ClassFinder
- isAsyncBackup() - Method in class org.infinispan.configuration.cache.BackupConfiguration
- isAsynchronous() - Method in enum org.infinispan.remoting.rpc.ResponseMode
- isAtLeast(byte) - Method in enum org.infinispan.server.hotrod.HotRodVersion
-
Checks whether the supplied version is equal or greater than the version represented by this object
- isAttributeDefault(int) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- isAttributeDefault(int) - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
-
Returns if the specified attribute was not in input was declared in XML.
- isAutoCommit() - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations.FlowableConnection
- isAutoPersist() - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
- isAvailable() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- isAvailable() - Method in interface org.infinispan.notifications.cachelistener.event.PersistenceAvailabilityChangedEvent
- isAvailable() - Method in class org.infinispan.persistence.async.AsyncNonBlockingStore
- isAvailable() - Method in class org.infinispan.persistence.file.SingleFileStore
- isAvailable() - Method in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
- isAvailable() - Method in class org.infinispan.persistence.remote.RemoteStore
- isAvailable() - Method in class org.infinispan.persistence.rocksdb.RocksDBStore
- isAvailable() - Method in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
- isAvailable() - Method in interface org.infinispan.persistence.spi.CacheLoader
-
Deprecated.
- isAvailable() - Method in interface org.infinispan.persistence.spi.CacheWriter
-
Deprecated.
- isAvailable() - Method in interface org.infinispan.persistence.spi.ExternalStore
-
Deprecated.
- isAvailable() - Method in interface org.infinispan.persistence.spi.NonBlockingStore
-
Returns a stage that, when complete, returns a boolean indicating whether the current store can be accessed for requests.
- isAvailable() - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
- isAvailable() - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- isAvailable() - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
- isAvailable() - Method in interface org.infinispan.util.concurrent.locks.LockPromise
-
It tests if the lock is available.
- isAvailable(String) - Method in class org.infinispan.commons.util.Features
- isBackupFor(String, String) - Method in class org.infinispan.configuration.cache.BackupForConfiguration
- isBatchingEnabled() - Method in enum org.infinispan.configuration.parsing.CacheParser.TransactionMode
- isBinary() - Method in class org.infinispan.commons.dataconversion.MediaType
- isBoolean() - Method in class org.infinispan.commons.dataconversion.internal.Json
- isBound() - Method in class org.infinispan.counter.configuration.StrongCounterConfiguration
- isCacheElement(String) - Static method in enum org.infinispan.configuration.parsing.Element
- isCacheIgnored(String) - Method in class org.infinispan.server.core.AbstractProtocolServer
- isCacheIgnored(String) - Method in interface org.infinispan.server.core.ServerStateManager
- isCacheReady() - Method in class org.infinispan.persistence.cluster.ClusterLoader
-
Deprecated.A test to check whether the cache is in its started state.
- isCacheRebalancingEnabled(String) - Method in interface org.infinispan.topology.LocalTopologyManager
-
Checks whether rebalancing is enabled for the specified cache.
- isCacheRebalancingEnabled(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- isChanged() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
- isChanged() - Method in interface org.infinispan.container.entries.CacheEntry
- isChanged() - Method in class org.infinispan.container.entries.ClearCacheEntry
- isChanged() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
- isChanged() - Method in class org.infinispan.container.entries.NullCacheEntry
- isChanged() - Method in class org.infinispan.container.entries.ReadCommittedEntry
- isChildOf(String, String) - Static method in class org.infinispan.io.GridFile
-
Deprecated.Verifies whether child is a child (dir or file) of parent
- isClose() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
- isClose() - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
- isClustered() - Method in enum org.infinispan.configuration.cache.CacheMode
- isClustered() - Method in class org.infinispan.configuration.global.GlobalConfiguration
- isClustered() - Method in class org.infinispan.configuration.global.JGroupsConfiguration
- isClustered() - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
- isClustered() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
- isClustered() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- isClustered() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
- isClustered(GlobalConfiguration) - Static method in class org.infinispan.configuration.cache.Configurations
- isClusterWide() - Method in class org.infinispan.factories.impl.MBeanMetadata.AttributeMetadata
- isCommandRetried() - Method in interface org.infinispan.client.hotrod.event.ClientCacheEntryCreatedEvent
-
This will be true if the write command that caused this had to be retried again due to a topology change.
- isCommandRetried() - Method in interface org.infinispan.client.hotrod.event.ClientCacheEntryCustomEvent
-
This will be true if the write command that caused this had to be retried again due to a topology change.
- isCommandRetried() - Method in interface org.infinispan.client.hotrod.event.ClientCacheEntryModifiedEvent
-
This will be true if the write command that caused this had to be retried again due to a topology change.
- isCommandRetried() - Method in interface org.infinispan.client.hotrod.event.ClientCacheEntryRemovedEvent
-
This will be true if the write command that caused this had to be retried again due to a topology change.
- isCommandRetried() - Method in class org.infinispan.client.hotrod.event.impl.CreatedEventImpl
- isCommandRetried() - Method in class org.infinispan.client.hotrod.event.impl.CustomEventImpl
- isCommandRetried() - Method in class org.infinispan.client.hotrod.event.impl.ModifiedEventImpl
- isCommandRetried() - Method in class org.infinispan.client.hotrod.event.impl.RemovedEventImpl
- isCommandRetried() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
- isCommandRetried() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryCreatedEvent
-
This will be true if the write command that caused this had to be retried again due to a topology change.
- isCommandRetried() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryModifiedEvent
-
This will be true if the write command that caused this had to be retried again due to a topology change.
- isCommandRetried() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryRemovedEvent
-
This will be true if the write command that caused this had to be retried again due to a topology change.
- isCommandRetried() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- isCommitted() - Method in interface org.infinispan.container.entries.MVCCEntry
- isCommitted() - Method in class org.infinispan.container.entries.ReadCommittedEntry
- isCommitted() - Method in class org.infinispan.extendedstats.TransactionStatistics
- isCommunicationError(Throwable) - Static method in class org.infinispan.xsite.status.DefaultTakeOfflineManager
- isComplete() - Method in class org.infinispan.server.core.security.SubjectSaslServer
- isCompletedSuccessfully(CompletionStage<?>) - Static method in class org.infinispan.util.concurrent.CompletionStages
-
Returns if the provided
CompletionStage
has already completed normally, that is not due to an exception. - isCompletionFailed() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareLocalTransaction
-
Returns true if this transaction failed during 2nd phase of 2PC(prepare or commit).
- isConflictResolutionInProgress() - Method in interface org.infinispan.conflict.ConflictManager
- isConnected() - Method in class org.infinispan.distribution.LocalizedCacheTopology
- isConnected(String) - Method in class org.infinispan.upgrade.RollingUpgradeManager
- isConnected(Cache<Object, Object>) - Method in class org.infinispan.persistence.remote.upgrade.HotRodTargetMigrator
- isConnected(Cache<Object, Object>) - Method in interface org.infinispan.upgrade.TargetMigrator
-
Check if a cluster is connected to other for doing rolling upgrades
- isConversionSupported(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.
- isConversionSupported(MediaType, MediaType) - Method in interface org.infinispan.marshall.core.EncoderRegistry
- isConversionSupported(MediaType, MediaType) - Method in class org.infinispan.marshall.core.EncoderRegistryImpl
- isCoordinator() - Method in class org.infinispan.manager.CacheManagerInfo
- isCoordinator() - Method in class org.infinispan.manager.DefaultCacheManager
- isCoordinator() - Method in interface org.infinispan.manager.EmbeddedCacheManager
- isCoordinator() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
- isCoordinator() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- isCoordinator() - Method in class org.infinispan.remoting.transport.jgroups.ClusterView
- isCoordinator() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- isCoordinator() - Method in interface org.infinispan.remoting.transport.Transport
- isCreate() - Method in class org.infinispan.notifications.cachelistener.filter.EventType
- isCreated() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
- isCreated() - Method in interface org.infinispan.container.entries.CacheEntry
- isCreated() - Method in class org.infinispan.container.entries.ClearCacheEntry
- isCreated() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
- isCreated() - Method in class org.infinispan.container.entries.NullCacheEntry
- isCreated() - Method in class org.infinispan.container.entries.ReadCommittedEntry
- isCreated() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
- isCreated() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryModifiedEvent
-
Indicates whether the cache entry modification event is the result of the cache entry being created.
- isCreated() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- isCurrentState() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryEvent
- isCurrentState() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- isCurrentThreadBlocking() - Method in class org.infinispan.util.concurrent.BlockingManagerImpl
- isCustomMaxResults() - Method in class org.infinispan.query.impl.QueryDefinition
- isDefaultRoles() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
- isDefaultRunning() - Method in class org.infinispan.manager.DefaultCacheManager
- isDefaultRunning() - Method in interface org.infinispan.manager.EmbeddedCacheManager
-
Tests whether the default cache is running.
- isDefaultRunning() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
- isDefined(String) - Method in class org.infinispan.client.hotrod.counter.impl.RemoteCounterManager
- isDefined(String) - Method in interface org.infinispan.counter.api.CounterManager
- isDefined(String) - Method in interface org.infinispan.lock.api.ClusteredLockManager
-
Checks if a lock is already defined.
- IsDefinedOperation - Class in org.infinispan.client.hotrod.counter.operation
-
A counter operation for
CounterManager.isDefined(String)
. - IsDefinedOperation(ChannelFactory, AtomicReference<ClientTopology>, Configuration, String) - Constructor for class org.infinispan.client.hotrod.counter.operation.IsDefinedOperation
- isDelete() - Method in class org.infinispan.functional.impl.StatsEnvelope
- isDeltaFilter() - Method in interface org.infinispan.objectfilter.FilterSubscription
- isDeprecated(int, int) - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
- isDirectory() - Method in class org.infinispan.io.GridFile
-
Deprecated.
- isDirectory() - Method in class org.infinispan.io.GridFile.Metadata
-
Deprecated.
- isDistributed() - Method in enum org.infinispan.configuration.cache.CacheMode
- isDone() - Method in class org.infinispan.interceptors.ExceptionSyncInvocationStage
- isDone() - Method in class org.infinispan.interceptors.InvocationStage
- isDone() - Method in class org.infinispan.interceptors.SyncInvocationStage
- isEmbeddedMode(GlobalConfiguration) - Static method in class org.infinispan.configuration.cache.Configurations
- isEmpty() - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
- isEmpty() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- isEmpty() - Method in class org.infinispan.cache.impl.CacheImpl
- isEmpty() - Method in class org.infinispan.cache.impl.DecoratedCache
- isEmpty() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySetBase
- isEmpty() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- isEmpty() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.KeySet
- isEmpty() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.Values
- isEmpty() - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- isEmpty() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- isEmpty() - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
- isEmpty() - Method in interface org.infinispan.commons.stat.SimpleStat
- isEmpty() - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
- isEmpty() - Method in class org.infinispan.commons.util.AbstractDelegatingMap
- isEmpty() - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
- isEmpty() - Method in class org.infinispan.commons.util.FastCopyHashMap.EntrySet
- isEmpty() - Method in class org.infinispan.commons.util.FastCopyHashMap
- isEmpty() - Method in class org.infinispan.commons.util.ForwardingList
- isEmpty() - Method in class org.infinispan.commons.util.ImmutableHopscotchHashSet
- isEmpty() - Method in class org.infinispan.commons.util.ImmutableIntSet
-
Deprecated.
- isEmpty() - Method in class org.infinispan.commons.util.ImmutableListCopy
- isEmpty() - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- isEmpty() - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- isEmpty() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- isEmpty() - Method in class org.infinispan.container.versioning.irac.DefaultIracTombstoneManager
- isEmpty() - Method in interface org.infinispan.container.versioning.irac.IracTombstoneManager
- isEmpty() - Method in class org.infinispan.container.versioning.irac.NoOpIracTombstoneManager
- isEmpty() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
-
Checks if the provided set is empty.
- isEmpty() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
-
Checks if the provided map is empty.
- isEmpty() - Method in class org.infinispan.functional.impl.MetaParams
- isEmpty() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
- isEmpty() - Method in class org.infinispan.InternalCacheSet
- isEmpty() - Method in class org.infinispan.metadata.impl.PrivateMetadata
- isEmpty() - Method in class org.infinispan.multimap.impl.Bucket
- isEmpty() - Method in class org.infinispan.remoting.transport.AggregateBackupResponse
- isEmpty() - Method in interface org.infinispan.remoting.transport.BackupResponse
- isEmpty() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsBackupResponse
- isEmpty() - Method in class org.infinispan.security.impl.SecureCacheImpl
- isEmpty() - Method in class org.infinispan.server.hotrod.tx.table.GlobalTxTable
- isEmpty() - Method in class org.infinispan.server.hotrod.tx.table.PerCacheTxTable
-
testing only
- isEmpty() - Method in class org.infinispan.spring.remote.ConfigurationPropertiesOverrides
- isEmpty() - Method in class org.infinispan.topology.CacheStatusResponse
- isEmpty() - Method in class org.infinispan.transaction.impl.ModificationList
- isEmpty() - Method in class org.infinispan.util.CollectionMapper
- isEmpty() - Method in class org.infinispan.xsite.commands.remote.IracPutManyRequest
- isEmpty() - Method in class org.infinispan.xsite.irac.DefaultIracManager
- isEmptyElementTag() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- isEmptyElementTag() - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
-
Returns true if the current event is START_TAG and the tag is degenerated (e.g.
- isEnabled() - Method in class org.infinispan.client.hotrod.impl.ClientStatistics
- isEnabled() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
- isEnabled() - Method in enum org.infinispan.configuration.cache.Index
-
Deprecated.Use
IndexingConfiguration.enabled()
} instead - isEnabled() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
- isEnabled() - Method in enum org.infinispan.eviction.EvictionStrategy
-
Whether or not the cache will do something due to the strategy
- isEnabled() - Method in interface org.infinispan.eviction.impl.PassivationManager
- isEnabled() - Method in class org.infinispan.eviction.impl.PassivationManagerImpl
- isEnabled() - Method in class org.infinispan.eviction.impl.PassivationManagerStub
- isEnabled() - Method in interface org.infinispan.expiration.ExpirationManager
- isEnabled() - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
- isEnabled() - Method in class org.infinispan.extendedstats.topK.StreamSummaryContainer
- isEnabled() - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- isEnabled() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- isEnabled() - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
- isEnabled() - Static method in class org.infinispan.server.hotrod.logging.HotRodAccessLogging
- isEncoded() - Method in interface org.infinispan.functional.FunctionalMap
-
Tells if the underlying cache is using encoding or not
- isEnlisted() - Method in class org.infinispan.transaction.impl.LocalTransaction
- isEnlisted() - Method in class org.infinispan.transaction.synchronization.SyncLocalTransaction
- isEnlisted() - Method in class org.infinispan.transaction.xa.LocalXaTransaction
-
As per the JTA spec, XAResource.start is called on enlistment.
- isEntryRemovedInContext(Object) - Method in class org.infinispan.context.impl.AbstractInvocationContext
- isEntryRemovedInContext(Object) - Method in class org.infinispan.context.impl.ClearInvocationContext
- isEntryRemovedInContext(Object) - Method in class org.infinispan.context.impl.ImmutableContext
- isEntryRemovedInContext(Object) - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
- isEntryRemovedInContext(Object) - Method in interface org.infinispan.context.InvocationContext
-
Deprecated.Since 11, to be removed in 14 with no replacement
- isEvicted() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
- isEvicted() - Method in interface org.infinispan.container.entries.CacheEntry
- isEvicted() - Method in class org.infinispan.container.entries.ClearCacheEntry
- isEvicted() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
- isEvicted() - Method in class org.infinispan.container.entries.NullCacheEntry
- isEvicted() - Method in class org.infinispan.container.entries.ReadCommittedEntry
- isEvictionEnabled() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
-
Returns whether remove eviction is in use
- isExceptionBased() - Method in enum org.infinispan.eviction.EvictionStrategy
-
The cache will throw exceptions to prevent memory growth
- isExceptionBasedEviction(Configuration) - Static method in class org.infinispan.configuration.cache.Configurations
- isExceptionThrown() - Method in class org.infinispan.executors.ExecutorAllCompletionService
- isExpired() - Method in interface org.infinispan.container.entries.MVCCEntry
-
Returns whether this entry was marked as being expired or not
- isExpired() - Method in class org.infinispan.container.entries.ReadCommittedEntry
- isExpired() - Method in class org.infinispan.notifications.cachelistener.filter.EventType
- isExpired() - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository.InfinispanSession
- isExpired(long) - Method in class org.infinispan.container.entries.ImmortalCacheEntry
- isExpired(long) - Method in class org.infinispan.container.entries.ImmortalCacheValue
- isExpired(long) - Method in interface org.infinispan.container.entries.InternalCacheEntry
- isExpired(long) - Method in interface org.infinispan.container.entries.InternalCacheValue
- isExpired(long) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
- isExpired(long) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
- isExpired(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
- isExpired(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
- isExpired(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
- isExpired(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue
- isExpired(long) - Method in class org.infinispan.container.entries.MortalCacheEntry
- isExpired(long) - Method in class org.infinispan.container.entries.MortalCacheValue
- isExpired(long) - Method in class org.infinispan.container.entries.TransientCacheEntry
- isExpired(long) - Method in class org.infinispan.container.entries.TransientCacheValue
- isExpired(long) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
- isExpired(long) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
- isExpired(long) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
-
Returns whether entry is expired or not.
- isExpired(long) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
-
Returns whether entry is expired.
- isExpired(long) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
- isExpired(long) - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
-
Deprecated.
- isExpired(long) - Method in interface org.infinispan.metadata.InternalMetadata
-
Deprecated.
- isExpired(long) - Method in interface org.infinispan.persistence.spi.MarshallableEntry
- isExpiredMortal(long, long, long) - Static method in class org.infinispan.container.entries.ExpiryHelper
- isExpiredTransient(long, long, long) - Static method in class org.infinispan.container.entries.ExpiryHelper
- isExpiredTransientMortal(long, long, long, long, long) - Static method in class org.infinispan.container.entries.ExpiryHelper
- isExplicitInner() - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter.Tag
- isExplicitOuter() - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter.Tag
- isFile() - Method in class org.infinispan.io.GridFile
-
Deprecated.
- isFile() - Method in class org.infinispan.io.GridFile.Metadata
-
Deprecated.
- isFilterable() - Method in class org.infinispan.commons.dataconversion.ByteArrayWrapper
- isFilterable() - Method in class org.infinispan.commons.dataconversion.IdentityWrapper
- isFilterable() - Method in interface org.infinispan.commons.dataconversion.Wrapper
- isFilterOnStorageFormat() - Method in class org.infinispan.notifications.cachelistener.ListenerHolder
- isFromRemoteSite() - Method in class org.infinispan.transaction.impl.LocalTransaction
-
When x-site replication is used, this returns when this operation happens as a result of backing up data from a remote site.
- isFromStateTransfer() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
- isGlob(String) - Static method in class org.infinispan.commons.util.GlobUtils
- isGlobal() - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
- isGlobalScope() - Method in class org.infinispan.factories.impl.ComponentAccessor
-
Temporary, for ComponentRegistry.getLocalComponent
- isHidden() - Method in class org.infinispan.io.GridFile
-
Deprecated.
- isHit() - Method in class org.infinispan.functional.impl.StatsEnvelope
- isIgnorableDataAccessThrowable(Throwable) - Method in class org.infinispan.search.mapper.model.impl.InfinispanRuntimeIntrospector
- isImmutable() - Method in class org.infinispan.commons.configuration.attributes.Attribute
- isImmutable() - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
- isImmutable(Object) - Static method in class org.infinispan.commons.util.Immutables
-
Whether or not this collection type is immutable
- isImplicit() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- isImplicitTransaction() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
- isImplicitTransaction() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
- isImplicitTransaction() - Method in interface org.infinispan.context.impl.TxInvocationContext
- isImplicitTransaction() - Method in class org.infinispan.transaction.impl.LocalTransaction
- isIncludeCurrentState() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- isInDoubt() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
-
A transaction is in doubt if it is prepared and and it is orphan.
- isInheritable() - Method in class org.infinispan.security.impl.CacheRoleImpl
- isInheritable() - Method in interface org.infinispan.security.Role
-
Whether this role can be implicitly inherited.
- isInternalCache(String) - Method in class org.infinispan.registry.impl.InternalCacheRegistryImpl
- isInTxScope() - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
- isInTxScope() - Method in class org.infinispan.context.impl.ClearInvocationContext
- isInTxScope() - Method in class org.infinispan.context.impl.ImmutableContext
- isInTxScope() - Method in class org.infinispan.context.impl.NonTxInvocationContext
- isInTxScope() - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
- isInTxScope() - Method in interface org.infinispan.context.InvocationContext
-
Returns true if this call is performed in the context of an transaction, false otherwise.
- isInvalidation() - Method in enum org.infinispan.configuration.cache.CacheMode
-
Returns true if the mode is invalidation, either sync or async.
- isIs() - Method in class org.infinispan.factories.impl.MBeanMetadata.AttributeMetadata
- isJmx() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- isJoinComplete() - Method in interface org.infinispan.distribution.DistributionManager
-
Tests whether the current instance has completed joining the cluster
- isJoinComplete() - Method in class org.infinispan.distribution.impl.DistributionManagerImpl
- isKeyEquals(Object) - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
- isKeyGeneratorThreadActive() - Method in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
- isKeyGeneratorThreadAlive() - Method in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
- isKeyOperationAllowed(boolean, long, LocalizedCacheTopology, Object) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
-
Check if a read/write operation is allowed with the actual members
- isKeyOperationAllowed(boolean, long, LocalizedCacheTopology, Object) - Method in class org.infinispan.scattered.impl.ScatteredPartitionHandlingManagerImpl
- isKnownMarshallable(Class<?>) - Method in class org.infinispan.commons.marshall.MarshallableTypeHints
-
Returns whether the hint on whether a particular type is marshallable or not is available.
- isL1Entry() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
- isL1Entry() - Method in interface org.infinispan.container.entries.InternalCacheEntry
- isL1Entry() - Method in class org.infinispan.container.entries.L1InternalCacheEntry
- isL1Entry() - Method in class org.infinispan.container.entries.metadata.L1MetadataInternalCacheEntry
- isListenerConnected(byte[]) - Method in class org.infinispan.client.hotrod.event.impl.ClientListenerNotifier
- isLoaded() - Method in interface org.infinispan.container.entries.MVCCEntry
- isLoaded() - Method in class org.infinispan.container.entries.ReadCommittedEntry
- isLocal() - Method in enum org.infinispan.distribution.DataLocality
-
Deprecated.
- isLocal() - Method in enum org.infinispan.extendedstats.container.ExtendedStatistic
- isLocal() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfo
- isLocalTransaction() - Method in class org.infinispan.extendedstats.LocalTransactionStatistics
- isLocalTransaction() - Method in class org.infinispan.extendedstats.RemoteTransactionStatistics
- isLocalTransaction() - Method in class org.infinispan.extendedstats.TransactionStatistics
- isLocatedLocally(String) - Method in class org.infinispan.distribution.impl.DistributionManagerImpl
- isLocked() - Method in interface org.infinispan.lock.api.ClusteredLock
-
Returns a
CompletableFuture<Boolean>
holdingtrue
when the lock is locked andfalse
when the lock is released. - isLocked() - Method in class org.infinispan.util.concurrent.locks.impl.InfinispanLock
-
It checks if the lock is acquired.
- isLocked(Object) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticLockManager
- isLocked(Object) - Method in class org.infinispan.extendedstats.wrappers.TopKeyLockManager
- isLocked(Object) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
- isLocked(Object) - Method in interface org.infinispan.util.concurrent.locks.impl.LockContainer
- isLocked(Object) - Method in class org.infinispan.util.concurrent.locks.impl.PerKeyLockContainer
- isLocked(Object) - Method in class org.infinispan.util.concurrent.locks.impl.StripedLockContainer
- isLocked(Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
-
Tests if the
key
is locked. - isLockedByMe() - Method in interface org.infinispan.lock.api.ClusteredLock
-
Returns a
CompletableFuture<Boolean>
holdingtrue
when the lock is owned by the caller andfalse
when the lock is owned by someone else or it's released. - isLogEvent() - Method in class org.infinispan.tasks.TaskContext
-
Whether executing this task will generate an event in the event log
- isLogFile(int) - Method in class org.infinispan.persistence.sifs.FileProvider
- isLostSegment() - Method in interface org.infinispan.reactive.publisher.impl.SegmentAwarePublisherSupplier.NotificationWithLost
-
Whether this notification is for a lost segment
- isLowerBoundReached() - Method in exception org.infinispan.counter.exception.CounterOutOfBoundsException
- isLowLevelTrace() - Method in class org.infinispan.configuration.cache.IndexWriterConfiguration
- isManuallyDegraded() - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
- isManuallyDegraded() - Method in class org.infinispan.topology.ClusterCacheStatus
- isMarkedForRollback() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
- isMarkedForRollback() - Method in interface org.infinispan.transaction.xa.CacheTransaction
- isMarshallable(Class<?>) - Method in class org.infinispan.commons.marshall.MarshallableTypeHints
-
Returns whether a type can be serialized.
- isMarshallable(Object) - Method in class org.infinispan.client.hotrod.marshall.BytesOnlyMarshaller
- isMarshallable(Object) - Method in class org.infinispan.commons.marshall.IdentityMarshaller
- isMarshallable(Object) - Method in class org.infinispan.commons.marshall.ImmutableProtoStreamMarshaller
- isMarshallable(Object) - Method in class org.infinispan.commons.marshall.JavaSerializationMarshaller
- isMarshallable(Object) - Method in interface org.infinispan.commons.marshall.Marshaller
-
A method that checks whether the given object is marshallable as per the rules of this marshaller.
- isMarshallable(Object) - Method in interface org.infinispan.commons.marshall.StreamAwareMarshaller
-
A method that checks whether the given object is marshallable as per the rules of this marshaller.
- isMarshallable(Object) - Method in class org.infinispan.commons.marshall.StringMarshaller
- isMarshallable(Object) - Method in class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller
- isMarshallable(Object) - Method in class org.infinispan.jboss.marshalling.core.JBossUserMarshaller
- isMarshallable(Object) - Method in class org.infinispan.marshall.core.GlobalMarshaller
- isMarshallable(Object) - Method in class org.infinispan.persistence.remote.wrapper.HotRodEntryMarshaller
-
Deprecated.
- isMarshallableCandidate(Object) - Method in class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller
- isMarshallableCandidate(Object) - Method in class org.infinispan.jboss.marshalling.core.JBossMarshaller
- isMavenArtifact(String) - Static method in class org.infinispan.commons.maven.MavenArtifact
- isMaxIdleExpirable() - Method in interface org.infinispan.container.entries.InternalCacheValue
- isMaxIdleExpirable() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
- isMaxIdleExpirable() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue
- isMaxIdleExpirable() - Method in class org.infinispan.container.entries.TransientCacheValue
- isMaxIdleExpirable() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
- isMediaTypeChanged() - Method in class org.infinispan.configuration.cache.ContentTypeConfiguration
- isMergeView() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
- isMergeView() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
- isMetadata() - Method in class org.infinispan.server.hotrod.iteration.IterableIterationResult
- isMinorityPartition(List<Address>, List<Address>) - Method in class org.infinispan.partitionhandling.impl.PreferConsistencyStrategy
- isMiss() - Method in class org.infinispan.functional.impl.StatsEnvelope
- isModified() - Method in class org.infinispan.commons.configuration.attributes.Attribute
- isModified() - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Returns whether any attributes in this set have been modified
- isModified() - Method in class org.infinispan.commons.configuration.attributes.ConfigurationElement
- isModified() - Method in class org.infinispan.configuration.global.GlobalStatePathConfiguration
- isModified() - Method in class org.infinispan.notifications.cachelistener.filter.EventType
- isModified() - Method in interface org.infinispan.reactive.publisher.impl.ModifiedValueFunction
-
This method should return true when this function changes the actual values of the Publisher.
- isModified() - Method in class org.infinispan.stream.impl.CacheIntermediatePublisher
- isMulticastCapable() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- isMulticastCapable() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- isMulticastCapable() - Method in interface org.infinispan.remoting.transport.Transport
-
Tests whether the transport supports true multicast
- isMultiValued() - Method in class org.infinispan.search.mapper.mapping.metamodel.ObjectFieldMetamodel
- isMultiValued() - Method in class org.infinispan.search.mapper.mapping.metamodel.ValueFieldMetamodel
- isMultiValuedInRoot() - Method in class org.infinispan.search.mapper.mapping.metamodel.ObjectFieldMetamodel
- isMultiValuedInRoot() - Method in class org.infinispan.search.mapper.mapping.metamodel.ValueFieldMetamodel
- isNameChar(char) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- isNameStartChar(char) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- isNested() - Method in class org.infinispan.search.mapper.mapping.metamodel.ObjectFieldMetamodel
- isNext(int, long, int) - Method in class org.infinispan.distribution.TriangleOrderManager
- isNoNamespaceAttribute(ConfigurationReader, int) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- isNonBlocking() - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
- isNotificationAllowed(FlagAffectedCommand, List<CacheEntryListenerInvocation<K, V>>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- isNotModifiedSince(String, Long) - Static method in class org.infinispan.rest.DateUtils
- isNull() - Method in class org.infinispan.commons.configuration.attributes.Attribute
- isNull() - Method in class org.infinispan.commons.dataconversion.internal.Json
- isNull() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
- isNull() - Method in interface org.infinispan.container.entries.CacheEntry
-
Tests whether the entry represents a null value, typically used for repeatable read.
- isNull() - Method in class org.infinispan.container.entries.ClearCacheEntry
- isNull() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
- isNull() - Method in class org.infinispan.container.entries.NullCacheEntry
- isNull() - Method in class org.infinispan.container.entries.ReadCommittedEntry
- isNull() - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
-
Deprecated.Checks that the left argument is null.
- isNumber() - Method in class org.infinispan.commons.dataconversion.internal.Json
- isObject() - Method in class org.infinispan.commons.dataconversion.internal.Json
- isObjectStorage() - Method in class org.infinispan.client.hotrod.DataFormat
- isObjectStorage() - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- isObjectStorage() - Method in interface org.infinispan.client.hotrod.impl.InternalRemoteCache
- isObjectStorage() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- isObjectStorage() - Method in class org.infinispan.configuration.cache.ContentTypeConfiguration
- isObjectStorage() - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
- isObjectStorage() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
- isOffHeap() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
- isOffline() - Method in class org.infinispan.xsite.response.AutoStateTransferResponse
- isOffline() - Method in class org.infinispan.xsite.status.AbstractMixedSiteStatus
- isOffline() - Method in class org.infinispan.xsite.status.AbstractSiteStatusBuilder
- isOffline() - Method in class org.infinispan.xsite.status.ContainerSiteStatusBuilder
- isOffline() - Method in class org.infinispan.xsite.status.OfflineSiteStatus
- isOffline() - Method in class org.infinispan.xsite.status.OnlineSiteStatus
- isOffline() - Method in interface org.infinispan.xsite.status.SiteStatus
- ISOLATED - Enum constant in enum org.infinispan.tasks.TaskInstantiationMode
-
Creates a new instance for every invocation
- ISOLATION - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- ISOLATION_LEVEL - Static variable in class org.infinispan.configuration.cache.LockingConfiguration
- isolationLevel() - Method in class org.infinispan.configuration.cache.LockingConfiguration
-
Cache isolation level.
- isolationLevel() - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
- isolationLevel(IsolationLevel) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
-
Cache isolation level.
- IsolationLevel - Enum in org.infinispan.util.concurrent
-
Various transaction isolation levels as an enumerated class.
- isOlder(byte) - Method in enum org.infinispan.server.hotrod.HotRodVersion
-
Checks whether the supplied version is older than the version represented by this object
- isOnePhaseCommit(Configuration) - Static method in class org.infinispan.configuration.cache.Configurations
- isOnline() - Method in class org.infinispan.xsite.status.AbstractMixedSiteStatus
- isOnline() - Method in class org.infinispan.xsite.status.AbstractSiteStatusBuilder
- isOnline() - Method in class org.infinispan.xsite.status.ContainerSiteStatusBuilder
- isOnline() - Method in class org.infinispan.xsite.status.OfflineSiteStatus
- isOnline() - Method in class org.infinispan.xsite.status.OnlineSiteStatus
- isOnline() - Method in interface org.infinispan.xsite.status.SiteStatus
- isOnlyPrimary() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- isOpen() - Method in class org.infinispan.io.ReadableGridFileChannel
-
Deprecated.
- isOpen() - Method in class org.infinispan.io.WritableGridFileChannel
-
Deprecated.
- isOpened() - Method in class org.infinispan.util.concurrent.ReclosableLatch
- isOriginatorMissing(Collection<Address>) - Method in class org.infinispan.xsite.statetransfer.BaseXSiteStateProviderState
- isOriginatorMissing(Collection<Address>) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateProviderState
-
Returns
- isOriginatorMissing(GlobalTransaction) - Method in class org.infinispan.server.hotrod.tx.ServerTransactionOriginatorChecker
- isOriginatorMissing(GlobalTransaction) - Method in class org.infinispan.transaction.impl.ClusteredTransactionOriginatorChecker
- isOriginatorMissing(GlobalTransaction) - Method in interface org.infinispan.transaction.impl.TransactionOriginatorChecker
- isOriginatorMissing(GlobalTransaction, Collection<Address>) - Method in class org.infinispan.server.hotrod.tx.ServerTransactionOriginatorChecker
- isOriginatorMissing(GlobalTransaction, Collection<Address>) - Method in class org.infinispan.transaction.impl.ClusteredTransactionOriginatorChecker
- isOriginatorMissing(GlobalTransaction, Collection<Address>) - Method in interface org.infinispan.transaction.impl.TransactionOriginatorChecker
- isOriginLocal() - Method in class org.infinispan.context.impl.AbstractInvocationContext
- isOriginLocal() - Method in class org.infinispan.context.impl.ImmutableContext
- isOriginLocal() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
- isOriginLocal() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
- isOriginLocal() - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
- isOriginLocal() - Method in interface org.infinispan.context.InvocationContext
-
Returns true if the call was originated locally, false if it is the result of a remote rpc.
- isOriginLocal() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
- isOriginLocal() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- isOriginLocal() - Method in interface org.infinispan.notifications.cachelistener.event.TransactionalEvent
- isOrphan() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
-
A remote transaction is orphan if the node on which the transaction originated (ie the originator) is no longer part of the cluster.
- isParallel() - Method in class org.infinispan.stream.impl.AbstractCacheStream
- isParallel() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- isParallel() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- isParallel() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- isParallel() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- isParallel() - Method in class org.infinispan.stream.impl.LockedStreamImpl
- isParallel() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- isPermissive() - Method in interface org.infinispan.security.AuthorizationManager
- isPermissive() - Method in class org.infinispan.security.impl.AuthorizationManagerImpl
- isPermissive() - Method in class org.infinispan.security.impl.PermissiveAuthorizationManager
- isPersistent() - Method in class org.infinispan.commons.configuration.attributes.Attribute
- ISPNBlockingThreadGroup(String) - Constructor for class org.infinispan.commons.ThreadGroups.ISPNBlockingThreadGroup
- ISPNNonBlockingThreadGroup(String) - Constructor for class org.infinispan.commons.ThreadGroups.ISPNNonBlockingThreadGroup
- isPre() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
- isPre() - Method in interface org.infinispan.notifications.cachelistener.event.Event
- isPre() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- isPreEvent() - Method in class org.infinispan.notifications.cachelistener.filter.EventType
- isPrepared() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareLocalTransaction
- isPrepared() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
- isPrepared() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryAwareTransaction
- isPrepareSent() - Method in class org.infinispan.transaction.impl.LocalTransaction
- isPrimary() - Method in class org.infinispan.distribution.DistributionInfo
- isPrimaryIdentifier() - Method in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.Parameter
- isPrimaryOwner() - Method in enum org.infinispan.configuration.cache.Index
-
Deprecated.in 10.1. Equivalent to a simple equality comparison to
Index.PRIMARY_OWNER
. - isPrimaryOwner(ConsistentHash, Object) - Method in class org.infinispan.stream.impl.AbstractCacheStream
- isPrimaryRelayNode() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- isPrimaryRelayNode() - Method in interface org.infinispan.remoting.transport.Transport
- isPrimitive() - Method in class org.infinispan.commons.dataconversion.internal.Json
- isPrivateCache(String) - Method in class org.infinispan.registry.impl.InternalCacheRegistryImpl
- isPrivileged() - Static method in class org.infinispan.security.Security
- isProjectable() - Method in class org.infinispan.search.mapper.mapping.metamodel.ValueFieldMetamodel
- isProtected() - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Returns whether this attribute set is protected
- isProtobufStorage() - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
- isProtoBufStorage() - Method in class org.infinispan.configuration.cache.ContentTypeConfiguration
- isQueryable() - Method in class org.infinispan.encoding.impl.StorageConfigurationManager
- isRaftAvailable() - Method in enum org.infinispan.remoting.transport.impl.EmptyRaftManager
- isRaftAvailable() - Static method in enum org.infinispan.remoting.transport.jgroups.RaftUtil
- isRaw() - Method in class org.infinispan.commons.dataconversion.internal.Json
- isRead() - Method in interface org.infinispan.container.entries.MVCCEntry
-
Check is this entry as loaded from the cache (as opposed to generated by the application using write-only command), mostly for purposes of the write skew check.
- isRead() - Method in class org.infinispan.container.entries.RepeatableReadEntry
- isRead() - Method in interface org.infinispan.functional.impl.EntryViews.AccessLoggingReadWriteView
- isReadOnly() - Method in class org.infinispan.extendedstats.TransactionStatistics
- isReadOnly() - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- isReadOnly() - Method in class org.infinispan.transaction.impl.LocalTransaction
- isReadOwner() - Method in class org.infinispan.distribution.DistributionInfo
- isReadOwner(Object) - Method in class org.infinispan.distribution.LocalizedCacheTopology
- isReady() - Method in class org.infinispan.remoting.inboundhandler.action.DefaultReadyAction
- isReady() - Method in interface org.infinispan.remoting.inboundhandler.action.ReadyAction
- isReady() - Method in interface org.infinispan.util.concurrent.BlockingRunnable
- isReady() - Method in interface org.infinispan.util.concurrent.locks.PendingLockPromise
- isReadyForHttpChallenge() - Method in interface org.infinispan.rest.authentication.Authenticator
-
Returns whether the realm backing this authenticator is ready to authenticate users
- isRebalance() - Method in enum org.infinispan.topology.CacheTopology.Phase
- isRebalanceEnabled() - Method in class org.infinispan.topology.ClusterCacheStatus
- isRebalanceInProgress() - Method in class org.infinispan.topology.ClusterCacheStatus
- isRebalancingEnabled() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- isRebalancingEnabled() - Method in class org.infinispan.cache.impl.CacheImpl
- isRebalancingEnabled() - Method in class org.infinispan.manager.CacheManagerInfo
- isRebalancingEnabled() - Method in interface org.infinispan.topology.ClusterTopologyManager
- isRebalancingEnabled() - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- isRebalancingEnabled() - Method in interface org.infinispan.topology.LocalTopologyManager
-
Checks whether rebalancing is enabled for the entire cluster.
- isRebalancingEnabled() - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- isRebalancingEnabled() - Method in class org.infinispan.topology.ManagerStatusResponse
- isRebalancingEnabled(String) - Method in interface org.infinispan.topology.ClusterTopologyManager
-
Returns whether rebalancing is enabled or disabled for this container.
- isRebalancingEnabled(String) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- isRecoverable() - Method in class org.infinispan.server.hotrod.tx.table.TxState
- isRecoveryEnabled() - Method in enum org.infinispan.configuration.cache.TransactionMode
- isRecoveryEnabled() - Method in enum org.infinispan.configuration.parsing.CacheParser.TransactionMode
- isReentrant() - Method in class org.infinispan.lock.api.ClusteredLockConfiguration
- isRegistered(Class<? extends Encoder>) - Method in interface org.infinispan.marshall.core.EncoderRegistry
-
Deprecated, for removal: This API element is subject to removal in a future version.
- isRegistered(Class<? extends Encoder>) - Method in class org.infinispan.marshall.core.EncoderRegistryImpl
- isRehashInProgress() - Method in interface org.infinispan.distribution.DistributionManager
-
Tests whether a rehash is in progress
- isRehashInProgress() - Method in class org.infinispan.distribution.impl.DistributionManagerImpl
-
Tests whether a rehash is in progress
- isRelayNode() - Method in class org.infinispan.manager.CacheManagerInfo
- isRelayNode() - Method in class org.infinispan.manager.DefaultCacheManager
- isRemote() - Method in enum org.infinispan.extendedstats.container.ExtendedStatistic
- isRemote() - Method in class org.infinispan.transaction.xa.GlobalTransaction
- isRemovalBased() - Method in enum org.infinispan.eviction.EvictionStrategy
-
The cache will remove other entries to make room to limit memory growth
- isRemove() - Method in class org.infinispan.notifications.cachelistener.filter.EventType
- isRemoved() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
- isRemoved() - Method in interface org.infinispan.container.entries.CacheEntry
- isRemoved() - Method in class org.infinispan.container.entries.ClearCacheEntry
- isRemoved() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
- isRemoved() - Method in class org.infinispan.container.entries.NullCacheEntry
- isRemoved() - Method in class org.infinispan.container.entries.ReadCommittedEntry
- isRemoved(String, int, int) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
- isRepeated() - Method in class org.infinispan.commons.configuration.attributes.Attribute
- isRepeated() - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
- isRepeating() - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter.Tag
- isReplicated() - Method in enum org.infinispan.configuration.cache.CacheMode
- isReplicated() - Method in interface org.infinispan.distribution.ch.ConsistentHash
- isReplicated() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
- isReset() - Method in class org.infinispan.extendedstats.container.ConcurrentGlobalContainer
- isRestarting() - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
- isRetry() - Method in class org.infinispan.notifications.cachelistener.filter.EventType
- isReturnValueExpected() - Method in interface org.infinispan.commands.ReplicableCommand
-
If true, a return value will be provided when performed remotely.
- isReturnValueExpected() - Method in class org.infinispan.expiration.impl.TouchCommand
- isReturnValueExpected() - Method in class org.infinispan.manager.impl.ReplicableManagerFunctionCommand
- isReturnValueExpected() - Method in class org.infinispan.manager.impl.ReplicableRunnableCommand
- isReturnValueExpected() - Method in class org.infinispan.notifications.cachelistener.cluster.MultiClusterEventCommand
- isReturnValueExpected() - Method in class org.infinispan.server.hotrod.command.tx.ForwardCommitCommand
- isReturnValueExpected() - Method in class org.infinispan.topology.HeartBeatCommand
- isReturnValueExpected() - Method in class org.infinispan.xsite.commands.XSiteAmendOfflineStatusCommand
- isReturnValueExpected() - Method in class org.infinispan.xsite.commands.XSiteAutoTransferStatusCommand
- isReturnValueExpected() - Method in class org.infinispan.xsite.commands.XSiteBringOnlineCommand
- isReturnValueExpected() - Method in class org.infinispan.xsite.commands.XSiteLocalEventCommand
- isReturnValueExpected() - Method in class org.infinispan.xsite.commands.XSiteOfflineStatusCommand
- isReturnValueExpected() - Method in class org.infinispan.xsite.commands.XSiteSetStateTransferModeCommand
- isReturnValueExpected() - Method in class org.infinispan.xsite.commands.XSiteStateTransferCancelSendCommand
- isReturnValueExpected() - Method in class org.infinispan.xsite.commands.XSiteStateTransferClearStatusCommand
- isReturnValueExpected() - Method in class org.infinispan.xsite.commands.XSiteStateTransferFinishReceiveCommand
- isReturnValueExpected() - Method in class org.infinispan.xsite.commands.XSiteStateTransferFinishSendCommand
- isReturnValueExpected() - Method in class org.infinispan.xsite.commands.XSiteStateTransferRestartSendingCommand
- isReturnValueExpected() - Method in class org.infinispan.xsite.commands.XSiteStateTransferStartReceiveCommand
- isReturnValueExpected() - Method in class org.infinispan.xsite.commands.XSiteStateTransferStartSendCommand
- isReturnValueExpected() - Method in class org.infinispan.xsite.commands.XSiteStateTransferStatusRequestCommand
- isReturnValueExpected() - Method in class org.infinispan.xsite.commands.XSiteStatusCommand
- isReturnValueExpected() - Method in class org.infinispan.xsite.commands.XSiteTakeOfflineCommand
- isReturnValueExpected() - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
- isRunning() - Method in class org.infinispan.client.hotrod.event.impl.EventDispatcher
- isRunning() - Method in interface org.infinispan.factories.impl.ComponentRef
- isRunning() - Method in interface org.infinispan.query.Indexer
- isRunning() - Method in class org.infinispan.server.core.transport.NettyTransport
- isRunning() - Method in interface org.infinispan.server.core.transport.Transport
- isRunning(String) - Method in class org.infinispan.manager.DefaultCacheManager
- isRunning(String) - Method in interface org.infinispan.manager.EmbeddedCacheManager
-
Tests whether a cache is running.
- isRunning(String) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
- isS(char) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- isSafeClass(String) - Method in class org.infinispan.commons.configuration.ClassAllowList
- isSafeClass(String, List<String>) - Static method in class org.infinispan.commons.marshall.MarshallUtil
-
Checks whether class name is matched by the class name white list regular expressions provided.
- isSameAs(GlobalTransaction, boolean, long) - Method in class org.infinispan.server.hotrod.tx.table.TxState
- isSameMachine(TopologyAwareAddress) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
- isSameMachine(TopologyAwareAddress) - Method in interface org.infinispan.remoting.transport.TopologyAwareAddress
- isSameRack(TopologyAwareAddress) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
- isSameRack(TopologyAwareAddress) - Method in interface org.infinispan.remoting.transport.TopologyAwareAddress
- isSameRM(XAResource) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
-
the only situation in which it returns true is when the other xa resource pertains to the same cache, on the same node.
- isSameSite(TopologyAwareAddress) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
- isSameSite(TopologyAwareAddress) - Method in interface org.infinispan.remoting.transport.TopologyAwareAddress
- isScattered() - Method in enum org.infinispan.configuration.cache.CacheMode
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 14.0, will be removed in 16.0.
- isSearchable() - Method in class org.infinispan.search.mapper.mapping.metamodel.ValueFieldMetamodel
- isSegmentComplete() - Method in interface org.infinispan.reactive.publisher.impl.SegmentPublisherSupplier.Notification
-
Whether this notification is for a completed segmented
- isSegmentLocalToNode(Address, int) - Method in interface org.infinispan.distribution.ch.ConsistentHash
-
Check if a segment is local to a given member.
- isSegmentLocalToNode(Address, int) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
- isSegmentLocalToNode(Address, int) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
- isSegmentLocalToNode(Address, int) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
- isSegmentReadOwner(int) - Method in class org.infinispan.distribution.LocalizedCacheTopology
- isSegmentWriteOwner(int) - Method in class org.infinispan.distribution.LocalizedCacheTopology
- isSending() - Method in class org.infinispan.xsite.statetransfer.BaseXSiteStateProviderState
- isSending() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateProviderState
- isSeqIdOld(long, int, Object, byte[]) - Method in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
- isServerError() - Method in exception org.infinispan.client.hotrod.exceptions.HotRodClientException
- isShutdown() - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
- isShutdown() - Method in class org.infinispan.executors.LazyInitializingExecutorService
- isShutdown() - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
- isShutdown() - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- isShutdown() - Method in class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
- isShutdown() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
- isShuttingDown() - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- isSingleton() - Method in class org.infinispan.spring.embedded.InfinispanDefaultCacheFactoryBean
-
Always returns
true
. - isSingleton() - Method in class org.infinispan.spring.embedded.provider.ContainerEmbeddedCacheManagerFactoryBean
- isSingleton() - Method in class org.infinispan.spring.embedded.provider.SpringEmbeddedCacheManagerFactoryBean
-
Always returns
true
. - isSingleton() - Method in class org.infinispan.spring.embedded.support.InfinispanEmbeddedCacheManagerFactoryBean
-
Always returns
true
. - isSingleton() - Method in class org.infinispan.spring.embedded.support.InfinispanNamedEmbeddedCacheFactoryBean
-
Always returns
true
. - isSingleton() - Method in class org.infinispan.spring.remote.provider.ContainerRemoteCacheManagerFactoryBean
- isSingleton() - Method in class org.infinispan.spring.remote.provider.SpringRemoteCacheManagerFactoryBean
-
Always return
true
. - isSingleton() - Method in class org.infinispan.spring.remote.support.InfinispanNamedRemoteCacheFactoryBean
-
Always return true.
- isSingleton() - Method in class org.infinispan.spring.remote.support.InfinispanRemoteCacheManagerFactoryBean
-
Always return
true
. - isSiteCoordinator() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- isSiteCoordinator() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- isSiteCoordinator() - Method in interface org.infinispan.remoting.transport.Transport
- isSkip(Params) - Static method in enum org.infinispan.functional.Param.StatisticsMode
- isSkipSharedStore() - Method in interface org.infinispan.container.entries.MVCCEntry
- isSkipSharedStore() - Method in class org.infinispan.container.entries.ReadCommittedEntry
- isSortable() - Method in class org.infinispan.search.mapper.mapping.metamodel.ValueFieldMetamodel
- isSsl() - Method in class org.infinispan.client.hotrod.impl.HotRodURI
- isStarted() - Method in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
- isStarted() - Method in interface org.infinispan.affinity.KeyAffinityService
-
Checks weather or not the service is started.
- isStarted() - Method in interface org.infinispan.client.hotrod.RemoteCacheContainer
- isStarted() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
- isStateTransferInProgress() - Method in interface org.infinispan.conflict.ConflictManager
- isStateTransferInProgress() - Method in class org.infinispan.xsite.statetransfer.RemoteSiteStatus
- isStateTransferStore(StoreConfiguration) - Static method in class org.infinispan.configuration.cache.Configurations
-
Deprecated, for removal: This API element is subject to removal in a future version.since 14.0. Returns true if the store is not shared.
- isStatistics() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- isStatisticsEnabled() - Method in class org.infinispan.query.impl.InfinispanQueryStatisticsInfo
- isStatisticsEnabled() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- isStatisticsEnabled() - Method in class org.infinispan.stats.impl.AbstractClusterStats
- isStatisticsEnabled() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
-
Deprecated.
- isStatisticsEnabled() - Method in class org.infinispan.stats.impl.LocalContainerStatsImpl
- isStatusOk() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferCollector
- isStopped() - Method in class org.infinispan.remoting.transport.jgroups.ClusterView
- isStopping() - Method in enum org.infinispan.lifecycle.ComponentStatus
- isStorageBinary() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
- isStorageFormatFilterable() - Method in interface org.infinispan.commons.dataconversion.Encoder
-
Deprecated.
- isStorageFormatFilterable() - Method in class org.infinispan.commons.dataconversion.IdentityEncoder
-
Deprecated.
- isStorageFormatFilterable() - Method in class org.infinispan.commons.dataconversion.MarshallerEncoder
-
Deprecated.
- isStorageFormatFilterable() - Method in class org.infinispan.commons.dataconversion.UTF8Encoder
-
Deprecated.
- isStoreMetadata(Metadata, InternalCacheEntry) - Static method in class org.infinispan.container.impl.InternalEntryFactoryImpl
-
Indicates whether the entire metadata object needs to be stored or not.
- isString() - Method in class org.infinispan.commons.dataconversion.internal.Json
- isSuccessful() - Method in interface org.infinispan.commands.ReplicableCommand
-
If true, a return value will be marshalled as a
SuccessfulResponse
, otherwise it will be marshalled as aUnsuccessfulResponse
. - isSuccessful() - Method in class org.infinispan.remoting.responses.InvalidResponse
- isSuccessful() - Method in class org.infinispan.remoting.responses.PrepareResponse
- isSuccessful() - Method in interface org.infinispan.remoting.responses.Response
- isSuccessful() - Method in class org.infinispan.remoting.responses.SuccessfulResponse
- isSuccessful() - Method in class org.infinispan.remoting.responses.UnsuccessfulResponse
- isSuccessful() - Method in class org.infinispan.remoting.responses.UnsureResponse
- isSuccessful() - Method in class org.infinispan.xsite.response.AutoStateTransferResponse
- isSuccessfullyDone(Object) - Static method in class org.infinispan.interceptors.BaseAsyncInterceptor
- isSupportedType(Class<?>) - Method in class org.infinispan.persistence.keymappers.DefaultTwoWayKey2StringMapper
- isSupportedType(Class<?>) - Method in interface org.infinispan.persistence.keymappers.Key2StringMapper
-
Do we support this key type?
- isSupportedType(Class<?>) - Method in class org.infinispan.persistence.keymappers.WrappedByteArrayOrPrimitiveMapper
- isSuspectExceptionInChain(Throwable) - Static method in exception org.infinispan.remoting.transport.jgroups.SuspectException
- isSuspendTxAfterInvocation() - Method in class org.infinispan.batch.BatchContainer
- isSync() - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
- isSync() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
- isSync() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
- isSync() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
- isSync() - Method in class org.infinispan.xsite.statetransfer.AsyncProviderState
- isSync() - Method in class org.infinispan.xsite.statetransfer.RemoteSiteStatus
- isSync() - Method in class org.infinispan.xsite.statetransfer.SyncProviderState
- isSync() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateProviderState
- isSync(String) - Method in class org.infinispan.remoting.transport.AggregateBackupResponse
- isSync(String) - Method in interface org.infinispan.remoting.transport.BackupResponse
- isSync(String) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsBackupResponse
- isSyncBackup() - Method in class org.infinispan.configuration.cache.BackupConfiguration
- isSynchronous() - Method in enum org.infinispan.configuration.cache.CacheMode
- isSynchronous() - Method in enum org.infinispan.configuration.parsing.CacheParser.Mode
- isSynchronous() - Method in enum org.infinispan.remoting.rpc.ResponseMode
- isTaskRunning() - Method in class org.infinispan.container.versioning.irac.DefaultIracTombstoneManager
- isTaskRunning() - Method in interface org.infinispan.container.versioning.irac.IracTombstoneManager
- isTaskRunning() - Method in class org.infinispan.container.versioning.irac.NoOpIracTombstoneManager
- isTemplate() - Method in class org.infinispan.configuration.cache.Configuration
- isTerminated() - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
- isTerminated() - Method in class org.infinispan.executors.LazyInitializingExecutorService
- isTerminated() - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
- isTerminated() - Method in enum org.infinispan.lifecycle.ComponentStatus
- isTerminated() - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- isTerminated() - Method in class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
- isTerminated() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
- isTimeExpired(long) - Method in class org.infinispan.commons.time.DefaultTimeService
- isTimeExpired(long) - Method in interface org.infinispan.commons.time.TimeService
- isTombstoneCleanupTaskRunning() - Method in class org.infinispan.xsite.irac.DefaultIracManager
- isTouched() - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
- isTouchEvenIfExpired() - Method in class org.infinispan.expiration.impl.TouchCommand
- isTraceEnabled() - Method in interface org.infinispan.util.logging.LogSupplier
- isTracingPropagationEnabled() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- isTransactional() - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- isTransactional() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- isTransactional() - Method in interface org.infinispan.client.hotrod.RemoteCache
- isTransactional() - Method in enum org.infinispan.transaction.TransactionMode
- isTransactional(String) - Method in interface org.infinispan.client.hotrod.RemoteCacheContainer
- isTransactional(String) - Method in class org.infinispan.client.hotrod.RemoteCacheManager
- isTransactionCompleted(GlobalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
- isTransactionPartiallyCommitted(GlobalTransaction) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
- isTransactionPartiallyCommitted(GlobalTransaction) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
-
It checks if the transaction resources (for example locks) can be released.
- isTransactionPartiallyCommitted(GlobalTransaction) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
- isTransactionPrepared(GlobalTransaction) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
-
Checks both internal state and transaction table's state for the given tx.
- isTransactionPrepared(GlobalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
- isTransactionSuccessful() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- isTransactionSuccessful() - Method in interface org.infinispan.notifications.cachelistener.event.TransactionCompletedEvent
- isTransactionValid() - Method in class org.infinispan.context.impl.LocalTxInvocationContext
- isTransactionValid() - Method in class org.infinispan.context.impl.RemoteTxInvocationContext
- isTransactionValid() - Method in interface org.infinispan.context.impl.TxInvocationContext
- isTransportEnabled() - Method in class org.infinispan.server.core.AbstractProtocolServer
- isTwoPhaseCommit() - Method in class org.infinispan.configuration.cache.BackupConfiguration
- isTxVersioned(Configuration) - Static method in class org.infinispan.configuration.cache.Configurations
- isUncertain() - Method in enum org.infinispan.distribution.DataLocality
-
Deprecated.
- isUpdated() - Method in enum org.infinispan.client.hotrod.impl.VersionedOperationResponse.RspCode
- isUpperBoundReached() - Method in exception org.infinispan.counter.exception.CounterOutOfBoundsException
- isUseSetter() - Method in class org.infinispan.factories.impl.MBeanMetadata.AttributeMetadata
- isValid() - Method in class org.infinispan.remoting.responses.InvalidResponse
- isValid() - Method in interface org.infinispan.remoting.responses.Response
- isValid() - Method in class org.infinispan.remoting.responses.ValidResponse
- isValid() - Method in class org.infinispan.xsite.response.AutoStateTransferResponse
- isValid(String) - Static method in class org.infinispan.util.ByteString
- isValidJson(byte[], Charset) - Static method in class org.infinispan.server.core.dataconversion.JsonTranscoder
- isValue() - Method in interface org.infinispan.reactive.publisher.impl.SegmentPublisherSupplier.Notification
-
Whether this notification contains a value, always non null if so
- isVersionActual(int, EntryVersion) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
- isVersionActual(int, EntryVersion) - Method in interface org.infinispan.scattered.ScatteredVersionManager
- isVersionPre12(Configuration) - Static method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
-
Is version previous to, and not including, 1.2?
- isViewIdAtLeast(int) - Method in class org.infinispan.remoting.transport.jgroups.ClusterView
- isVolatile() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
-
Does the index use a provider that does not persist upon restart?
- isWhitespace() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- isWhitespace() - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
-
Checks whether the current TEXT event contains only whitespace characters.
- isWired() - Method in interface org.infinispan.factories.impl.ComponentRef
- isWritable() - Method in class org.infinispan.factories.impl.MBeanMetadata.AttributeMetadata
- isWriteBackup() - Method in class org.infinispan.distribution.DistributionInfo
- isWriteOwner() - Method in class org.infinispan.distribution.DistributionInfo
- isWriteOwner(Object) - Method in class org.infinispan.distribution.LocalizedCacheTopology
- isXAEnabled() - Method in enum org.infinispan.configuration.cache.TransactionMode
- isXAEnabled() - Method in enum org.infinispan.configuration.parsing.CacheParser.TransactionMode
- isZeroCapacityNode() - Method in class org.infinispan.configuration.global.GlobalConfiguration
-
Returns true if this node is configured as a zero-capacity node.
- iter - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator
- IterableIterationResult - Class in org.infinispan.server.hotrod.iteration
- ITERATION_END - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- ITERATION_END_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- ITERATION_FILTER - Static variable in class org.infinispan.server.core.ExternalizerIds
- ITERATION_NEXT - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- ITERATION_NEXT_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- ITERATION_QUERY_FILTER_CONVERTER_FACTORY_NAME - Static variable in class org.infinispan.client.hotrod.filter.Filters
- ITERATION_START - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- ITERATION_START_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- iterationClosed(String) - Method in interface org.infinispan.client.hotrod.logging.Log
- IterationFilter<K,
V, C> - Class in org.infinispan.server.hotrod.iteration - IterationFilter(MediaType, MediaType, Optional<KeyValueFilterConverter<K, V, C>>) - Constructor for class org.infinispan.server.hotrod.iteration.IterationFilter
- IterationFilter.IterationFilterExternalizer - Class in org.infinispan.server.hotrod.iteration
- IterationFilterExternalizer() - Constructor for class org.infinispan.server.hotrod.iteration.IterationFilter.IterationFilterExternalizer
- IterationManager - Interface in org.infinispan.server.hotrod.iteration
- iterationNextResponse(HotRodHeader, HotRodServer, Channel, IterableIterationResult) - Method in class org.infinispan.server.hotrod.Encoder4x
- iterationNextResponse(HotRodHeader, HotRodServer, Channel, IterableIterationResult) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- IterationReaper - Class in org.infinispan.server.hotrod.iteration
- IterationReaper(IterationManager, String) - Constructor for class org.infinispan.server.hotrod.iteration.IterationReaper
- iterationStartResponse(HotRodHeader, HotRodServer, Channel, String) - Method in class org.infinispan.server.hotrod.Encoder4x
- iterationStartResponse(HotRodHeader, HotRodServer, Channel, String) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- IterationState - Interface in org.infinispan.server.hotrod.iteration
- iterationTransportObtained(SocketAddress, String) - Method in interface org.infinispan.client.hotrod.logging.Log
- iterator() - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
- iterator() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntrySet
- iterator() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySet
- iterator() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.KeySet
- iterator() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.Values
- iterator() - Method in interface org.infinispan.CacheStream
- iterator() - Method in class org.infinispan.client.hotrod.near.NearCacheService
- iterator() - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
- iterator() - Method in interface org.infinispan.commons.util.CloseableIterable
- iterator() - Method in interface org.infinispan.commons.util.CloseableIteratorCollection
- iterator() - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
- iterator() - Method in class org.infinispan.commons.util.FastCopyHashMap.EntrySet
- iterator() - Method in class org.infinispan.commons.util.FastCopyHashMap.KeySet
- iterator() - Method in class org.infinispan.commons.util.FastCopyHashMap.Values
- iterator() - Method in class org.infinispan.commons.util.ForwardingList
- iterator() - Method in class org.infinispan.commons.util.ImmutableHopscotchHashSet
- iterator() - Method in class org.infinispan.commons.util.ImmutableIntSet
-
Deprecated.
- iterator() - Method in class org.infinispan.commons.util.ImmutableListCopy.ImmutableSubList
- iterator() - Method in class org.infinispan.commons.util.ImmutableListCopy
- iterator() - Method in interface org.infinispan.commons.util.IntSet
-
A primtive iterator that allows iteration over the int values.
- iterator() - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- iterator() - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- iterator() - Method in interface org.infinispan.container.DataContainer
- iterator() - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- iterator() - Method in class org.infinispan.container.impl.DefaultDataContainer
- iterator() - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
- iterator() - Method in class org.infinispan.container.offheap.OffHeapDataContainer
- iterator() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
- iterator() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareEntryCollection
- iterator() - Method in class org.infinispan.functional.impl.MetaParams
- iterator() - Method in class org.infinispan.InternalCacheSet
- iterator() - Method in interface org.infinispan.LockedStream
-
This method is not supported when using a
LockedStream
- iterator() - Method in interface org.infinispan.query.dsl.Query
-
Returns a
CloseableIterator
over the results. - iterator() - Method in interface org.infinispan.query.impl.IndexedQuery
- iterator() - Method in class org.infinispan.query.impl.IndexedQueryImpl
- iterator() - Method in class org.infinispan.rest.framework.impl.Invocations
- iterator() - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- iterator() - Method in class org.infinispan.stream.impl.DistributedCacheStream
- iterator() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- iterator() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- iterator() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- iterator() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- iterator() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- iterator() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- iterator() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- iterator() - Method in class org.infinispan.stream.impl.LockedStreamImpl
- iterator() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- iterator() - Method in class org.infinispan.util.CacheSetMapper
- iterator() - Method in class org.infinispan.util.CollectionMapper
- iterator() - Method in class org.infinispan.util.WriteableCacheCollectionMapper
- iterator(Iterator<? extends E>) - Static method in class org.infinispan.commons.util.Closeables
-
Creates a closeable iterator from the given iterator that does nothing when close is called.
- iterator(BaseStream<R, Stream<R>>) - Static method in class org.infinispan.commons.util.Closeables
-
Creates a closeable iterator that when closed will close the underlying stream as well
- iterator(IntSet) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- iterator(IntSet) - Method in class org.infinispan.container.impl.DefaultDataContainer
- iterator(IntSet) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
- iterator(IntSet) - Method in interface org.infinispan.container.impl.InternalDataContainer
-
Same as
DataContainer.iterator()
except that only entries that map to the provided segments are returned via the iterator. - iterator(IntSet) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- iterator(IntSet) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
- iterator(Publisher<E>, int) - Static method in class org.infinispan.commons.util.Closeables
-
Converts a
Publisher
to aCloseableIterator
by utilizing items fetched into an array and refetched as they are consumed from the iterator. - iterator(Publisher<E>, int) - Static method in class org.infinispan.util.Closeables
-
Deprecated, for removal: This API element is subject to removal in a future version.since 11.0 Please use
Closeables.iterator(Publisher, int)
instead. - iteratorIncludingExpired() - Method in interface org.infinispan.container.DataContainer
-
Same as
DataContainer.iterator()
except that is also returns expired entries. - iteratorIncludingExpired() - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- iteratorIncludingExpired() - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
- iteratorIncludingExpired() - Method in class org.infinispan.container.impl.DefaultDataContainer
- iteratorIncludingExpired() - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
- iteratorIncludingExpired() - Method in class org.infinispan.container.impl.L1SegmentedDataContainer
- iteratorIncludingExpired() - Method in class org.infinispan.container.offheap.OffHeapDataContainer
- iteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- iteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
- iteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.DefaultDataContainer
- iteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
- iteratorIncludingExpired(IntSet) - Method in interface org.infinispan.container.impl.InternalDataContainer
-
Same as
DataContainer.iteratorIncludingExpired()
except that only entries that map to the provided segments are returned via the iterator. - iteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.L1SegmentedDataContainer
- iteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- iteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
- IteratorMapper<E,
S> - Class in org.infinispan.commons.util -
A iterator that maps each value to the output of the Function.
- IteratorMapper(Iterator<? extends E>, Function<? super E, ? extends S>) - Constructor for class org.infinispan.commons.util.IteratorMapper
- iteratorOperation - Variable in class org.infinispan.stream.impl.AbstractCacheStream
J
- JAVA_SERIAL_ALLOWLIST - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- JAVA_SERIAL_WHITELIST - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
-
Deprecated, for removal: This API element is subject to removal in a future version.
- JAVA_SERIALIZATION - 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.
- javaClass() - Method in interface org.infinispan.search.mapper.mapping.SearchIndexedEntity
- JavaSerializationEncoder - Class in org.infinispan.commons.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.
- JavaSerializationEncoder(ClassAllowList) - Constructor for class org.infinispan.commons.dataconversion.JavaSerializationEncoder
-
Deprecated.
- JavaSerializationMarshaller - Class in org.infinispan.commons.marshall
-
Standard Java serialization marshaller.
- JavaSerializationMarshaller() - Constructor for class org.infinispan.commons.marshall.JavaSerializationMarshaller
- JavaSerializationMarshaller(ClassAllowList) - Constructor for class org.infinispan.commons.marshall.JavaSerializationMarshaller
- JavaSerializationTranscoder - Class in org.infinispan.encoding.impl
- JavaSerializationTranscoder(ClassAllowList) - Constructor for class org.infinispan.encoding.impl.JavaSerializationTranscoder
- JBOSS_AS_4_6 - Enum constant in enum org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
- JBOSS_AS_7 - Enum constant in enum org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
- JBOSS_TM - Enum constant in enum org.infinispan.commons.tx.lookup.LookupNames.TransactionManagerFactory
- JBOSS_USER_MARSHALLER_CLASS - Static variable in class org.infinispan.commons.util.Util
- JBossExternalizerAdapter - Class in org.infinispan.jboss.marshalling.commons
- JBossExternalizerAdapter(Externalizer<? super Object>) - Constructor for class org.infinispan.jboss.marshalling.commons.JBossExternalizerAdapter
- JBossMarshaller - Class in org.infinispan.jboss.marshalling.core
-
A JBoss Marshalling based marshaller that is oriented at internal, embedded, Infinispan usage.
- JBossMarshallerFactory - Class in org.infinispan.jboss.marshalling.commons
-
A JBoss Marshalling factory class for retrieving marshaller/unmarshaller instances.
- JBossMarshallerFactory() - Constructor for class org.infinispan.jboss.marshalling.commons.JBossMarshallerFactory
- JbossMarshallingModule - Class in org.infinispan.jboss.marshalling
-
JBoss Marshalling module lifecycle callbacks
- JbossMarshallingModule() - Constructor for class org.infinispan.jboss.marshalling.JbossMarshallingModule
- JBossMarshallingTranscoder - Class in org.infinispan.jboss.marshalling.dataconversion
-
Transcode between application/x-jboss-marshalling and commons formats
- JBossMarshallingTranscoder(Marshaller) - Constructor for class org.infinispan.jboss.marshalling.dataconversion.JBossMarshallingTranscoder
- JBossStandaloneJTAManagerLookup - Class in org.infinispan.transaction.lookup
-
JTA standalone TM lookup (JBoss AS 7 and earlier, and WildFly 8, 9, and 10).
- JBossStandaloneJTAManagerLookup() - Constructor for class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
- JBossUserMarshaller - Class in org.infinispan.jboss.marshalling.core
-
An extension of the
JBossMarshaller
that loads user definedExternalizer
implementations. - JBossUserMarshaller() - Constructor for class org.infinispan.jboss.marshalling.core.JBossUserMarshaller
- JBossUserMarshaller(ClassResolver) - Constructor for class org.infinispan.jboss.marshalling.core.JBossUserMarshaller
- JDBC_LOWER_BOUND - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- JDBC_PERSISTED_METADATA - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- JdbcStoreConfigurationChildBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,
S>> - Interface in org.infinispan.persistence.jdbc.common.configuration -
JdbcStoreConfigurationChildBuilder.
- JdbcStoreConfigurationParser - Class in org.infinispan.persistence.jdbc.configuration
-
JDBC cache store configuration parser.
- JdbcStoreConfigurationParser() - Constructor for class org.infinispan.persistence.jdbc.configuration.JdbcStoreConfigurationParser
- JdbcStringBasedStore<K,
V> - Class in org.infinispan.persistence.jdbc.stringbased -
AdvancedCacheLoader
implementation that stores the entries in a database. - JdbcStringBasedStore() - Constructor for class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- JdbcStringBasedStoreConfiguration - Class in org.infinispan.persistence.jdbc.configuration
- JdbcStringBasedStoreConfiguration(AttributeSet, AsyncStoreConfiguration, ConnectionFactoryConfiguration, TableManipulationConfiguration) - Constructor for class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfiguration
- JdbcStringBasedStoreConfigurationBuilder - Class in org.infinispan.persistence.jdbc.configuration
-
JdbcStringBasedStoreConfigurationBuilder.
- JdbcStringBasedStoreConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
- JdbcStringBasedStoreConfigurationBuilder.StringTableManipulationConfigurationBuilder - Class in org.infinispan.persistence.jdbc.configuration
- JdbcStringBasedStoreConfigurationSerializer - Class in org.infinispan.persistence.jdbc.configuration
-
JdbcStringBasedStoreConfigurationSerializer.
- JdbcStringBasedStoreConfigurationSerializer() - Constructor for class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationSerializer
- JdbcUtil - Class in org.infinispan.persistence.jdbc.common
-
Contains common methods used by JDBC CacheStores.
- JdbcUtil() - Constructor for class org.infinispan.persistence.jdbc.common.JdbcUtil
- jgroups() - Method in class org.infinispan.configuration.global.TransportConfiguration
- jgroups() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
- JGROUPS - Enum constant in enum org.infinispan.configuration.parsing.Element
- JGROUPS_ADDRESS - Static variable in interface org.infinispan.commons.marshall.Ids
- JGROUPS_ADDRESS - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- JGROUPS_CLUSTER_TAG_NAME - Static variable in interface org.infinispan.metrics.Constants
- JGROUPS_PREFIX - Static variable in interface org.infinispan.metrics.Constants
- JGROUPS_TOPOLOGY_AWARE_ADDRESS - Static variable in interface org.infinispan.commons.marshall.Ids
- JGroupsAddress - Class in org.infinispan.remoting.transport.jgroups
-
An encapsulation of a JGroups Address
- JGroupsAddress(Address) - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsAddress
- JGroupsAddress.Externalizer - Class in org.infinispan.remoting.transport.jgroups
- JGroupsAddress$___Marshaller_fff84712bca7d00f611bdc3fd76a067b0a3a1f4981a7d3aad1c9257d9a5d7324 - Class in org.infinispan.remoting.transport.jgroups
-
WARNING: Generated code! Do not edit!
- JGroupsAddress$___Marshaller_fff84712bca7d00f611bdc3fd76a067b0a3a1f4981a7d3aad1c9257d9a5d7324() - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsAddress$___Marshaller_fff84712bca7d00f611bdc3fd76a067b0a3a1f4981a7d3aad1c9257d9a5d7324
- JGroupsAddressCache - Class in org.infinispan.remoting.transport.jgroups
-
Cache JGroupsAddress instances
- JGroupsAddressCache() - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsAddressCache
- JGroupsBackupResponse - Class in org.infinispan.remoting.transport.jgroups
- JGroupsBackupResponse(Map<XSiteBackup, CompletableFuture<ValidResponse>>, TimeService) - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsBackupResponse
- JGroupsChannelConfigurator - Interface in org.infinispan.remoting.transport.jgroups
- JGroupsChannelLookup - Interface in org.infinispan.remoting.transport.jgroups
-
Deprecated, for removal: This API element is subject to removal in a future version.since 11.0, this will be removed in the next major version with no direct replacement.
- JGroupsConfiguration - Class in org.infinispan.configuration.global
- JGroupsConfigurationBuilder - Class in org.infinispan.configuration.global
- JGroupsMetricsManager - Interface in org.infinispan.remoting.transport.jgroups
-
Stores and register metrics statistics related to JGroups, including the protocol metrics and per destination metrics information (latency, bytes sent, etc.).
- JGroupsMetricsManagerImpl - Class in org.infinispan.remoting.transport.jgroups
-
Concrete implementation of
JGroupsMetricsManager
. - JGroupsMetricsManagerImpl(boolean) - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsMetricsManagerImpl
- JGroupsMetricsMetadata - Class in org.infinispan.remoting.transport.jgroups
- JGroupsProtocolComponent - Annotation Type in org.infinispan.external
- JGroupsTopologyAwareAddress - Class in org.infinispan.remoting.transport.jgroups
-
An encapsulation of a JGroups
ExtendedUUID
with a site id, a rack id, and a machine id. - JGroupsTopologyAwareAddress(ExtendedUUID) - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
- JGroupsTopologyAwareAddress.Externalizer - Class in org.infinispan.remoting.transport.jgroups
- JGroupsTransport - Class in org.infinispan.remoting.transport.jgroups
-
An encapsulation of a JGroups transport.
- JGroupsTransport() - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- JGroupsTransport(JChannel) - Constructor for class org.infinispan.remoting.transport.jgroups.JGroupsTransport
-
This form is used when the transport is created by an external source and passed in to the GlobalConfiguration.
- jmx() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
- jmx() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
- jmx() - Method in class org.infinispan.configuration.global.GlobalConfiguration
- jmx() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- jmx() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Global JMX configuration.
- JMX - Enum constant in enum org.infinispan.configuration.parsing.Element
- JMX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- JMX_DOMAIN - Static variable in class org.infinispan.client.hotrod.configuration.StatisticsConfiguration
- JMX_DOMAIN - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- JMX_ENABLED - Static variable in class org.infinispan.client.hotrod.configuration.StatisticsConfiguration
- JMX_NAME - Static variable in class org.infinispan.client.hotrod.configuration.StatisticsConfiguration
- JMX_NAME - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- JMX_STATISTICS - Enum constant in enum org.infinispan.configuration.parsing.Element
- jmxDisable() - Method in class org.infinispan.client.hotrod.configuration.StatisticsConfigurationBuilder
-
Disables exposure of client-side statistics over JMX
- jmxDomain() - Method in class org.infinispan.client.hotrod.configuration.StatisticsConfiguration
- jmxDomain(String) - Method in class org.infinispan.client.hotrod.configuration.StatisticsConfigurationBuilder
-
Sets the JMX domain name with which MBeans are exposed.
- jmxDomain(String) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 10.1.3, please use
GlobalJmxStatisticsConfigurationBuilder.domain(String)
instead. - JmxDomainConflictException - Exception in org.infinispan.jmx
- JmxDomainConflictException(String) - Constructor for exception org.infinispan.jmx.JmxDomainConflictException
- jmxEnable() - Method in class org.infinispan.client.hotrod.configuration.StatisticsConfigurationBuilder
-
Enables exposure of client-side statistics over JMX
- jmxEnabled() - Method in class org.infinispan.client.hotrod.configuration.StatisticsConfiguration
- jmxEnabled(boolean) - Method in class org.infinispan.client.hotrod.configuration.StatisticsConfigurationBuilder
-
Enables or disables exposure of client-side statistics over JMX
- jmxName() - Method in class org.infinispan.client.hotrod.configuration.StatisticsConfiguration
- jmxName(String) - Method in class org.infinispan.client.hotrod.configuration.StatisticsConfigurationBuilder
-
Sets the name of the MBean.
- jmxRegistration - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- jmxRegistrationFailed(Throwable) - Method in interface org.infinispan.counter.logging.Log
- jmxRegistrationFailed(Throwable) - Method in interface org.infinispan.lock.logging.Log
- jmxRegistrationFailure(Throwable) - Method in interface org.infinispan.client.hotrod.logging.Log
- jmxStatistics() - Method in class org.infinispan.configuration.cache.Configuration
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.1.3 use
Configuration.statistics()
instead. This will be removed in next major version. - jmxStatistics() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.1.3 use
ConfigurationChildBuilder.statistics()
instead. This will be removed in next major version. - JMXStatisticsConfiguration - Interface in org.infinispan.configuration.cache
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.1.3. Use
StatisticsConfiguration
instead. This will be removed in next major version. - JMXStatisticsConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.1.3. Use
StatisticsConfigurationBuilder
instead. This will be removed in next major version. - JmxStatisticsExposer - Interface in org.infinispan.jmx
-
Interface containing common cache management operations
- jmxUnregistrationFailure(Throwable) - Method in interface org.infinispan.client.hotrod.logging.Log
- JNDI_NAME - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- JNDI_URL - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
- JNDI_URL - Static variable in class org.infinispan.persistence.jdbc.common.configuration.ManagedConnectionFactoryConfiguration
- jndiUrl() - Method in class org.infinispan.persistence.jdbc.common.configuration.ManagedConnectionFactoryConfiguration
- jndiUrl(String) - Method in class org.infinispan.persistence.jdbc.common.configuration.ManagedConnectionFactoryConfigurationBuilder
- join(String, CacheJoinInfo, CacheTopologyHandler, PartitionHandlingManager) - Method in interface org.infinispan.topology.LocalTopologyManager
-
Forwards the join request to the coordinator.
- join(String, CacheJoinInfo, CacheTopologyHandler, PartitionHandlingManager) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- join(CompletionStage<R>) - Static method in class org.infinispan.util.concurrent.CompletionStages
-
Returns the result value when complete, or throws an (unchecked) exception if completed exceptionally.
- join(List<String>, String) - Static method in class org.infinispan.commons.util.Util
- joinedMembers() - Method in class org.infinispan.topology.CacheStatusResponse
- joinPC() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- JSArrays - Class in org.infinispan.scripting.utils
- JSArrays() - Constructor for class org.infinispan.scripting.utils.JSArrays
- Json - Class in org.infinispan.commons.dataconversion.internal
-
Represents a JSON (JavaScript Object Notation) entity.
- Json() - Constructor for class org.infinispan.commons.dataconversion.internal.Json
- Json(Json) - Constructor for class org.infinispan.commons.dataconversion.internal.Json
- JSON_STRING_ARRAY_ELEMENT_REGEX - Static variable in class org.infinispan.client.hotrod.RemoteCacheManager
- Json.DefaultFactory - Class in org.infinispan.commons.dataconversion.internal
- Json.Factory - Interface in org.infinispan.commons.dataconversion.internal
-
This interface defines how
Json
instances are constructed. - Json.Function<T,
R> - Interface in org.infinispan.commons.dataconversion.internal - Json.help - Class in org.infinispan.commons.dataconversion.internal
-
Exposes some internal methods that are useful for
Json.Factory
implementations or other extension/layers of the library. - Json.MalformedJsonException - Exception in org.infinispan.commons.dataconversion.internal
- Json.Schema - Interface in org.infinispan.commons.dataconversion.internal
-
Represents JSON schema - a specific data format that a JSON entity must follow.
- JsonArrayCollector - Class in org.infinispan.commons.dataconversion.internal
- JsonArrayCollector() - Constructor for class org.infinispan.commons.dataconversion.internal.JsonArrayCollector
- JsonConfigurationReader - Class in org.infinispan.commons.configuration.io.json
- JsonConfigurationReader(BufferedReader, ConfigurationResourceResolver, Properties, PropertyReplacer, NamingStrategy) - Constructor for class org.infinispan.commons.configuration.io.json.JsonConfigurationReader
- JsonConfigurationWriter - Class in org.infinispan.commons.configuration.io.json
- JsonConfigurationWriter(Writer, boolean, boolean) - Constructor for class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- JSONConstants - Interface in org.infinispan.query.remote.json
- JSONConstants - Interface in org.infinispan.rest
- JsonProjection - Class in org.infinispan.query.remote.json
- JsonProjection(Map<String, Object>) - Constructor for class org.infinispan.query.remote.json.JsonProjection
- JsonQueryErrorResult - Class in org.infinispan.query.remote.json
- JsonQueryErrorResult(String, String) - Constructor for class org.infinispan.query.remote.json.JsonQueryErrorResult
- JsonQueryRequest - Class in org.infinispan.query.remote.json
- JsonQueryRequest(String, Integer, Integer, Integer) - Constructor for class org.infinispan.query.remote.json.JsonQueryRequest
- JsonQueryResponse - Class in org.infinispan.query.remote.json
- JsonQueryResult - Class in org.infinispan.query.remote.json
- JsonQueryResult(List<Hit>, long) - Constructor for class org.infinispan.query.remote.json.JsonQueryResult
- JsonSerialization - Interface in org.infinispan.commons.dataconversion.internal
- JsonTranscoder - Class in org.infinispan.server.core.dataconversion
- JsonTranscoder() - Constructor for class org.infinispan.server.core.dataconversion.JsonTranscoder
- JsonTranscoder(ClassLoader, ClassAllowList) - Constructor for class org.infinispan.server.core.dataconversion.JsonTranscoder
- JsonTranscoder(ClassAllowList) - Constructor for class org.infinispan.server.core.dataconversion.JsonTranscoder
- JsonUtils - Class in org.infinispan.commons.dataconversion.internal
-
Utility function for
Json
- JVMMemoryInfoInfo - Class in org.infinispan.commons.util
- JVMMemoryInfoInfo() - Constructor for class org.infinispan.commons.util.JVMMemoryInfoInfo
K
- KEBAB_CASE - Enum constant in enum org.infinispan.commons.configuration.io.NamingStrategy
- KEEP_ALIVE_TIME - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- keepAlive - Variable in class org.infinispan.factories.threads.AbstractThreadPoolExecutorFactory
- keepAlive() - Method in class org.infinispan.commons.executors.BlockingThreadPoolExecutorFactory
-
Deprecated.
- keepAlive() - Method in class org.infinispan.factories.threads.AbstractThreadPoolExecutorFactory
- keepAliveTime() - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
- keepAliveTime(Long) - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
- key - Variable in class org.infinispan.container.entries.AbstractInternalCacheEntry
- key - Variable in class org.infinispan.container.entries.ReadCommittedEntry
- key - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl.KeyAndVersion
- key - Variable in class org.infinispan.server.hotrod.AccessLoggingHeader
- key - Variable in class org.infinispan.server.memcached.MemcachedDecoder
- key() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
- key() - Method in interface org.infinispan.functional.EntryView.ReadEntryView
-
Key of the read-only entry view.
- key() - Method in interface org.infinispan.functional.EntryView.WriteEntryView
-
Key of the write-only entry view.
- key() - Method in interface org.infinispan.search.mapper.common.EntityReference
- key() - Method in class org.infinispan.search.mapper.common.impl.EntityReferenceImpl
- key() - Method in class org.infinispan.xsite.statetransfer.XSiteState
- KEY - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- KEY_ALIAS - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- KEY_ALIAS - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- KEY_COLUMNS - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
- KEY_CONTENT_TYPE_HEADER - Enum constant in enum org.infinispan.rest.RequestHeader
- KEY_CONTENT_TYPE_HEADER - Enum constant in enum org.infinispan.rest.ResponseHeader
- KEY_DATA_TYPE - Enum constant in enum org.infinispan.configuration.parsing.Element
- KEY_EQUIVALENCE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- KEY_FILTER_AS_CACHE_EVENT_FILTER - Static variable in interface org.infinispan.commons.marshall.Ids
- KEY_FILTER_AS_KEY_VALUE_FILTER - Static variable in interface org.infinispan.commons.marshall.Ids
- KEY_MESSAGE_NAME - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
- KEY_MESSAGE_NAME - Static variable in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfiguration
- KEY_PARTITIONER - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- KEY_PARTITIONER - Static variable in class org.infinispan.configuration.cache.HashConfiguration
- KEY_POS_11_0 - Static variable in class org.infinispan.persistence.file.SingleFileStore
- KEY_POS_BEFORE_11 - Static variable in class org.infinispan.persistence.file.SingleFileStore
- KEY_POS_LATEST - Static variable in class org.infinispan.persistence.file.SingleFileStore
- KEY_SIZE_ESTIMATE - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 12.0, will be removed in 15.0
- KEY_SIZE_ESTIMATE - 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
- KEY_STORE_CERTIFICATE_PASSWORD - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- KEY_STORE_FILE_NAME - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- KEY_STORE_PASSWORD - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- KEY_STORE_TYPE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- KEY_TO_STRING_MAPPER - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
- KEY_TRANSFER - Enum constant in enum org.infinispan.scattered.ScatteredVersionManager.SegmentState
- KEY_TRANSFORMER - Enum constant in enum org.infinispan.configuration.parsing.Element
- KEY_TRANSFORMERS - Enum constant in enum org.infinispan.configuration.parsing.Element
- KEY_TRANSFORMERS - Static variable in class org.infinispan.configuration.cache.IndexingConfiguration
- KEY_VALUE_FILTER_AS_CACHE_EVENT_FILTER - Static variable in interface org.infinispan.commons.marshall.Ids
- KEY_VALUE_FILTER_AS_KEY_FILTER - Static variable in interface org.infinispan.commons.marshall.Ids
- KEY_VALUE_FILTER_CONVERTER_AS_CACHE_EVENT_FILTER_CONVERTER - Static variable in interface org.infinispan.commons.marshall.Ids
- KEY_VALUE_PAIR_ID - Static variable in interface org.infinispan.commons.marshall.Ids
- KEY_VALUE_VERSION_CONVERTER - Static variable in class org.infinispan.server.core.ExternalizerIds
- KEY_VALUE_WITH_PREVIOUS_CONVERTER - Static variable in class org.infinispan.server.core.ExternalizerIds
- key2StringMapper() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfiguration
- key2StringMapper(Class<? extends Key2StringMapper>) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
-
The class of a
Key2StringMapper
to use for mapping keys to strings suitable for storage in a database table. - key2StringMapper(String) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
-
The class name of a
Key2StringMapper
to use for mapping keys to strings suitable for storage in a database table. - Key2StringMapper - Interface in org.infinispan.persistence.keymappers
-
Defines the logic of mapping a key object to a String.
- KeyAffinityService<K> - Interface in org.infinispan.affinity
-
Defines a service that generates keys to be mapped to specific nodes in a distributed(vs.
- KeyAffinityServiceFactory - Class in org.infinispan.affinity
-
Factory for
KeyAffinityService
. - KeyAffinityServiceFactory() - Constructor for class org.infinispan.affinity.KeyAffinityServiceFactory
- KeyAffinityServiceImpl<K> - Class in org.infinispan.affinity.impl
-
Implementation of KeyAffinityService.
- KeyAffinityServiceImpl(Executor, Cache<? extends K, ?>, KeyGenerator<? extends K>, int, Collection<Address>, boolean) - Constructor for class org.infinispan.affinity.impl.KeyAffinityServiceImpl
- keyAlias() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
- keyAlias() - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfiguration
- keyAlias() - Method in class org.infinispan.persistence.remote.configuration.SslConfiguration
- keyAlias() - Method in class org.infinispan.server.core.configuration.SslEngineConfiguration
- keyAlias(String) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
-
Sets the alias of the key to use, in case the keyStore contains multiple certificates.
- keyAlias(String) - Method in class org.infinispan.commons.util.SslContextFactory
- keyAlias(String) - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfigurationBuilder
- keyAlias(String) - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
- keyAlias(String) - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
-
Selects a specific key to choose from the keystore
- keyAlias(String) - Method in class org.infinispan.server.core.configuration.SslEngineConfigurationBuilder
-
Selects a specific key to choose from the keystore
- keyAllowed(Object) - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
- KeyAndVersion(Object, EntryVersion) - Constructor for class org.infinispan.scattered.impl.ScatteredStateConsumerImpl.KeyAndVersion
- KeyAwareLockListener - Interface in org.infinispan.util.concurrent.locks
-
A listener for
KeyAwareLockPromise
. - KeyAwareLockPromise - Interface in org.infinispan.util.concurrent.locks
-
An extension of
LockPromise
that contains a key associated to the lock. - keyCannotEmbedWithEnum(String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- keyClassNotFound(String, Exception) - Method in interface org.infinispan.query.logging.Log
- keyColumns() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfiguration
- keyColumns(String) - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfigurationBuilder
- keyColumnsNotReturnedFromSelectAll(String, String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- keyColumnsRequired() - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- keyContentType() - Method in interface org.infinispan.rest.framework.RestRequest
- keyContentType() - Method in class org.infinispan.rest.NettyRestRequest
- keyConversion - Variable in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.ProtoSchemaOptions
- keyDataConversion - Variable in class org.infinispan.functional.impl.ReadWriteMapImpl
- keyDataType() - Method in class org.infinispan.configuration.cache.EncodingConfiguration
- KeyDoesNotExist - Enum constant in enum org.infinispan.server.hotrod.OperationStatus
- keyFilterMapper - Variable in class org.infinispan.util.WriteableCacheCollectionMapper
- keyFromStorage(Object) - Method in class org.infinispan.cache.impl.EncoderCache
- KeyGenerator<K> - Interface in org.infinispan.affinity
-
Used for generating keys; used by
KeyAffinityService
to generate the affinity keys. - keyIsTooLong(Object, int, int, int) - Method in interface org.infinispan.persistence.sifs.Log
- keyIterator(IntSet) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- keyIterator(IntSet) - Method in interface org.infinispan.client.hotrod.impl.InternalRemoteCache
- keyIterator(IntSet) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- keyLength() - Method in class org.infinispan.persistence.sifs.EntryHeader
- keyMarshaller(Marshaller) - Method in class org.infinispan.client.hotrod.DataFormat.Builder
- keyMessageName - Variable in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.ProtoSchemaOptions
- keyMessageName() - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfiguration
- keyMessageName(String) - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfigurationBuilder
-
The protobuf message name to use to marshall the cache key to the database.
- keyMigrationFailed(String, Throwable) - Method in interface org.infinispan.persistence.remote.logging.Log
- keyNotInSchema(String, String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- keyParameters - Variable in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.ProtoSchemaOptions
- keyPartitioner - Variable in class org.infinispan.cache.impl.CacheImpl
- keyPartitioner - Variable in class org.infinispan.container.impl.AbstractInternalDataContainer
- keyPartitioner - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
- keyPartitioner - Variable in class org.infinispan.stream.impl.AbstractCacheStream
- keyPartitioner() - Method in class org.infinispan.configuration.cache.HashConfiguration
- keyPartitioner(KeyPartitioner) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
-
Key partitioner, controlling the mapping of keys to hash segments.
- KeyPartitioner - Interface in org.infinispan.distribution.ch
-
Map keys to segments.
- KeyPartitionerFactory - Class in org.infinispan.distribution.ch.impl
-
Key partitioner factory that uses the hash function defined in the configuration.
- KeyPartitionerFactory() - Constructor for class org.infinispan.distribution.ch.impl.KeyPartitionerFactory
- keyPublisher(IntSet, Set<K>, Set<K>, long, DeliveryGuarantee, Function<? super Publisher<K>, ? extends Publisher<R>>) - Method in interface org.infinispan.reactive.publisher.impl.LocalPublisherManager
-
Same as
LocalPublisherManager.entryPublisher(IntSet, Set, Set, long, DeliveryGuarantee, Function)
except that the source publisher provided to the transformer is made up of keys only. - keyPublisher(IntSet, Set<K>, Set<K>, long, DeliveryGuarantee, Function<? super Publisher<K>, ? extends Publisher<R>>) - Method in class org.infinispan.reactive.publisher.impl.LocalPublisherManagerImpl
- keyPublisher(IntSet, Set<K>, InvocationContext, long, DeliveryGuarantee, int, Function<? super Publisher<K>, ? extends Publisher<R>>) - Method in interface org.infinispan.reactive.publisher.impl.ClusterPublisherManager
-
Same as
ClusterPublisherManager.entryPublisher(IntSet, Set, InvocationContext, long, DeliveryGuarantee, int, Function)
except that the source publisher provided to the transformer is made up of keys only. - keyPublisher(IntSet, Set<K>, InvocationContext, long, DeliveryGuarantee, int, Function<? super Publisher<K>, ? extends Publisher<R>>) - Method in class org.infinispan.reactive.publisher.impl.ClusterPublisherManagerImpl
- keyPublisher(IntSet, Set<K>, InvocationContext, long, DeliveryGuarantee, int, Function<? super Publisher<K>, ? extends Publisher<R>>) - Method in class org.infinispan.reactive.publisher.impl.LocalClusterPublisherManagerImpl
- keyPublisher(IntSet, Set<K>, InvocationContext, long, DeliveryGuarantee, int, Function<? super Publisher<K>, ? extends Publisher<R>>) - Method in class org.infinispan.reactive.publisher.impl.PartitionAwareClusterPublisherManager
- keyReduction(boolean, IntSet, Set<K>, Set<K>, long, DeliveryGuarantee, Function<? super Publisher<K>, ? extends CompletionStage<R>>, Function<? super Publisher<R>, ? extends CompletionStage<R>>) - Method in interface org.infinispan.reactive.publisher.impl.LocalPublisherManager
-
Same as
LocalPublisherManager.entryReduction(boolean, IntSet, Set, Set, long, DeliveryGuarantee, Function, Function)
except that the source publisher provided to the transformer is made up of keys only. - keyReduction(boolean, IntSet, Set<K>, Set<K>, long, DeliveryGuarantee, Function<? super Publisher<K>, ? extends CompletionStage<R>>, Function<? super Publisher<R>, ? extends CompletionStage<R>>) - Method in class org.infinispan.reactive.publisher.impl.LocalPublisherManagerImpl
- keyReduction(boolean, IntSet, Set<K>, InvocationContext, long, DeliveryGuarantee, Function<? super Publisher<K>, ? extends CompletionStage<R>>, Function<? super Publisher<R>, ? extends CompletionStage<R>>) - Method in interface org.infinispan.reactive.publisher.impl.ClusterPublisherManager
-
Same as
ClusterPublisherManager.entryReduction(boolean, IntSet, Set, InvocationContext, long, DeliveryGuarantee, Function, Function)
except that the source publisher provided to the transformer is made up of keys only. - keyReduction(boolean, IntSet, Set<K>, InvocationContext, long, DeliveryGuarantee, Function<? super Publisher<K>, ? extends CompletionStage<R>>, Function<? super Publisher<R>, ? extends CompletionStage<R>>) - Method in class org.infinispan.reactive.publisher.impl.ClusterPublisherManagerImpl
- keyReduction(boolean, IntSet, Set<K>, InvocationContext, long, DeliveryGuarantee, Function<? super Publisher<K>, ? extends CompletionStage<R>>, Function<? super Publisher<R>, ? extends CompletionStage<R>>) - Method in class org.infinispan.reactive.publisher.impl.LocalClusterPublisherManagerImpl
- keyReduction(boolean, IntSet, Set<K>, InvocationContext, long, DeliveryGuarantee, Function<? super Publisher<K>, ? extends CompletionStage<R>>, Function<? super Publisher<R>, ? extends CompletionStage<R>>) - Method in class org.infinispan.reactive.publisher.impl.PartitionAwareClusterPublisherManager
- keys - Variable in class org.infinispan.commons.util.ArrayMap
- keys() - Method in interface org.infinispan.functional.FunctionalMap.ReadOnlyMap
-
Provides a
Traversable
that allows clients to navigate all cached keys. - keys() - Method in class org.infinispan.functional.impl.ReadOnlyMapImpl
- keySet - Variable in class org.infinispan.commons.util.AbstractMap
- keySet() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- keySet() - Method in class org.infinispan.cache.impl.CacheImpl
- keySet() - Method in class org.infinispan.cache.impl.DecoratedCache
- keySet() - Method in class org.infinispan.cache.impl.EncoderCache
- keySet() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- keySet() - Method in interface org.infinispan.Cache
-
Returns a set view of the keys contained in this cache and cache loader across the entire cluster.
- keySet() - Method in interface org.infinispan.client.hotrod.RemoteCache
- keySet() - Method in class org.infinispan.commons.util.AbstractDelegatingMap
- keySet() - Method in class org.infinispan.commons.util.ArrayMap
- keySet() - Method in class org.infinispan.commons.util.FastCopyHashMap
- keySet() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- keySet() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
- keySet() - Method in class org.infinispan.security.impl.SecureCacheImpl
- keySet(IntSet) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- keySet(IntSet) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- keySet(IntSet) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
This method is identical to
RemoteCache.keySet()
except that it will only return keys that map to the given segments. - KeySet() - Constructor for class org.infinispan.cache.impl.SimpleCacheImpl.KeySet
- KeySet() - Constructor for class org.infinispan.commons.util.FastCopyHashMap.KeySet
- keySizeEstimate() - Method in class org.infinispan.client.hotrod.configuration.Configuration
-
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
- keySizeEstimate() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
-
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
- keySizeEstimate(int) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
-
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
- keySizeEstimate(int) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
-
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
- keySizeEstimate(int) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
-
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
- keySizeEstimate(int) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
-
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
- keySizeEstimate(int) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
-
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
- keySizeEstimate(int) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
-
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
- keysToFilter - Variable in class org.infinispan.stream.impl.AbstractCacheStream
- KEYSTORE - Enum constant in enum org.infinispan.persistence.remote.configuration.Element
- keyStoreCertificatePassword() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
- keyStoreCertificatePassword() - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfiguration
- keyStoreCertificatePassword() - Method in class org.infinispan.persistence.remote.configuration.SslConfiguration
- keyStoreCertificatePassword() - Method in class org.infinispan.server.core.configuration.SslConfiguration
- keyStoreCertificatePassword() - Method in class org.infinispan.server.core.configuration.SslEngineConfiguration
- keyStoreCertificatePassword(char[]) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.since 9.3
- keyStoreCertificatePassword(char[]) - Method in class org.infinispan.commons.util.SslContextFactory
- keyStoreCertificatePassword(char[]) - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfigurationBuilder
- keyStoreCertificatePassword(char[]) - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
-
Specifies the password needed to access private key associated with certificate stored in specified
SslConfigurationBuilder.keyStoreFileName(String)
. - keyStoreCertificatePassword(char[]) - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
-
Specifies the password needed to access private key associated with certificate stored in specified
SslConfigurationBuilder.keyStoreFileName(String)
. - keyStoreCertificatePassword(char[]) - Method in class org.infinispan.server.core.configuration.SslEngineConfigurationBuilder
-
Specifies the password needed to access private key associated with certificate stored in specified
SslEngineConfigurationBuilder.keyStoreFileName(String)
. - keyStoreConfiguration() - Method in class org.infinispan.persistence.remote.configuration.SslConfiguration
- KeyStoreConfiguration - Class in org.infinispan.persistence.remote.configuration
- KeyStoreConfigurationBuilder - Class in org.infinispan.persistence.remote.configuration
- KeyStoreConfigurationBuilder(SecurityConfigurationBuilder) - Constructor for class org.infinispan.persistence.remote.configuration.KeyStoreConfigurationBuilder
- keyStoreFileName() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
- keyStoreFileName() - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfiguration
- keyStoreFileName() - Method in class org.infinispan.persistence.remote.configuration.SslConfiguration
- keyStoreFileName() - Method in class org.infinispan.server.core.configuration.SslConfiguration
- keyStoreFileName() - Method in class org.infinispan.server.core.configuration.SslEngineConfiguration
- keyStoreFileName(String) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
-
Specifies the filename of a keystore to use to create the
SSLContext
You also need to specify aSslConfigurationBuilder.keyStorePassword(char[])
. - keyStoreFileName(String) - Method in class org.infinispan.commons.util.SslContextFactory
- keyStoreFileName(String) - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfigurationBuilder
- keyStoreFileName(String) - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
-
Specifies the filename of a keystore to use to create the
SSLContext
You also need to specify aSslConfigurationBuilder.keyStorePassword(char[])
. - keyStoreFileName(String) - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
-
Specifies the filename of a keystore to use to create the
SSLContext
You also need to specify aSslConfigurationBuilder.keyStorePassword(char[])
. - keyStoreFileName(String) - Method in class org.infinispan.server.core.configuration.SslEngineConfigurationBuilder
-
Specifies the filename of a keystore to use to create the
SSLContext
You also need to specify aSslEngineConfigurationBuilder.keyStorePassword(char[])
. - keyStorePassword() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
- keyStorePassword() - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfiguration
- keyStorePassword() - Method in class org.infinispan.persistence.remote.configuration.SslConfiguration
- keyStorePassword() - Method in class org.infinispan.server.core.configuration.SslConfiguration
- keyStorePassword() - Method in class org.infinispan.server.core.configuration.SslEngineConfiguration
- keyStorePassword(char[]) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
-
Specifies the password needed to open the keystore You also need to specify a
SslConfigurationBuilder.keyStoreFileName(String)
. - keyStorePassword(char[]) - Method in class org.infinispan.commons.util.SslContextFactory
- keyStorePassword(char[]) - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfigurationBuilder
- keyStorePassword(char[]) - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
-
Specifies the password needed to open the keystore You also need to specify a
SslConfigurationBuilder.keyStoreFileName(String)
. - keyStorePassword(char[]) - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
-
Specifies the password needed to open the keystore You also need to specify a
SslConfigurationBuilder.keyStoreFileName(String)
. - keyStorePassword(char[]) - Method in class org.infinispan.server.core.configuration.SslEngineConfigurationBuilder
-
Specifies the password needed to open the keystore You also need to specify a
SslEngineConfigurationBuilder.keyStoreFileName(String)
. - keyStoreType() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
- keyStoreType() - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfiguration
- keyStoreType() - Method in class org.infinispan.persistence.remote.configuration.SslConfiguration
- keyStoreType() - Method in class org.infinispan.server.core.configuration.SslEngineConfiguration
- keyStoreType(String) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
-
Specifies the type of the keystore, such as JKS or JCEKS.
- keyStoreType(String) - Method in class org.infinispan.commons.util.SslContextFactory
- keyStoreType(String) - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfigurationBuilder
- keyStoreType(String) - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
-
Specifies the type of the keystore, such as JKS or JCEKS.
- keyStoreType(String) - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
-
Specifies the type of the keystore, such as JKS or JCEKS.
- keyStoreType(String) - Method in class org.infinispan.server.core.configuration.SslEngineConfigurationBuilder
-
Specifies the type of the keystore, such as JKS or JCEKS.
- keyToBytes(Object) - Method in class org.infinispan.client.hotrod.DataFormat
- keyToBytes(Object) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- keyToBytes(Object) - Method in interface org.infinispan.client.hotrod.impl.InternalRemoteCache
- keyToBytes(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- keyToBytes(Object) - Method in interface org.infinispan.client.hotrod.marshall.MediaTypeMarshaller
-
Transforms the key object to the marshalled form.
- keyToBytes(Object, int, int) - Method in class org.infinispan.client.hotrod.DataFormat
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 12.0, will be removed in 15.0
- keyToEntryFunction() - Static method in class org.infinispan.stream.StreamMarshalling
-
Provides a function that given a key will return the
CacheEntry
that maps to this key. - keyToObj(byte[], ClassAllowList) - Method in class org.infinispan.client.hotrod.DataFormat
- keyToStorage(Object) - Method in class org.infinispan.cache.impl.EncoderCache
- KeyTransformationHandlerIdentifierBridge - Class in org.infinispan.query.impl
-
An
IdentifierBridge
to map cache keys to the document identifiers. - keyTransformers() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
-
The currently configured key transformers.
- keyType(MediaType) - Method in class org.infinispan.client.hotrod.DataFormat.Builder
- KeyValueFilter<K,
V> - Interface in org.infinispan.filter -
A filter for keys with their values.
- KeyValueFilterAsCacheEventFilter<K,
V> - Class in org.infinispan.notifications.cachelistener.filter -
CacheEventFilter that implements it's filtering solely on the use of the provided KeyValueFilter
- KeyValueFilterAsCacheEventFilter(KeyValueFilter<? super K, ? super V>) - Constructor for class org.infinispan.notifications.cachelistener.filter.KeyValueFilterAsCacheEventFilter
- KeyValueFilterAsCacheEventFilter.Externalizer - Class in org.infinispan.notifications.cachelistener.filter
- KeyValueFilterConverter<K,
V, C> - Interface in org.infinispan.filter -
This interface is an optimization that can be used when a filter and converter are most efficiently used as the same object composing the filtering and conversion in the same method invocation.
- KeyValueFilterConverterAsCacheEventFilterConverter<K,
V, C> - Class in org.infinispan.notifications.cachelistener.filter -
CacheEventFilterConverter
that uses an underlyingKeyValueFilterConverter
to do the conversion and filtering. - KeyValueFilterConverterAsCacheEventFilterConverter(KeyValueFilterConverter<K, V, C>) - Constructor for class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter
- KeyValueFilterConverterAsCacheEventFilterConverter(KeyValueFilterConverter<K, V, C>, MediaType) - Constructor for class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter
- KeyValueFilterConverterAsCacheEventFilterConverter.Externalizer - Class in org.infinispan.notifications.cachelistener.filter
- KeyValueFilterConverterFactory<K,
V, C> - Interface in org.infinispan.filter -
Factory for
KeyValueFilterConverter
instances - KeyValueMetadataSizeCalculator<K,
V> - Interface in org.infinispan.container.impl -
Size calculator that takes into account not only key and value but also metadata.
- KeyValuePair<K,
V> - Class in org.infinispan.util -
Holds logically related key-value pairs or binary tuples.
- KeyValuePair(K, V) - Constructor for class org.infinispan.util.KeyValuePair
- KeyValuePair.Externalizer - Class in org.infinispan.util
- KeyValueWithPrevious<K,
V> - Class in org.infinispan.commons.util - KeyValueWithPrevious(K, V, V) - Constructor for class org.infinispan.commons.util.KeyValueWithPrevious
- KeyValueWithPrevious$___Marshaller_9145896a24b67e12a03ab245b027743214e8f0a00cff4e94594e6701c8f07ff1 - Class in org.infinispan.commons.util
-
WARNING: Generated code! Do not edit!
- KeyValueWithPrevious$___Marshaller_9145896a24b67e12a03ab245b027743214e8f0a00cff4e94594e6701c8f07ff1() - Constructor for class org.infinispan.commons.util.KeyValueWithPrevious$___Marshaller_9145896a24b67e12a03ab245b027743214e8f0a00cff4e94594e6701c8f07ff1
- KeyValueWithPreviousEventConverter<K,
V> - Class in org.infinispan.server.hotrod.event - KeyValueWithPreviousEventConverter() - Constructor for class org.infinispan.server.hotrod.event.KeyValueWithPreviousEventConverter
- KeyValueWithPreviousEventConverterExternalizer - Class in org.infinispan.server.hotrod.event
-
Externalizer for KeyValueWithPreviousEventConverter
- KeyValueWithPreviousEventConverterExternalizer() - Constructor for class org.infinispan.server.hotrod.event.KeyValueWithPreviousEventConverterExternalizer
- KeyValueWithPreviousEventConverterFactory<K,
V> - Class in org.infinispan.server.hotrod.event - KeyValueWithPreviousEventConverterFactory() - Constructor for class org.infinispan.server.hotrod.event.KeyValueWithPreviousEventConverterFactory
- KIBIBYTES - Enum constant in enum org.infinispan.commons.util.MemoryUnit
-
Deprecated.
- KILOBYTES - Enum constant in enum org.infinispan.commons.util.MemoryUnit
-
Deprecated.
- KnownClassKey$___Marshaller_b1b9e11dd7f2c702e88c180bbc686b798fa5794bc27ae13347aacd2e4a465e3d - Class in org.infinispan.query.impl
-
WARNING: Generated code! Do not edit!
- KnownClassKey$___Marshaller_b1b9e11dd7f2c702e88c180bbc686b798fa5794bc27ae13347aacd2e4a465e3d() - Constructor for class org.infinispan.query.impl.KnownClassKey$___Marshaller_b1b9e11dd7f2c702e88c180bbc686b798fa5794bc27ae13347aacd2e4a465e3d
- KnownComponentNames - Class in org.infinispan.factories
-
Holder for known named component names.
- KnownComponentNames() - Constructor for class org.infinispan.factories.KnownComponentNames
- KUBERNETES(Properties) - Static method in class org.infinispan.remoting.transport.jgroups.BuiltinJGroupsChannelConfigurator
L
- l1() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
- l1() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
-
This method allows configuration of the L1 cache for distributed caches.
- l1() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
-
This method allows configuration of the L1 cache for distributed caches.
- l1() - Method in interface org.infinispan.configuration.cache.ClusteringConfigurationChildBuilder
-
Configures the L1 cache behavior in 'distributed' caches instances.
- L1 - Enum constant in enum org.infinispan.configuration.parsing.Element
- L1_LIFESPAN - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- L1Configuration - Class in org.infinispan.configuration.cache
-
Configures the L1 cache behavior in 'distributed' caches instances.
- L1ConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Configures the L1 cache behavior in 'distributed' caches instances.
- L1InternalCacheEntry - Class in org.infinispan.container.entries
-
A
InternalCacheEntry
implementation to store a L1 entry. - L1InternalCacheEntry(Object, Object, long, long) - Constructor for class org.infinispan.container.entries.L1InternalCacheEntry
- L1Manager - Interface in org.infinispan.distribution
-
Manages the L1 Cache, in particular recording anyone who is going to cache an a command that a node responds to so that a unicast invalidation can be sent later if needed.
- L1ManagerImpl - Class in org.infinispan.distribution.impl
- L1ManagerImpl() - Constructor for class org.infinispan.distribution.impl.L1ManagerImpl
- L1Metadata - Class in org.infinispan.metadata.impl
-
Metadata
implementation that must be passed to theDataContainer.put(Object, Object, org.infinispan.metadata.Metadata)
when the entry to store is a L1 entry. - L1Metadata(Metadata) - Constructor for class org.infinispan.metadata.impl.L1Metadata
- L1MetadataInternalCacheEntry - Class in org.infinispan.container.entries.metadata
-
A
InternalCacheEntry
implementation to store a L1 entry. - L1MetadataInternalCacheEntry(Object, Object, Metadata, long) - Constructor for class org.infinispan.container.entries.metadata.L1MetadataInternalCacheEntry
- L1SegmentedDataContainer<K,
V> - Class in org.infinispan.container.impl -
Segmented data container that also allows for non owned segments to be written to a temporary map (L1).
- L1SegmentedDataContainer(Supplier<PeekableTouchableMap<K, V>>, int) - Constructor for class org.infinispan.container.impl.L1SegmentedDataContainer
- LAMBDA_CONSTANT - Static variable in interface org.infinispan.commons.marshall.Ids
- LAMBDA_SET_VALUE_IF_EQUALS_RETURN_BOOLEAN - Static variable in interface org.infinispan.commons.marshall.Ids
- LAMBDA_WITH_METAS - Static variable in interface org.infinispan.commons.marshall.Ids
- LambdaExternalizer<T> - Interface in org.infinispan.commons.marshall
-
A lambda
AdvancedExternalizer
. - LambdaWithMetasExternalizer() - Constructor for class org.infinispan.marshall.core.MarshallableFunctionExternalizers.LambdaWithMetasExternalizer
- last() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
- LAST - Enum constant in enum org.infinispan.configuration.cache.InterceptorConfiguration.Position
-
Specifies that the new interceptor is placed last in the chain.
- LAST_MODIFIED_HEADER - Enum constant in enum org.infinispan.rest.ResponseHeader
- LAST_USED_HEADER - Enum constant in enum org.infinispan.rest.RequestHeader
- LAST_USED_HEADER - Enum constant in enum org.infinispan.rest.ResponseHeader
- lastAddress - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
- lastIndexOf(Object) - Method in class org.infinispan.commons.util.ForwardingList
- lastIndexOf(Object) - Method in class org.infinispan.commons.util.ImmutableListCopy
- lastModified() - Method in class org.infinispan.io.GridFile
-
Deprecated.
- lastModified(Long) - Method in interface org.infinispan.rest.framework.impl.RestResponseBuilder
- lastModified(Long) - Method in class org.infinispan.rest.framework.impl.SimpleRestResponse.Builder
- lastModified(Long) - Method in class org.infinispan.rest.NettyRestResponse.Builder
- lastUsed - Variable in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
- lastUsed - Variable in class org.infinispan.container.entries.ReadCommittedEntry
- lastUsed - Variable in class org.infinispan.container.entries.TransientCacheEntry
- lastUsed - Variable in class org.infinispan.container.entries.TransientCacheValue
- lastUsed - Variable in class org.infinispan.container.entries.TransientMortalCacheEntry
- lastUsed - Variable in class org.infinispan.container.entries.TransientMortalCacheValue
- lastUsed() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
- lastUsed() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
-
Deprecated.
- lastUsed() - Method in interface org.infinispan.metadata.InternalMetadata
-
Deprecated.
- lastUsed() - Method in interface org.infinispan.persistence.spi.MarshallableEntry
- lastUsed(long) - Method in class org.infinispan.rest.NettyRestResponse.Builder
- LATEST - Static variable in enum org.infinispan.server.hotrod.HotRodVersion
- latestSent(int, int) - Method in class org.infinispan.distribution.TriangleOrderManager
-
Meant for testing only.
- LAZY_RETRIEVAL - Enum constant in enum org.infinispan.server.hotrod.configuration.Attribute
- LAZY_RETRIEVAL - Static variable in class org.infinispan.server.hotrod.configuration.TopologyCacheConfiguration
- LazyByteArrayOutputStream - Class in org.infinispan.commons.io
-
ByteArrayOutputStream alternative exposing the internal buffer.
- LazyByteArrayOutputStream() - Constructor for class org.infinispan.commons.io.LazyByteArrayOutputStream
- LazyByteArrayOutputStream(int) - Constructor for class org.infinispan.commons.io.LazyByteArrayOutputStream
- LazyByteArrayOutputStream(int, int) - Constructor for class org.infinispan.commons.io.LazyByteArrayOutputStream
-
Creates a new byte array output stream, with a buffer capacity of the specified size, in bytes.
- LazyConcatIterator<E> - Class in org.infinispan.util
-
Iterator implementation that will return all entries from the first iterator.
- LazyConcatIterator(CloseableIterator<E>, Supplier<? extends CloseableIterator<E>>) - Constructor for class org.infinispan.util.LazyConcatIterator
- lazyGetComponent(Class<T>) - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
-
Looks up a component named
name
in the registry, or registers it if necessary. - lazyGetComponent(Class<T>) - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
- LazyInitializingBlockingTaskAwareExecutorService - Class in org.infinispan.executors
-
A delegating executor that lazily constructs and initializes the underlying executor.
- LazyInitializingBlockingTaskAwareExecutorService(ThreadPoolExecutorFactory<ExecutorService>, ThreadFactory, TimeService) - Constructor for class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
- LazyInitializingExecutorService - Class in org.infinispan.executors
-
A delegating executor that lazily constructs and initializes the underlying executor, since unused JDK executors are expensive.
- LazyInitializingExecutorService(ThreadPoolExecutorFactory<ExecutorService>, ThreadFactory) - Constructor for class org.infinispan.executors.LazyInitializingExecutorService
- LazyInitializingScheduledExecutorService - Class in org.infinispan.executors
-
A delegating scheduled executor that lazily constructs and initializes the underlying scheduled executor, since unused JDK executors are expensive.
- LazyInitializingScheduledExecutorService(ThreadPoolExecutorFactory<ScheduledExecutorService>, ThreadFactory) - Constructor for class org.infinispan.executors.LazyInitializingScheduledExecutorService
- lazyRetrieval() - Method in class org.infinispan.server.hotrod.configuration.TopologyCacheConfiguration
- lazyRetrieval(boolean) - Method in class org.infinispan.server.hotrod.configuration.TopologyCacheConfigurationBuilder
- leave(String, long) - Method in interface org.infinispan.topology.LocalTopologyManager
-
Forwards the leave request to the coordinator.
- leave(String, long) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- left() - Method in class org.infinispan.commons.util.Either
- LEFT - Enum constant in enum org.infinispan.commons.util.Either.Type
- legacyBuilder() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.
- LegacyKeySupportSystemProperties - Class in org.infinispan.commons.util
-
A wrapper around system properties that supports legacy keys
- LegacyKeySupportSystemProperties() - Constructor for class org.infinispan.commons.util.LegacyKeySupportSystemProperties
- length() - Method in class org.infinispan.io.GridFile
-
Deprecated.
- length() - Method in class org.infinispan.persistence.sifs.EntryMetadata
- LF - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- Lifecycle - Interface in org.infinispan.commons.api
-
Lifecycle interface that defines the lifecycle of components
- LIFECYCLE - Enum constant in enum org.infinispan.security.AuthorizationPermission
-
Allows control of a cache's lifecycle (i.e.
- LifecycleCallbacks - Class in org.infinispan.persistence.remote
- LifecycleCallbacks - Class in org.infinispan.rest
-
Lifecycle callbacks for the REST module.
- LifecycleCallbacks - Class in org.infinispan.server.core
-
Server module lifecycle callbacks
- LifecycleCallbacks - Class in org.infinispan.server.hotrod
-
Module lifecycle callbacks implementation that enables module specific
AdvancedExternalizer
implementations to be registered. - LifecycleCallbacks - Class in org.infinispan.server.memcached
-
Module lifecycle callbacks implementation that enables module specific
AdvancedExternalizer
implementations to be registered. - LifecycleCallbacks() - Constructor for class org.infinispan.persistence.remote.LifecycleCallbacks
- LifecycleCallbacks() - Constructor for class org.infinispan.rest.LifecycleCallbacks
- LifecycleCallbacks() - Constructor for class org.infinispan.server.core.LifecycleCallbacks
- LifecycleCallbacks() - Constructor for class org.infinispan.server.hotrod.LifecycleCallbacks
- LifecycleCallbacks() - Constructor for class org.infinispan.server.memcached.LifecycleCallbacks
- LifecycleManager - Class in org.infinispan.query.impl
-
Lifecycle of the Query module: initializes the Hibernate Search engine and shuts it down at cache stop.
- LifecycleManager() - Constructor for class org.infinispan.query.impl.LifecycleManager
- LifecycleRejectedExecutionHandler - Class in org.infinispan.commons.util.concurrent
-
A handler for rejected tasks that always throws a
IllegalLifecycleStateException
. - lifespan - Variable in class org.infinispan.container.entries.MortalCacheEntry
- lifespan - Variable in class org.infinispan.container.entries.MortalCacheValue
- lifespan - Variable in class org.infinispan.container.entries.TransientMortalCacheEntry
- lifespan - Variable in class org.infinispan.metadata.EmbeddedMetadata.Builder
- lifespan() - Method in class org.infinispan.configuration.cache.ExpirationConfiguration
-
Maximum lifespan of a cache entry, after which the entry is expired cluster-wide, in milliseconds.
- lifespan() - Method in class org.infinispan.configuration.cache.L1Configuration
-
Maximum lifespan of an entry placed in the L1 cache.
- lifespan() - Method in class org.infinispan.container.entries.RemoteMetadata
- lifespan() - Method in class org.infinispan.counter.api.CounterConfiguration
- lifespan() - Method in class org.infinispan.counter.configuration.StrongCounterConfiguration
- lifespan() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
- lifespan() - Method in class org.infinispan.metadata.EmbeddedMetadata.EmbeddedExpirableMetadata
- lifespan() - Method in class org.infinispan.metadata.EmbeddedMetadata.EmbeddedLifespanExpirableMetadata
- lifespan() - Method in class org.infinispan.metadata.EmbeddedMetadata
- lifespan() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
-
Deprecated.
- lifespan() - Method in class org.infinispan.metadata.impl.L1Metadata
- lifespan() - Method in interface org.infinispan.metadata.Metadata
-
Returns the lifespan of the cache entry with which this metadata object is associated, in milliseconds.
- lifespan(long) - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
-
Maximum lifespan of a cache entry, after which the entry is expired cluster-wide, in milliseconds.
- lifespan(long) - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
-
Maximum lifespan of an entry placed in the L1 cache.
- lifespan(long) - Method in class org.infinispan.counter.api.CounterConfiguration.Builder
- lifespan(long) - Method in class org.infinispan.counter.configuration.StrongCounterConfigurationBuilder
- lifespan(long) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata.Builder
- lifespan(long) - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
- lifespan(long) - Method in interface org.infinispan.metadata.Metadata.Builder
-
Set lifespan time assuming that the time unit is milliseconds.
- lifespan(long, TimeUnit) - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
-
Maximum lifespan of a cache entry, after which the entry is expired cluster-wide, in milliseconds.
- lifespan(long, TimeUnit) - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
-
Maximum lifespan of an entry placed in the L1 cache.
- lifespan(long, TimeUnit) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata.Builder
- lifespan(long, TimeUnit) - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
- lifespan(long, TimeUnit) - Method in interface org.infinispan.metadata.Metadata.Builder
-
Set lifespan time with a given time unit.
- LIFESPAN - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- LIFESPAN - Enum constant in enum org.infinispan.counter.configuration.Attribute
- LIFESPAN - Static variable in class org.infinispan.configuration.cache.ExpirationConfiguration
- LIFESPAN - Static variable in class org.infinispan.configuration.cache.L1Configuration
- LifespanExternalizer() - Constructor for class org.infinispan.marshall.exts.MetaParamExternalizers.LifespanExternalizer
- lifespanUnit - Variable in class org.infinispan.metadata.EmbeddedMetadata.Builder
- like(String) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
-
Deprecated.Checks that the left argument (which is expected to be a String) matches a wildcard pattern that follows the JPA rules.
- limit(long) - Method in interface org.infinispan.CacheStream
- limit(long) - Method in interface org.infinispan.DoubleCacheStream
- limit(long) - Method in interface org.infinispan.IntCacheStream
- limit(long) - Method in interface org.infinispan.LongCacheStream
- limit(long) - Method in class org.infinispan.stream.impl.DistributedCacheStream
- limit(long) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- limit(long) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- limit(long) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- limit(long) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- limit(long) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- limit(long) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- limit(long) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- limit(long) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- limitedBlockingExecutor(String, int) - Method in interface org.infinispan.util.concurrent.BlockingManager
-
Provides a
BlockingManager.BlockingExecutor
which is limited to the provided concurrency amount. - limitedBlockingExecutor(String, int) - Method in class org.infinispan.util.concurrent.BlockingManagerImpl
- LimitedExecutor - Class in org.infinispan.executors
-
Executes tasks in the given executor, but never has more than
maxConcurrentTasks
tasks running at the same time. - LimitedExecutor(String, Executor, int) - Constructor for class org.infinispan.executors.LimitedExecutor
- lineNumber - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- LINUX - Enum constant in enum org.infinispan.commons.util.OS
- list() - Method in class org.infinispan.io.GridFile
-
Deprecated.
- list() - Method in interface org.infinispan.query.dsl.Query
-
Returns the results of a search as a list.
- list() - Method in interface org.infinispan.query.dsl.QueryResult
- list() - Method in interface org.infinispan.query.impl.IndexedQuery
- list(FilenameFilter) - Method in class org.infinispan.io.GridFile
-
Deprecated.
- list(Enum<?>, List<T>) - Static method in class org.infinispan.commons.configuration.attributes.ConfigurationElement
- list(String) - Method in class org.infinispan.security.mappers.ClusterRoleMapper
- list(String) - Method in interface org.infinispan.security.MutablePrincipalRoleMapper
- LIST - Enum constant in enum org.infinispan.persistence.modifications.Modification.Type
- listAll() - Method in class org.infinispan.security.mappers.ClusterRoleMapper
- listAll() - Method in interface org.infinispan.security.MutablePrincipalRoleMapper
- LISTEN - Enum constant in enum org.infinispan.security.AuthorizationPermission
-
Allows attaching listeners to a cache
- Listenable - Interface in org.infinispan.notifications
-
Interface that denotes that the implementation can have listeners attached to it.
- listener - Variable in class org.infinispan.reactive.publisher.impl.PartitionAwareClusterPublisherManager
- Listener - Annotation Type in org.infinispan.notifications
-
Class-level annotation used to annotate an object as being a valid cache listener.
- LISTENER_EXECUTOR - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- Listener.Observation - Enum in org.infinispan.notifications
-
Enumeration that defines when a listener event can be observed.
- ListenerHolder - Class in org.infinispan.notifications.cachelistener
- ListenerHolder(Object, DataConversion, DataConversion, boolean) - Constructor for class org.infinispan.notifications.cachelistener.ListenerHolder
- ListenerInvocation<T> - Interface in org.infinispan.notifications.impl
-
Defines simple listener invocation.
- ListenerInvocationImpl(Object, Method, boolean, ClassLoader, Subject) - Constructor for class org.infinispan.notifications.impl.AbstractListenerImpl.ListenerInvocationImpl
- listenerNotifier - Variable in class org.infinispan.client.hotrod.RemoteCacheManager
- ListenerOperationStatus - Enum in org.infinispan.server.hotrod.counter.listener
-
The listener operation (add/remove) return status.
- ListenerRegistration - Class in org.infinispan.affinity
-
Used for registering various cache notifications.
- ListenerRegistration(KeyAffinityServiceImpl<?>) - Constructor for class org.infinispan.affinity.ListenerRegistration
- listeners - Variable in class org.infinispan.container.impl.AbstractInternalDataContainer
- listeners - Variable in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- listeners() - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
-
Allows to read-write listeners to be registered.
- listeners() - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
-
Allows to write-only listeners to be registered.
- listeners() - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
- listeners() - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
- Listeners - Class in org.infinispan.functional
-
Holder class for functional listener definitions.
- LISTENERS_CHECK_INTERVAL - Static variable in class org.infinispan.server.hotrod.HotRodServer
- Listeners.ReadWriteListeners<K,
V> - Interface in org.infinispan.functional -
Read-write listeners enable users to register listeners for cache entry created, modified and removed events, and also register listeners for any cache entry write events.
- Listeners.ReadWriteListeners.ReadWriteListener<K,
V> - Interface in org.infinispan.functional -
Read-write listener
- Listeners.WriteListeners<K,
V> - Interface in org.infinispan.functional -
Write listeners enable user to register listeners for any cache entry write events that happen in either a read-write or write-only functional map.
- Listeners.WriteListeners.WriteListener<K,
V> - Interface in org.infinispan.functional -
Write-only listener.
- listenersMap - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl
- listenerThreadPool() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
- listenerThreadPool() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
- listenerThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfiguration
- listenerThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- listenerThreadPool() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Configuration for the listener thread pool
- listenerThreadPool() - Method in class org.infinispan.configuration.global.ThreadsConfiguration
- listenerThreadPool() - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
- listenerThreadPoolName() - Method in class org.infinispan.configuration.global.GlobalConfiguration
- listenerThreadPoolName(String) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- listFiles() - Method in class org.infinispan.io.GridFile
-
Deprecated.
- listFiles(FileFilter) - Method in class org.infinispan.io.GridFile
-
Deprecated.
- listFiles(FilenameFilter) - Method in class org.infinispan.io.GridFile
-
Deprecated.
- listIterator() - Method in class org.infinispan.commons.util.ForwardingList
- listIterator() - Method in class org.infinispan.commons.util.ImmutableListCopy
- listIterator(int) - Method in class org.infinispan.commons.util.ForwardingList
- listIterator(int) - Method in class org.infinispan.commons.util.ImmutableListCopy.ImmutableSubList
- listIterator(int) - Method in class org.infinispan.commons.util.ImmutableListCopy
- load(int, Object) - Method in class org.infinispan.persistence.async.AsyncNonBlockingStore
- load(int, Object) - Method in class org.infinispan.persistence.file.SingleFileStore
- load(int, Object) - Method in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
- load(int, Object) - Method in class org.infinispan.persistence.remote.RemoteStore
- load(int, Object) - Method in class org.infinispan.persistence.rocksdb.RocksDBStore
- load(int, Object) - Method in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
- load(int, Object) - Method in interface org.infinispan.persistence.spi.NonBlockingStore
-
Returns a stage that will contain the value loaded from the store.
- load(int, Object) - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
- load(int, Object) - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
- load(Class<T>, ClassLoader...) - Static method in class org.infinispan.commons.util.ServiceFinder
- LOAD_PERSIST - Enum constant in enum org.infinispan.functional.Param.PersistenceMode
- loadAll() - Method in interface org.infinispan.globalstate.LocalConfigurationStorage
-
Deprecated, for removal: This API element is subject to removal in a future version.since 12.0, use
LocalConfigurationStorage.loadAllCaches()
instead - loadAllCaches() - Method in class org.infinispan.globalstate.impl.ImmutableLocalConfigurationStorage
- loadAllCaches() - Method in class org.infinispan.globalstate.impl.OverlayLocalConfigurationStorage
- loadAllCaches() - Method in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
- loadAllCaches() - Method in interface org.infinispan.globalstate.LocalConfigurationStorage
-
Loads all persisted cache configurations
- loadAllTemplates() - Method in class org.infinispan.globalstate.impl.ImmutableLocalConfigurationStorage
- loadAllTemplates() - Method in class org.infinispan.globalstate.impl.OverlayLocalConfigurationStorage
- loadAllTemplates() - Method in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
- loadAllTemplates() - Method in interface org.infinispan.globalstate.LocalConfigurationStorage
-
Loads all persisted templates
- loadAndCheckExpiration(PersistenceManager, Object, int, InvocationContext) - Static method in class org.infinispan.persistence.internal.PersistenceUtil
- loadAndCheckExpiration(PersistenceManager, Object, InvocationContext, TimeService) - Static method in class org.infinispan.persistence.PersistenceUtil
-
Deprecated, for removal: This API element is subject to removal in a future version.since 9.4 This method references PersistenceManager, which isn't a public class
- loadAndComputeInDataContainer(DataContainer<K, V>, int, PersistenceManager, K, InvocationContext, TimeService, DataContainer.ComputeAction<K, V>) - Static method in class org.infinispan.persistence.internal.PersistenceUtil
- loadAndComputeInDataContainer(DataContainer<K, V>, int, PersistenceManager, K, InvocationContext, TimeService, DataContainer.ComputeAction<K, V>) - Static method in class org.infinispan.persistence.PersistenceUtil
-
Deprecated, for removal: This API element is subject to removal in a future version.since 9.4 This method references PersistenceManager, which isn't a public class
- loadAndStoreInDataContainer(K, int) - Method in interface org.infinispan.persistence.util.EntryLoader
-
Load and store the entry if present in the data container, returning the entry in the CompletionStage.
- loadAndStoreInDataContainer(DataContainer<K, V>, int, PersistenceManager, K, InvocationContext, TimeService, AtomicReference<Boolean>) - Static method in class org.infinispan.persistence.internal.PersistenceUtil
- loadAndStoreInDataContainer(DataContainer<K, V>, int, PersistenceManager, K, InvocationContext, TimeService, AtomicReference<Boolean>) - Static method in class org.infinispan.persistence.PersistenceUtil
-
Deprecated, for removal: This API element is subject to removal in a future version.since 9.4 This method references PersistenceManager, which isn't a public class
- loadAndStoreInDataContainer(DataContainer<K, V>, PersistenceManager, K, InvocationContext, TimeService, AtomicReference<Boolean>) - Static method in class org.infinispan.persistence.internal.PersistenceUtil
- loadAndStoreInDataContainer(DataContainer<K, V>, PersistenceManager, K, InvocationContext, TimeService, AtomicReference<Boolean>) - Static method in class org.infinispan.persistence.PersistenceUtil
-
Deprecated, for removal: This API element is subject to removal in a future version.since 9.4 This method references PersistenceManager, which isn't a public class
- loadAndStoreInDataContainer(InvocationContext, Object, int, FlagAffectedCommand) - Method in interface org.infinispan.persistence.util.EntryLoader
-
Load and store the entry if present in the data container, returning the entry in the CompletionStage
- loadBlocking(List<?>, Deadline) - Method in class org.infinispan.query.impl.EntityLoader
- loadClass(String, ClassLoader) - Static method in class org.infinispan.commons.util.Util
-
Loads the specified class using the passed classloader, or, if it is
null
the Infinispan classes' classloader. - loadClassStrict(String, ClassLoader) - Static method in class org.infinispan.commons.util.Util
-
Loads the specified class using the passed classloader, or, if it is
null
the Infinispan classes' classloader. - LOADED - Enum constant in enum org.infinispan.container.entries.ReadCommittedEntry.Flags
- LOADED - Static variable in class org.infinispan.functional.MetaParam.MetaLoadedFromPersistence
- loadEntry(Object) - Method in class org.infinispan.persistence.cluster.ClusterLoader
-
Deprecated.
- loadEntry(Object) - Method in interface org.infinispan.persistence.spi.CacheLoader
-
Deprecated.Fetches an entry from the storage.
- loadEntry(Object) - Method in class org.infinispan.persistence.support.AbstractSegmentedAdvancedLoadWriteStore
- loadEntry(Object) - Method in class org.infinispan.persistence.support.DelegatingCacheLoader
- loadEntry(Connection, int, Object) - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
- loadEntry(Connection, int, Object) - Method in interface org.infinispan.persistence.jdbc.common.TableOperations
- loader() - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
- LOADER - Enum constant in enum org.infinispan.configuration.parsing.Element
- LoaderConfigurationChildBuilder<S> - Interface in org.infinispan.configuration.cache
-
LoaderConfigurationBuilder is an interface which should be implemented by all cache loader builders
- loadFromAllStores(Object, boolean, boolean) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- loadFromAllStores(Object, int, boolean, boolean) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- loadingStrategy(PojoLoadingTypeContext<T>) - Method in class org.infinispan.search.mapper.search.loading.context.impl.InfinispanLoadingContext
- loadingStrategyOptional(PojoLoadingTypeContext<T>) - Method in class org.infinispan.search.mapper.search.loading.context.impl.InfinispanLoadingContext
- loadJavaServices(Class<S>) - Method in class org.infinispan.search.mapper.mapping.impl.ClassLoaderServiceImpl
- loadMetadata(FileProvider.Handle, int) - Method in class org.infinispan.persistence.sifs.EntryRecord
- loadMetadataAndValue(FileProvider.Handle, int, boolean) - Method in class org.infinispan.persistence.sifs.EntryRecord
- loadModuleCommandHandlers(ClassLoader) - Method in class org.infinispan.util.ModuleProperties
-
Deprecated.
- loadType() - Method in interface org.infinispan.commands.VisitableCommand
- loadType() - Method in class org.infinispan.expiration.impl.TouchCommand
- local(boolean) - Method in interface org.infinispan.query.dsl.Query
-
Set the query execution scope
- LOCAL - Enum constant in enum org.infinispan.client.hotrod.DefaultTemplate
- LOCAL - Enum constant in enum org.infinispan.configuration.cache.CacheMode
-
Data is not replicated.
- LOCAL - Enum constant in enum org.infinispan.configuration.cache.CacheType
- LOCAL - Enum constant in enum org.infinispan.configuration.parsing.ParsedCacheMode
- LOCAL - Enum constant in enum org.infinispan.distribution.DataLocality
-
Deprecated.
- LOCAL - Enum constant in enum org.infinispan.functional.Param.ExecutionMode
-
Command is executed only locally, it is not sent to remote nodes.
- LOCAL - Static variable in interface org.infinispan.transaction.impl.TransactionOriginatorChecker
-
A Local mode implementation.
- LOCAL_CACHE - Enum constant in enum org.infinispan.configuration.parsing.Element
- LOCAL_CACHE_CONFIGURATION - Enum constant in enum org.infinispan.configuration.parsing.Element
- LOCAL_CLUSTER_PUBLISHER - Static variable in class org.infinispan.factories.PublisherManagerFactory
- LOCAL_COMMIT_EXECUTION_TIME - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- LOCAL_CONTAINER_STATS - Static variable in class org.infinispan.stats.impl.LocalContainerStatsImpl
- LOCAL_EXEC_NO_CONT - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- LOCAL_GET - Enum constant in enum org.infinispan.extendedstats.topK.StreamSummaryContainer.Stat
- LOCAL_GET_EXECUTION - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- LOCAL_HEAP - Enum constant in enum org.infinispan.configuration.cache.IndexStorage
- LOCAL_INDEX_STATS - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- LOCAL_NODE - Static variable in class org.infinispan.manager.CacheManagerInfo
- LOCAL_PREPARE_EXECUTION_TIME - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- LOCAL_PUT - Enum constant in enum org.infinispan.extendedstats.topK.StreamSummaryContainer.Stat
- LOCAL_PUT_EXECUTION - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- LOCAL_QUERY_STATS - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- LOCAL_ROLLBACK_EXECUTION_TIME - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- LOCAL_SITE - Enum constant in enum org.infinispan.functional.Param.ExecutionMode
-
Command is executed only in the current site (same as
Param.ExecutionMode.ALL
, but it is not sent for backup to other sites) - LOCAL_UNCERTAIN - Enum constant in enum org.infinispan.distribution.DataLocality
-
Deprecated.
- localAddress - Variable in class org.infinispan.stream.impl.AbstractCacheStream
- LocalArtifact - Class in org.infinispan.commons.maven
-
Represents a local artifact.
- LocalArtifact(String) - Constructor for class org.infinispan.commons.maven.LocalArtifact
- LocalClusterPublisherManagerImpl<K,
V> - Class in org.infinispan.reactive.publisher.impl - LocalClusterPublisherManagerImpl() - Constructor for class org.infinispan.reactive.publisher.impl.LocalClusterPublisherManagerImpl
- LocalCommand - Interface in org.infinispan.commands
-
This is a marker interface to indicate that such commands will never be replicated and hence will not return any valid command IDs.
- LocalConfigurationStorage - Interface in org.infinispan.globalstate
-
The
LocalConfigurationStorage
is responsible for applying on each node the configuration changes initiated through theGlobalConfigurationManager
and persist them unless they areCacheContainerAdmin.AdminFlag.VOLATILE
. - LocalContainerStatsImpl - Class in org.infinispan.stats.impl
-
Provide statistics of the local JVM instance.
- LocalContainerStatsImpl() - Constructor for class org.infinispan.stats.impl.LocalContainerStatsImpl
- LocalExtendedStatisticsContainer - Class in org.infinispan.extendedstats.container
-
Container for the statistics corresponding to local originated transactions.
- LocalExtendedStatisticsContainer() - Constructor for class org.infinispan.extendedstats.container.LocalExtendedStatisticsContainer
- LocalIndexStatistics - Class in org.infinispan.query.stats.impl
-
A
IndexStatistics
for an indexed Cache. - LocalIndexStatistics() - Constructor for class org.infinispan.query.stats.impl.LocalIndexStatistics
- LocalInvocation - Class in org.infinispan.remoting
-
Simulates a remote invocation on the local node.
- LocalizedCacheTopology - Class in org.infinispan.distribution
-
Extends
CacheTopology
with information about keys owned by the local node. - LocalizedCacheTopology(CacheMode, CacheTopology, KeyPartitioner, Address, boolean) - Constructor for class org.infinispan.distribution.LocalizedCacheTopology
- LocalModeAddress - Class in org.infinispan.remoting.transport
-
Represents the local node's address.
- localNodeName() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- localNodeName() - Method in interface org.infinispan.remoting.transport.Transport
- LocalOnlyCacheLoader - Interface in org.infinispan.persistence.spi
-
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.
- localPublisher(int) - Method in interface org.infinispan.CacheCollection
-
Returns a publisher that will publish all elements that map to the given segment.
- localPublisher(int) - Method in class org.infinispan.InternalCacheSet
- localPublisher(IntSet) - Method in interface org.infinispan.CacheCollection
-
Returns a publisher that will publish all elements that map to the given segment.
- localPublisher(IntSet) - Method in class org.infinispan.InternalCacheSet
- LocalPublisherManager<K,
V> - Interface in org.infinispan.reactive.publisher.impl -
Handles locally publishing entries from the cache.
- LocalPublisherManagerImpl<K,
V> - Class in org.infinispan.reactive.publisher.impl -
LocalPublisherManager that publishes entries from the local node only.
- LocalPublisherManagerImpl() - Constructor for class org.infinispan.reactive.publisher.impl.LocalPublisherManagerImpl
- localSite() - Method in class org.infinispan.configuration.global.SiteConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.
- localSite(String) - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.
- localSiteName() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- localSiteName() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- localSiteName() - Method in interface org.infinispan.remoting.transport.Transport
- LocalTopologyManager - Interface in org.infinispan.topology
-
Runs on every node and handles the communication with the
ClusterTopologyManager
. - LocalTopologyManagerFactory - Class in org.infinispan.topology
-
Factory for ClusterTopologyManager implementations.
- LocalTopologyManagerFactory() - Constructor for class org.infinispan.topology.LocalTopologyManagerFactory
- LocalTopologyManagerImpl - Class in org.infinispan.topology
-
The
LocalTopologyManager
implementation. - LocalTopologyManagerImpl() - Constructor for class org.infinispan.topology.LocalTopologyManagerImpl
- LocalTransaction - Class in org.infinispan.transaction.impl
-
Object that holds transaction's state on the node where it originated; as opposed to
RemoteTransaction
. - LocalTransaction(Transaction, GlobalTransaction, boolean, int, long) - Constructor for class org.infinispan.transaction.impl.LocalTransaction
- localTransactionPrepared(LocalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
- localTransactionPrepared(LocalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
- LocalTransactionStatistics - Class in org.infinispan.extendedstats
-
Represents the statistics collected for a local transaction
- LocalTransactionStatistics(boolean, TimeService) - Constructor for class org.infinispan.extendedstats.LocalTransactionStatistics
- LocalTxInvocationContext - Class in org.infinispan.context.impl
-
Invocation context to be used for locally originated transactions.
- LocalTxInvocationContext(LocalTransaction) - Constructor for class org.infinispan.context.impl.LocalTxInvocationContext
- LocalXaTransaction - Class in org.infinispan.transaction.xa
-
LocalTransaction
implementation to be used withTransactionXaAdapter
. - LocalXaTransaction(Transaction, GlobalTransaction, boolean, int, long) - Constructor for class org.infinispan.transaction.xa.LocalXaTransaction
- locateKey(String) - Method in class org.infinispan.distribution.impl.DistributionManagerImpl
- locateOwnersForSegment(int) - Method in interface org.infinispan.distribution.ch.ConsistentHash
- locateOwnersForSegment(int) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
- locateOwnersForSegment(int) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
- locateOwnersForSegment(int) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
- locatePrimaryOwnerForSegment(int) - Method in interface org.infinispan.distribution.ch.ConsistentHash
- locatePrimaryOwnerForSegment(int) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
- locatePrimaryOwnerForSegment(int) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
- locatePrimaryOwnerForSegment(int) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
- locateResourceStream(String) - Method in class org.infinispan.search.mapper.mapping.impl.ClassLoaderServiceImpl
- location - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- location() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
- location() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfiguration
- location(int, int) - Method in class org.infinispan.commons.dataconversion.internal.Json
- location(String) - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
-
Sets a location on disk where the store can write.
- location(String) - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
- location(String) - Method in interface org.infinispan.rest.framework.impl.RestResponseBuilder
- location(String) - Method in class org.infinispan.rest.framework.impl.SimpleRestResponse.Builder
- location(String) - Method in class org.infinispan.rest.NettyRestResponse.Builder
- location(String, String) - Method in class org.infinispan.configuration.global.GlobalStatePathConfigurationBuilder
- location(String, String) - Method in class org.infinispan.configuration.global.TemporaryGlobalStatePathConfigurationBuilder
- Location - Class in org.infinispan.commons.configuration.io
- Location() - Constructor for class org.infinispan.distribution.topologyaware.TopologyInfo.Location
- Location(String, int, int) - Constructor for class org.infinispan.commons.configuration.io.Location
- LOCATION - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- LOCATION - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.Attribute
- LOCATION - Enum constant in enum org.infinispan.rest.ResponseHeader
- LOCATION - Static variable in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
- lock() - Method in class org.infinispan.commons.util.concurrent.NonReentrantLock
- lock() - Method in interface org.infinispan.lock.api.ClusteredLock
-
Acquires the lock.
- lock() - Method in interface org.infinispan.util.concurrent.locks.LockPromise
-
It locks the key (or keys) associated to this promise.
- lock(Object, Object, long, TimeUnit) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticLockManager
- lock(Object, Object, long, TimeUnit) - Method in class org.infinispan.extendedstats.wrappers.TopKeyLockManager
- lock(Object, Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
- lock(Object, Object, long, TimeUnit) - Method in interface org.infinispan.util.concurrent.locks.LockManager
-
Attempts to lock the
key
if the lock isn't already held by thelockOwner
. - lock(Collection<? extends K>) - Method in interface org.infinispan.AdvancedCache
-
Locks collections of keys eagerly across cache nodes in a cluster.
- lock(Collection<? extends K>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- lock(Collection<? extends K>) - Method in class org.infinispan.cache.impl.CacheImpl
- lock(Collection<? extends K>) - Method in class org.infinispan.cache.impl.DecoratedCache
- lock(Collection<? extends K>) - Method in class org.infinispan.cache.impl.EncoderCache
- lock(Collection<? extends K>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- lock(Collection<? extends K>) - Method in class org.infinispan.security.impl.SecureCacheImpl
- lock(K...) - Method in interface org.infinispan.AdvancedCache
-
Locks a given key or keys eagerly across cache nodes in a cluster.
- lock(K...) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- lock(K...) - Method in class org.infinispan.cache.impl.CacheImpl
- lock(K...) - Method in class org.infinispan.cache.impl.DecoratedCache
- lock(K...) - Method in class org.infinispan.cache.impl.EncoderCache
- lock(K...) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- lock(K...) - Method in class org.infinispan.security.impl.SecureCacheImpl
- LOCK - Enum constant in enum org.infinispan.functional.Param.LockingMode
- LOCK_ACQUISITION_TIMEOUT - Static variable in class org.infinispan.configuration.cache.LockingConfiguration
- LOCK_DELETE_MSG - Static variable in interface org.infinispan.lock.logging.Log
- LOCK_HOLD_TIME - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- LOCK_HOLD_TIME_LOCAL - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- LOCK_HOLD_TIME_REMOTE - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- LOCK_HOLD_TIME_SUCCESS_LOCAL_TX - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- LOCK_TIMEOUT - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- LOCK_TIMEOUT - Enum constant in enum org.infinispan.server.hotrod.configuration.Attribute
- LOCK_WAITING_TIME - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- lockAcquisitionTimeout() - Method in class org.infinispan.configuration.cache.LockingConfiguration
-
Maximum time to attempt a particular lock acquisition
- lockAcquisitionTimeout(long) - Method in class org.infinispan.configuration.cache.LockingConfiguration
- lockAcquisitionTimeout(long) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
-
Maximum time to attempt a particular lock acquisition
- lockAcquisitionTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
-
Maximum time to attempt a particular lock acquisition
- lockAll() - Method in class org.infinispan.container.offheap.StripedLock
-
Locks all write locks.
- lockAll(Collection<?>, Object, long, TimeUnit) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticLockManager
- lockAll(Collection<?>, Object, long, TimeUnit) - Method in class org.infinispan.extendedstats.wrappers.TopKeyLockManager
- lockAll(Collection<?>, Object, long, TimeUnit) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
- lockAll(Collection<?>, Object, long, TimeUnit) - Method in interface org.infinispan.util.concurrent.locks.LockManager
-
Same as
LockManager.lock(Object, Object, long, TimeUnit)
but for multiple keys. - lockAs(Object) - Method in interface org.infinispan.AdvancedCache
-
Whenever this cache acquires a lock it will do so using the given Object as the owner of said lock.
- lockAs(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- lockAs(Object) - Method in class org.infinispan.cache.impl.CacheImpl
- lockAs(Object) - Method in class org.infinispan.cache.impl.DecoratedCache
- lockAs(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- lockAs(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
- LockContainer - Interface in org.infinispan.util.concurrent.locks.impl
-
A container for locks
- LockContainerFactory - Class in org.infinispan.factories
-
Factory class that creates instances of
LockContainer
. - LockContainerFactory() - Constructor for class org.infinispan.factories.LockContainerFactory
- lockDeleted() - Method in interface org.infinispan.lock.logging.Log
- lockedStream() - Method in interface org.infinispan.AdvancedCache
-
Returns a sequential stream using this Cache as the source.
- lockedStream() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- lockedStream() - Method in class org.infinispan.cache.impl.CacheImpl
- lockedStream() - Method in class org.infinispan.cache.impl.DecoratedCache
- lockedStream() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- lockedStream() - Method in class org.infinispan.security.impl.SecureCacheImpl
- LockedStream<K,
V> - Interface in org.infinispan -
Stream that allows for operation upon data solely with side effects by using
LockedStream.forEach(BiConsumer)
where the BiConsumer is invoked while guaranteeing that the entry being passed is properly locked for the entire duration of the invocation. - LockedStreamImpl<K,
V> - Class in org.infinispan.stream.impl -
Lock Stream implementation that locks a key using the
LockManager
before and after executing the various code. - LockedStreamImpl(CacheStream<CacheEntry<K, V>>, long, TimeUnit) - Constructor for class org.infinispan.stream.impl.LockedStreamImpl
- locking() - Method in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
- locking() - Method in class org.infinispan.configuration.cache.Configuration
- locking() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- locking() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- LOCKING - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- LOCKING - Enum constant in enum org.infinispan.configuration.parsing.Element
- LOCKING_MODE - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
- LOCKING_MODE_ID - Static variable in class org.infinispan.functional.ParamIds
- LockingConfiguration - Class in org.infinispan.configuration.cache
-
Defines the local, in-VM locking and concurrency characteristics of the cache.
- LockingConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Defines the local, in-VM locking and concurrency characteristics of the cache.
- LockingConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.LockingConfigurationBuilder
- lockingMode() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
-
Configures whether the cache uses optimistic or pessimistic locking.
- lockingMode(LockingMode) - Method in class org.infinispan.configuration.cache.TransactionConfiguration
-
Configures whether the cache uses optimistic or pessimistic locking.
- lockingMode(LockingMode) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
-
Configures whether the cache uses optimistic or pessimistic locking.
- LockingMode - Enum in org.infinispan.transaction
- lockInterruptibly() - Method in class org.infinispan.commons.util.concurrent.NonReentrantLock
- LockListener - Interface in org.infinispan.util.concurrent.locks
-
The listener for
LockPromise
. - LockManager - Interface in org.infinispan.util.concurrent.locks
-
An interface to deal with all aspects of acquiring and releasing locks for cache entries.
- LockManagerFactory - Class in org.infinispan.factories
-
Factory class that creates instances of
LockManager
. - LockManagerFactory() - Constructor for class org.infinispan.factories.LockManagerFactory
- lockOwner - Variable in class org.infinispan.cache.impl.AbstractCacheBackedSet
- LockPromise - Interface in org.infinispan.util.concurrent.locks
-
A promise returned by
InfinispanLock
. - LockReleasedException - Exception in org.infinispan.util.concurrent.locks
-
The exception is thrown if a locks is released while waiting for it to be acquired.
- LockReleasedException() - Constructor for exception org.infinispan.util.concurrent.locks.LockReleasedException
- LockReleasedException(String) - Constructor for exception org.infinispan.util.concurrent.locks.LockReleasedException
- LockReleasedException(String, Throwable) - Constructor for exception org.infinispan.util.concurrent.locks.LockReleasedException
- LockReleasedException(String, Throwable, boolean, boolean) - Constructor for exception org.infinispan.util.concurrent.locks.LockReleasedException
- LockReleasedException(Throwable) - Constructor for exception org.infinispan.util.concurrent.locks.LockReleasedException
- locks() - Method in class org.infinispan.lock.configuration.ClusteredLockManagerConfiguration
- locksAcquired(Collection<Address>) - Method in class org.infinispan.transaction.impl.LocalTransaction
- LockState - Enum in org.infinispan.util.concurrent.locks
-
The
InfinispanLock
possible states. - lockTimeout() - Method in class org.infinispan.server.hotrod.configuration.TopologyCacheConfiguration
- lockTimeout(long) - Method in class org.infinispan.server.hotrod.configuration.TopologyCacheConfigurationBuilder
- log - Static variable in class org.infinispan.client.hotrod.impl.MarshallerRegistry
- log - Static variable in class org.infinispan.commons.reactive.AbstractAsyncPublisherHandler
- log - Static variable in class org.infinispan.extendedstats.TransactionStatistics
- log - Static variable in class org.infinispan.factories.AnyScopeComponentFactory
- log - Static variable in class org.infinispan.globalstate.impl.ImmutableLocalConfigurationStorage
- log - Static variable in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
- log - Static variable in class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller
- log - Static variable in class org.infinispan.jboss.marshalling.commons.CheckedClassResolver
- log - Static variable in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
- log - Static variable in class org.infinispan.reactive.publisher.impl.ClusterPublisherManagerImpl
- log - Static variable in class org.infinispan.reactive.publisher.impl.InnerPublisherSubscription
- log - Static variable in class org.infinispan.reactive.RxJavaInterop
- log - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- log - Static variable in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
- log - Static variable in class org.infinispan.server.core.admin.AdminServerTask
- log - Static variable in class org.infinispan.server.core.backup.resources.CounterResource
- log - Static variable in class org.infinispan.server.hotrod.HotRodDecoder
- log - Variable in class org.infinispan.stats.impl.AbstractClusterStats
- log(ChannelHandlerContext, FullHttpRequest, HttpResponse) - Method in class org.infinispan.rest.logging.RestAccessLoggingHandler
- Log - Interface in org.infinispan.client.hotrod.logging
-
Log abstraction for the hot rod client.
- Log - Interface in org.infinispan.counter.logging
-
range: 29501 - 30000
- Log - Interface in org.infinispan.extendedstats.logging
-
The JBoss Logging interface which defined the logging methods for the extended statistics module.
- Log - Interface in org.infinispan.lock.logging
-
Range: 29001 - 30000
- Log - Interface in org.infinispan.persistence.jdbc.common.logging
-
Log abstraction for the JDBC cache store.
- Log - Interface in org.infinispan.persistence.remote.logging
-
Log abstraction for the remote cache store.
- Log - Interface in org.infinispan.persistence.rocksdb.logging
-
Log abstraction for the RocksDB cache store.
- Log - Interface in org.infinispan.persistence.sifs
-
This module reserves range 29001 - 29500
- Log - Interface in org.infinispan.query.logging
-
Log abstraction for the query module.
- Log - Interface in org.infinispan.rest.logging
-
Log abstraction for the REST server module.
- Log - Interface in org.infinispan.scripting.logging
-
Log abstraction for the Scripting module.
- Log - Interface in org.infinispan.search.mapper.log.impl
-
Log abstraction for the search mapper module.
- Log - Interface in org.infinispan.server.core.logging
-
Log abstraction for the server core module.
- Log - Interface in org.infinispan.server.hotrod.logging
-
Log abstraction for the Hot Rod server module.
- Log - Interface in org.infinispan.server.memcached.logging
-
Log abstraction for the Memcached server module.
- Log(int, FileChannel) - Constructor for class org.infinispan.persistence.sifs.FileProvider.Log
- LOG_ROOT - Static variable in interface org.infinispan.client.hotrod.logging.Log
- LOG_ROOT - Static variable in interface org.infinispan.counter.logging.Log
- LOG_ROOT - Static variable in interface org.infinispan.server.core.logging.Log
- LogAppender - Class in org.infinispan.persistence.sifs
- LogAppender(NonBlockingManager, Index, TemporaryTable, Compactor, FileProvider, boolean, int) - Constructor for class org.infinispan.persistence.sifs.LogAppender
- logEvent(boolean) - Method in class org.infinispan.tasks.TaskContext
-
Whether execution will generate an event in the event log
- logException(ChannelFuture, AccessLoggingHeader, String, int) - Method in class org.infinispan.server.hotrod.logging.HotRodAccessLogging
- logExceptions() - Method in class org.infinispan.xsite.irac.IracXSiteBackup
- LogFactory - Class in org.infinispan.client.hotrod.logging
-
Factory that creates
Log
instances. - LogFactory - Class in org.infinispan.commons.logging
-
Factory that creates
Log
instances. - LogFactory - Class in org.infinispan.util.logging
-
Factory that creates
Log
instances. - LogFactory() - Constructor for class org.infinispan.client.hotrod.logging.LogFactory
- LogFactory() - Constructor for class org.infinispan.commons.logging.LogFactory
- LogFactory() - Constructor for class org.infinispan.util.logging.LogFactory
- logger - Static variable in class org.infinispan.commons.dataconversion.TranscoderMarshallerAdapter
- logger - Static variable in class org.infinispan.encoding.ProtostreamTranscoder
- logger - Static variable in class org.infinispan.jboss.marshalling.dataconversion.JBossMarshallingTranscoder
- logger - Static variable in class org.infinispan.rest.operations.mediatypes.Charset
- logger - Static variable in class org.infinispan.rest.RestRequestHandler
- logger - Static variable in class org.infinispan.rest.stream.CacheChunkedStream
- logger - Static variable in class org.infinispan.server.core.dataconversion.json.SecureTypeIdResolver
-
Deprecated.
- logger - Static variable in class org.infinispan.server.core.dataconversion.JsonTranscoder
- logger - Static variable in class org.infinispan.spring.embedded.InfinispanDefaultCacheFactoryBean
- logger - Static variable in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
- LoggingAuditLogger - Class in org.infinispan.security.audit
-
LoggingAuditLogger.
- LoggingAuditLogger - Class in org.infinispan.security.impl
-
Deprecated, for removal: This API element is subject to removal in a future version.use
LoggingAuditLogger
instead - LoggingAuditLogger() - Constructor for class org.infinispan.security.audit.LoggingAuditLogger
- LoggingAuditLogger() - Constructor for class org.infinispan.security.impl.LoggingAuditLogger
-
Deprecated.
- LoggingResource - Class in org.infinispan.rest.resources
-
Logging configuration resource.
- LoggingResource(InvocationHelper) - Constructor for class org.infinispan.rest.resources.LoggingResource
- logOK(ChannelFuture, AccessLoggingHeader, int) - Method in class org.infinispan.server.hotrod.logging.HotRodAccessLogging
- logRoutingTableInformation(String) - Method in class org.infinispan.topology.CacheTopology
- LogSupplier - Interface in org.infinispan.util.logging
-
Provides a
Log
instance to use. - logThrowable(Throwable) - Method in interface org.infinispan.commands.ReplicableCommand
- logUpdateDiscarded(Object, IracMetadata, LogSupplier) - Static method in class org.infinispan.util.IracUtils
- Long(long) - Constructor for class org.infinispan.commons.util.ByRef.Long
- LONG - Enum constant in enum org.infinispan.stream.impl.IntermediateType
- long_(ByteBuf) - Static method in class org.infinispan.server.hotrod.Intrinsics
- LONG_ATTRIBUTES - Static variable in interface org.infinispan.stats.ContainerStats
- LONG_SUMMARY_STATISTICS - Static variable in interface org.infinispan.commons.marshall.Ids
- longCacheStream() - Method in class org.infinispan.stream.impl.DistributedCacheStream
- longCacheStream() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- longCacheStream() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- LongCacheStream - Interface in org.infinispan
-
A
LongStream
that has additional methods to allow for Serializable instances. - longResponse(HotRodHeader, HotRodServer, Channel, long) - Method in class org.infinispan.server.hotrod.Encoder4x
- longResponse(HotRodHeader, HotRodServer, Channel, long) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- LongSummaryStatisticsExternalizer - Class in org.infinispan.marshall.exts
-
Externalizer used for
LongSummaryStatistics
. - LongSummaryStatisticsExternalizer() - Constructor for class org.infinispan.marshall.exts.LongSummaryStatisticsExternalizer
- longToBytes(long, byte[], int) - Static method in class org.infinispan.commons.util.Util
- lookedUpEntries - Variable in class org.infinispan.transaction.impl.AbstractCacheTransaction
- lookedUpEntriesCount() - Method in interface org.infinispan.context.EntryLookup
- lookedUpEntriesCount() - Method in class org.infinispan.context.impl.NonTxInvocationContext
- lookedUpEntriesCount() - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
- lookedUpEntriesTopology() - Method in class org.infinispan.transaction.impl.RemoteTransaction
- lookuEntityReplacement(int) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- LOOKUP_MAX - Static variable in class org.infinispan.commons.configuration.io.xml.MXParser
- LOOKUP_MAX_CHAR - Static variable in class org.infinispan.commons.configuration.io.xml.MXParser
- lookupByJNDI() - Static method in class org.infinispan.commons.tx.lookup.LookupNames
-
Lookup for a
TransactionManager
by known JNDI names. - lookupByTransactionManagerFactory(ClassLoader) - Static method in class org.infinispan.commons.tx.lookup.LookupNames
-
Lookup a
TransactionManager
by factory. - lookupEntry(Object) - Method in interface org.infinispan.context.EntryLookup
-
Retrieves an entry from the collection of looked up entries in the current scope.
- lookupEntry(Object) - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
- lookupEntry(Object) - Method in class org.infinispan.context.impl.ClearInvocationContext
- lookupEntry(Object) - Method in class org.infinispan.context.impl.ImmutableContext
- lookupEntry(Object) - Method in class org.infinispan.context.impl.NonTxInvocationContext
- lookupEntry(Object) - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
- lookupEntry(Object) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
- lookupEntry(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
- lookupFile(String, ClassLoader) - Method in class org.infinispan.commons.util.AbstractFileLookup
-
Looks up the file, see :
FileLookupFactory.DefaultFileLookup
. - lookupFile(String, ClassLoader) - Method in interface org.infinispan.commons.util.FileLookup
-
Looks up the file, see :
FileLookupFactory.DefaultFileLookup
. - lookupFileLocation(String, ClassLoader) - Method in class org.infinispan.commons.util.AbstractFileLookup
- lookupFileLocation(String, ClassLoader) - Method in interface org.infinispan.commons.util.FileLookup
- lookupFileLocations(String, ClassLoader) - Method in class org.infinispan.commons.util.AbstractFileLookup
- lookupFileLocations(String, ClassLoader) - Method in interface org.infinispan.commons.util.FileLookup
- lookupFileStrict(String, ClassLoader) - Method in class org.infinispan.commons.util.AbstractFileLookup
-
Looks up the file, see :
FileLookupFactory.DefaultFileLookup
. - lookupFileStrict(String, ClassLoader) - Method in interface org.infinispan.commons.util.FileLookup
-
Looks up the file, see :
FileLookupFactory.DefaultFileLookup
. - lookupFileStrict(URI, ClassLoader) - Method in class org.infinispan.commons.util.AbstractFileLookup
- lookupFileStrict(URI, ClassLoader) - Method in interface org.infinispan.commons.util.FileLookup
-
Looks up the file, see :
FileLookupFactory.DefaultFileLookup
. - lookupInvocation(RestRequest) - Method in class org.infinispan.rest.framework.impl.RestDispatcherImpl
- lookupInvocation(RestRequest) - Method in interface org.infinispan.rest.framework.RestDispatcher
- lookupKnownTransactionManagers(ClassLoader) - Static method in class org.infinispan.commons.tx.lookup.LookupNames
-
Lookup for
TransactionManager
. - lookupNameChar - Static variable in class org.infinispan.commons.configuration.io.xml.MXParser
- LookupNames - Class in org.infinispan.commons.tx.lookup
-
The JDNI and
TransactionManager
factories we know of. - LookupNames.JndiTransactionManager - Enum in org.infinispan.commons.tx.lookup
-
JNDI locations for TransactionManagers we know of.
- LookupNames.TransactionManagerFactory - Enum in org.infinispan.commons.tx.lookup
-
TransactionManager factories we know of.
- lookupNameStartChar - Static variable in class org.infinispan.commons.configuration.io.xml.MXParser
- lookupResource(Method, String) - Method in interface org.infinispan.rest.framework.ResourceManager
- lookupResource(Method, String, String) - Method in class org.infinispan.rest.framework.impl.ResourceManagerImpl
- lookupResource(Method, String, String) - Method in interface org.infinispan.rest.framework.ResourceManager
- LookupResult - Interface in org.infinispan.rest.framework
- LookupResult.Status - Enum in org.infinispan.rest.framework
-
Status of the lookup operation.
- LookupResultImpl - Class in org.infinispan.rest.framework.impl
- LostDataCheck - Interface in org.infinispan.partitionhandling.impl
- lostSegment() - Method in interface org.infinispan.reactive.publisher.impl.SegmentAwarePublisherSupplier.NotificationWithLost
-
The segment that was complete for this notification
- lostSegment(boolean) - Method in interface org.infinispan.stream.impl.SegmentAwareOperation
-
This method will be invoked when the operation is known to be performing on a given set of segments and this node no longer owns 1 or many of them.
- LOW - Enum constant in enum org.infinispan.client.hotrod.configuration.SaslStrength
- LOW - Enum constant in enum org.infinispan.server.hotrod.configuration.Strength
- LOW_LEVEL_TRACE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- LOWER_BOUND - Enum constant in enum org.infinispan.counter.configuration.Attribute
- LOWER_BOUND - Enum constant in enum org.infinispan.counter.configuration.Element
- LOWER_BOUND - Static variable in exception org.infinispan.counter.exception.CounterOutOfBoundsException
- LOWER_BOUND_REACHED - Enum constant in enum org.infinispan.counter.api.CounterState
-
The counter value has reached its min threshold, i.e.
- lowerBound() - Method in class org.infinispan.counter.api.CounterConfiguration
- lowerBound() - Method in class org.infinispan.counter.configuration.StrongCounterConfiguration
- lowerBound(long) - Method in class org.infinispan.counter.api.CounterConfiguration.Builder
-
Sets the lower bound (inclusive) of the counter.
- lowerBound(long) - Method in class org.infinispan.counter.configuration.StrongCounterConfigurationBuilder
-
Sets the lower bound (inclusive) of the counter if a bounded counter is desired.
- lruLock - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
- lt(Object) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
-
Deprecated.Checks that the left argument is less than the given value.
- lte(Object) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
-
Deprecated.Checks that the left argument is less than or equal to the given value.
- LUCENE_LOWER_BOUND - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- LZ4 - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.CompressionType
- LZ4HC - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.CompressionType
M
- MAC_OS - Enum constant in enum org.infinispan.commons.util.OS
- MACHINE - Enum constant in enum org.infinispan.distribution.topologyaware.TopologyLevel
- MACHINE_ID - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- MACHINE_ID - Static variable in class org.infinispan.configuration.global.TransportConfiguration
- machineId() - Method in class org.infinispan.configuration.global.TransportConfiguration
- machineId(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
-
The id of the machine where this node runs.
- MAGIC_11_0 - Static variable in class org.infinispan.persistence.file.SingleFileStore
- MAGIC_12_0 - Static variable in class org.infinispan.persistence.file.SingleFileStore
- MAGIC_12_1 - Static variable in class org.infinispan.persistence.file.SingleFileStore
- MAGIC_BEFORE_11 - Static variable in class org.infinispan.persistence.file.SingleFileStore
- MAGIC_LATEST - Static variable in class org.infinispan.persistence.file.SingleFileStore
- MAGIC_REQ - Static variable in class org.infinispan.server.hotrod.Constants
- MAGIC_RES - Static variable in class org.infinispan.server.hotrod.Constants
- main(String[]) - Static method in class org.infinispan.commons.dataconversion.internal.Json
- main(String[]) - Static method in class org.infinispan.commons.util.ProcessorInfo
- main(String[]) - Static method in class org.infinispan.commons.util.Version
-
Prints version information.
- main(String[]) - Static method in class org.infinispan.Version
-
Deprecated.Prints version information.
- mainType - Variable in class org.infinispan.commons.dataconversion.OneToManyTranscoder
- make(Object) - Method in class org.infinispan.commons.dataconversion.internal.Json.DefaultFactory
- make(Object) - Method in interface org.infinispan.commons.dataconversion.internal.Json.Factory
-
Construct and return a JSON object.
- make(Object) - Static method in class org.infinispan.commons.dataconversion.internal.Json
-
Convert an arbitrary Java instance to a
Json
instance. - makeFactoryParams(String, Map<String, Object>) - Static method in class org.infinispan.client.hotrod.filter.Filters
- makeFactoryParams(Query<?>) - Static method in class org.infinispan.client.hotrod.filter.Filters
- makeFilter(String) - Static method in class org.infinispan.query.Search
-
Creates an event filter from an Ickle query string.
- makeFilter(String, Map<String, Object>) - Static method in class org.infinispan.query.Search
-
Creates event filters from Ickle query strings.
- makeFilter(Query<?>) - Static method in class org.infinispan.query.Search
-
Creates event filters from Ickle query strings.
- makeSegmentedSingletonTopology(KeyPartitioner, int, Address) - Static method in class org.infinispan.distribution.LocalizedCacheTopology
-
Creates a new local topology that has a single address but multiple segments.
- makeSingletonTopology(CacheMode, KeyPartitioner, int, Address) - Static method in class org.infinispan.distribution.impl.DistributionManagerImpl
- makeSingletonTopology(CacheMode, Address) - Static method in class org.infinispan.distribution.LocalizedCacheTopology
- makeStage(Object) - Static method in class org.infinispan.interceptors.BaseAsyncInterceptor
-
Encode the result of an
BaseAsyncInterceptor.invokeNext(InvocationContext, VisitableCommand)
in anInvocationStage
. - makeStage(Object) - Static method in class org.infinispan.interceptors.InvocationStage
-
If
maybeStage
is not anInvocationStage
, wrap it, otherwise cast it to anInvocationStage
. - MalformedJsonException(String, int, int) - Constructor for exception org.infinispan.commons.dataconversion.internal.Json.MalformedJsonException
- MalformedRequest - Exception in org.infinispan.rest.operations.exceptions
- MalformedRequest(String) - Constructor for exception org.infinispan.rest.operations.exceptions.MalformedRequest
- ManageableExecutorService<T extends ExecutorService> - Class in org.infinispan.executors
- ManageableExecutorService() - Constructor for class org.infinispan.executors.ManageableExecutorService
- ManageableThreadPoolExecutorService - Class in org.infinispan.server.core.utils
- ManageableThreadPoolExecutorService(ExecutorService) - Constructor for class org.infinispan.server.core.utils.ManageableThreadPoolExecutorService
- manageConnectionFactory() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfiguration
-
Deprecated.Since 13.0 with no replacement
- manageConnectionFactory(boolean) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
-
Deprecated.Deprecated since 13.0 with no replacement
- MANAGED - Enum constant in enum org.infinispan.globalstate.ConfigurationStorage
-
Stores non-
CacheContainerAdmin.AdminFlag.VOLATILE
caches in a managed environment such as the server model. - MANAGED_CONFIGURATION_STORAGE - Enum constant in enum org.infinispan.configuration.parsing.Element
- ManagedConnectionFactoryConfiguration - Class in org.infinispan.persistence.jdbc.common.configuration
-
ManagedConnectionFactoryConfiguration.
- ManagedConnectionFactoryConfigurationBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,
S>> - Class in org.infinispan.persistence.jdbc.common.configuration -
ManagedConnectionFactoryConfigurationBuilder.
- ManagedConnectionFactoryConfigurationBuilder(AbstractJdbcStoreConfigurationBuilder<?, S>) - Constructor for class org.infinispan.persistence.jdbc.common.configuration.ManagedConnectionFactoryConfigurationBuilder
- MANAGER - Static variable in interface org.infinispan.jmx.ObjectNameKeys
- MANAGER_STATUS_RESPONSE - Static variable in interface org.infinispan.commons.marshall.Ids
- ManagerStatusResponse - Class in org.infinispan.topology
- ManagerStatusResponse(Map<String, CacheStatusResponse>, boolean) - Constructor for class org.infinispan.topology.ManagerStatusResponse
- ManagerStatusResponse.Externalizer - Class in org.infinispan.topology
- MANUAL - Enum constant in enum org.infinispan.configuration.cache.XSiteStateTransferMode
-
Cross-site state transfer is triggered manually via CLI, JMX, or REST.
- MANUAL - Enum constant in enum org.infinispan.eviction.EvictionStrategy
-
Strategy where the cache does nothing but the user is assumed to manually invoke evict method
- manuallySwitchedBackToMainCluster() - Method in interface org.infinispan.client.hotrod.logging.Log
- manuallySwitchedToCluster(String) - Method in interface org.infinispan.client.hotrod.logging.Log
- manuallyUpdateAvailabilityMode(List<Address>, AvailabilityMode, boolean) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
-
Enter a new availability mode manually.
- manuallyUpdateAvailabilityMode(List<Address>, AvailabilityMode, boolean) - Method in class org.infinispan.topology.ClusterCacheStatus
- map - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
- map - Variable in class org.infinispan.remoting.transport.impl.MapResponseCollector
- map(DoubleUnaryOperator) - Method in interface org.infinispan.DoubleCacheStream
- map(DoubleUnaryOperator) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- map(DoubleUnaryOperator) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- map(Function<? super R, ? extends R1>) - Method in interface org.infinispan.CacheStream
- map(Function<? super R, ? extends R1>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
- map(Function<? super R, ? extends R1>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- map(Function<? super R, ? extends R1>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- map(Function<? super T, ? extends R>) - Method in interface org.infinispan.functional.Traversable
-
An intermediate operation that returns a traversable containing the results of applying the given function over the elements of the traversable.
- map(IntUnaryOperator) - Method in interface org.infinispan.IntCacheStream
- map(IntUnaryOperator) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- map(IntUnaryOperator) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- map(LongUnaryOperator) - Method in interface org.infinispan.LongCacheStream
- map(LongUnaryOperator) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- map(LongUnaryOperator) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- map(SerializableDoubleUnaryOperator) - Method in interface org.infinispan.DoubleCacheStream
-
Same as
DoubleCacheStream.map(DoubleUnaryOperator)
except that the DoubleUnaryOperator must also implementSerializable
- map(SerializableDoubleUnaryOperator) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- map(SerializableFunction<? super R, ? extends R1>) - Method in interface org.infinispan.CacheStream
-
Same as
CacheStream.map(Function)
except that the Function must also implementSerializable
- map(SerializableIntUnaryOperator) - Method in interface org.infinispan.IntCacheStream
-
Same as
IntCacheStream.map(IntUnaryOperator)
except that the IntUnaryOperator must also implementSerializable
- map(SerializableIntUnaryOperator) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- map(SerializableLongUnaryOperator) - Method in interface org.infinispan.LongCacheStream
-
Same as
LongCacheStream.map(LongUnaryOperator)
except that the LongUnaryOperator must also implement Serializable. - map(SerializableLongUnaryOperator) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- mapAddresses(List<Address>) - Method in interface org.infinispan.topology.PersistentUUIDManager
-
Returns a list of
PersistentUUID
s for the suppliedAddress
es - mapAddresses(List<Address>) - Method in class org.infinispan.topology.PersistentUUIDManagerImpl
- MapEntry$___Marshaller_37a121f54771729f5bc90dae7b319161c44a1e9491f8af866c7aba312bf9651e - Class in org.infinispan.container.versioning.irac
-
WARNING: Generated code! Do not edit!
- MapEntry$___Marshaller_37a121f54771729f5bc90dae7b319161c44a1e9491f8af866c7aba312bf9651e() - Constructor for class org.infinispan.container.versioning.irac.MapEntry$___Marshaller_37a121f54771729f5bc90dae7b319161c44a1e9491f8af866c7aba312bf9651e
- MapExternalizer - Class in org.infinispan.marshall.exts
-
Map externalizer for all map implementations except immutable maps and singleton maps, i.e.
- MapExternalizer() - Constructor for class org.infinispan.marshall.exts.MapExternalizer
- mapper - Variable in class org.infinispan.commons.util.SpliteratorMapper
- mapper - Variable in class org.infinispan.util.CollectionMapper
- mapper() - Method in class org.infinispan.configuration.global.PrincipalRoleMapperConfigurationBuilder
- mapper() - Method in class org.infinispan.configuration.global.RolePermissionMapperConfigurationBuilder
- mapper(PrincipalRoleMapper) - Method in class org.infinispan.configuration.global.PrincipalRoleMapperConfigurationBuilder
- mapper(RolePermissionMapper) - Method in class org.infinispan.configuration.global.RolePermissionMapperConfigurationBuilder
- MAPPER - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- mapping() - Method in class org.infinispan.search.mapper.log.impl.InfinispanEventContextMessages_$bundle
- mapping() - Method in interface org.infinispan.search.mapper.log.impl.InfinispanEventContextMessages
- mapping$str() - Method in class org.infinispan.search.mapper.log.impl.InfinispanEventContextMessages_$bundle
- MappingConfigurationContext - Interface in org.infinispan.search.mapper.mapping
- mappingIsRestarting() - Method in interface org.infinispan.query.logging.Log
- MapResponseCollector - Class in org.infinispan.remoting.transport.impl
- maps - Variable in class org.infinispan.container.impl.DefaultSegmentedDataContainer
- MAPS - Static variable in interface org.infinispan.commons.marshall.Ids
- MapSessionProtoAdapter - Class in org.infinispan.spring.common.session
-
Protostream adapter for Spring's
MapSession
. - MapSessionProtoAdapter() - Constructor for class org.infinispan.spring.common.session.MapSessionProtoAdapter
- MapSessionProtoAdapter.SessionAttribute - Class in org.infinispan.spring.common.session
- MapSessionProtoAdapter.SessionAttributeRawMarshaller - Class in org.infinispan.spring.common.session
-
Generated with protostream-processor and then adapted to use
JavaSerializationMarshaller
. - MapSessionProtoAdapter$___Marshaller_71442e7b0d28786c1f10a1743da12fcd08d64dc0b8a798e5658e855284c87eee - Class in org.infinispan.spring.common.session
-
WARNING: Generated code! Do not edit!
- MapSessionProtoAdapter$___Marshaller_71442e7b0d28786c1f10a1743da12fcd08d64dc0b8a798e5658e855284c87eee() - Constructor for class org.infinispan.spring.common.session.MapSessionProtoAdapter$___Marshaller_71442e7b0d28786c1f10a1743da12fcd08d64dc0b8a798e5658e855284c87eee
- mapSupplier - Variable in class org.infinispan.container.impl.DefaultSegmentedDataContainer
- mapToDouble(IntToDoubleFunction) - Method in interface org.infinispan.IntCacheStream
- mapToDouble(IntToDoubleFunction) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- mapToDouble(IntToDoubleFunction) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- mapToDouble(LongToDoubleFunction) - Method in interface org.infinispan.LongCacheStream
- mapToDouble(LongToDoubleFunction) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- mapToDouble(LongToDoubleFunction) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- mapToDouble(ToDoubleFunction<? super R>) - Method in interface org.infinispan.CacheStream
- mapToDouble(ToDoubleFunction<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
- mapToDouble(ToDoubleFunction<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- mapToDouble(ToDoubleFunction<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- mapToDouble(SerializableIntToDoubleFunction) - Method in interface org.infinispan.IntCacheStream
-
Same as
IntCacheStream.mapToDouble(IntToDoubleFunction)
except that the IntToIntFunction must also implementSerializable
- mapToDouble(SerializableIntToDoubleFunction) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- mapToDouble(SerializableLongToDoubleFunction) - Method in interface org.infinispan.LongCacheStream
-
Same as
LongCacheStream.mapToDouble(LongToDoubleFunction)
except that the LongToLongFunction must also implement Serializable. - mapToDouble(SerializableLongToDoubleFunction) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- mapToDouble(SerializableToDoubleFunction<? super R>) - Method in interface org.infinispan.CacheStream
-
Same as
CacheStream.mapToDouble(ToDoubleFunction)
except that the ToDoubleFunction must also implementSerializable
- mapToInt(DoubleToIntFunction) - Method in interface org.infinispan.DoubleCacheStream
- mapToInt(DoubleToIntFunction) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- mapToInt(DoubleToIntFunction) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- mapToInt(LongToIntFunction) - Method in interface org.infinispan.LongCacheStream
- mapToInt(LongToIntFunction) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- mapToInt(LongToIntFunction) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- mapToInt(ToIntFunction<? super R>) - Method in interface org.infinispan.CacheStream
- mapToInt(ToIntFunction<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
- mapToInt(ToIntFunction<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- mapToInt(ToIntFunction<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- mapToInt(SerializableDoubleToIntFunction) - Method in interface org.infinispan.DoubleCacheStream
-
Same as
DoubleCacheStream.mapToInt(DoubleToIntFunction)
except that the DoubleToIntFunction must also implementSerializable
- mapToInt(SerializableDoubleToIntFunction) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- mapToInt(SerializableLongToIntFunction) - Method in interface org.infinispan.LongCacheStream
-
Same as
LongCacheStream.mapToInt(LongToIntFunction)
except that the LongToIntFunction must also implement Serializable. - mapToInt(SerializableLongToIntFunction) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- mapToInt(SerializableToIntFunction<? super R>) - Method in interface org.infinispan.CacheStream
-
Same as
CacheStream.mapToInt(ToIntFunction)
except that the ToIntFunction must also implementSerializable
- mapToLong(DoubleToLongFunction) - Method in interface org.infinispan.DoubleCacheStream
- mapToLong(DoubleToLongFunction) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- mapToLong(DoubleToLongFunction) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- mapToLong(IntToLongFunction) - Method in interface org.infinispan.IntCacheStream
- mapToLong(IntToLongFunction) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- mapToLong(IntToLongFunction) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- mapToLong(ToLongFunction<? super R>) - Method in interface org.infinispan.CacheStream
- mapToLong(ToLongFunction<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
- mapToLong(ToLongFunction<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- mapToLong(ToLongFunction<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- mapToLong(SerializableDoubleToLongFunction) - Method in interface org.infinispan.DoubleCacheStream
-
Same as
DoubleCacheStream.mapToLong(DoubleToLongFunction)
except that the DoubleToLongFunction must also implementSerializable
- mapToLong(SerializableDoubleToLongFunction) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- mapToLong(SerializableIntToLongFunction) - Method in interface org.infinispan.IntCacheStream
-
Same as
IntCacheStream.mapToLong(IntToLongFunction)
except that the IntToLongFunction must also implementSerializable
- mapToLong(SerializableIntToLongFunction) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- mapToLong(SerializableToLongFunction<? super R>) - Method in interface org.infinispan.CacheStream
-
Same as
CacheStream.mapToLong(ToLongFunction)
except that the ToLongFunction must also implementSerializable
- mapToObj(DoubleFunction<? extends U>) - Method in interface org.infinispan.DoubleCacheStream
- mapToObj(DoubleFunction<? extends U>) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- mapToObj(DoubleFunction<? extends U>) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- mapToObj(IntFunction<? extends U>) - Method in interface org.infinispan.IntCacheStream
- mapToObj(IntFunction<? extends U>) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- mapToObj(IntFunction<? extends U>) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- mapToObj(LongFunction<? extends U>) - Method in interface org.infinispan.LongCacheStream
- mapToObj(LongFunction<? extends U>) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- mapToObj(LongFunction<? extends U>) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- mapToObj(SerializableDoubleFunction<? extends U>) - Method in interface org.infinispan.DoubleCacheStream
-
Same as
DoubleCacheStream.mapToObj(DoubleFunction)
except that the DoubleFunction must also implementSerializable
- mapToObj(SerializableDoubleFunction<? extends U>) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- mapToObj(SerializableIntFunction<? extends U>) - Method in interface org.infinispan.IntCacheStream
-
Same as
IntCacheStream.mapToObj(IntFunction)
except that the IntFunction must also implementSerializable
- mapToObj(SerializableIntFunction<? extends U>) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- mapToObj(SerializableLongFunction<? extends U>) - Method in interface org.infinispan.LongCacheStream
-
Same as
LongCacheStream.mapToObj(LongFunction)
except that the LongFunction must also implement Serializable. - mapToObj(SerializableLongFunction<? extends U>) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- MARIA_DB - Enum constant in enum org.infinispan.persistence.jdbc.common.DatabaseType
- MARK_COMMIT - Enum constant in enum org.infinispan.server.hotrod.tx.table.Status
-
The client
TransactionManager
decided to commit. - MARK_ROLLBACK - Enum constant in enum org.infinispan.server.hotrod.tx.table.Status
-
The client
TransactionManager
decided to rollback of we fail to replay/prepare the transaction. - markAsUpdateTransaction() - Method in class org.infinispan.extendedstats.TransactionStatistics
-
Sets this transaction as a write transaction.
- markAsWriteTransaction(GlobalTransaction, boolean) - Method in class org.infinispan.extendedstats.CacheStatisticManager
-
Marks the transaction as a write transaction (instead of a read only transaction)
- markCompleted(boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
-
Called when after the 2nd phase of a 2PC is successful.
- markDelivered(int, long, int) - Method in class org.infinispan.distribution.TriangleOrderManager
- markForRollback(boolean) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
- markForRollback(boolean) - Method in interface org.infinispan.transaction.xa.CacheTransaction
- markMarshallable(Class<?>, boolean) - Method in class org.infinispan.commons.marshall.MarshallableTypeHints
-
Marks a particular type as being marshallable or not being not marshallable.
- markPrepareSent() - Method in class org.infinispan.transaction.impl.LocalTransaction
-
Sets the prepare sent for this transaction
- markPreparing(List<WriteCommand>, TimeService) - Method in class org.infinispan.server.hotrod.tx.table.TxState
- markToCommit(XidImpl, CacheNameCollector) - Method in class org.infinispan.server.hotrod.tx.table.GlobalTxTable
- markToRollback(XidImpl, CacheNameCollector) - Method in class org.infinispan.server.hotrod.tx.table.GlobalTxTable
- markTransactionCompleted(GlobalTransaction, boolean) - Method in class org.infinispan.transaction.impl.TransactionTable
-
With the current state transfer implementation it is possible for a transaction to be prepared several times on a remote node.
- markUnexistingTransactionAsWriteTransaction(String) - Method in interface org.infinispan.extendedstats.logging.Log
- marshall(Object) - Method in class org.infinispan.commons.dataconversion.MarshallerEncoder
-
Deprecated.
- marshall(Object, Marshaller) - Static method in class org.infinispan.persistence.jdbc.common.JdbcUtil
- MARSHALLABLE_USER_OBJECT - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- MarshallableEntry<K,
V> - Interface in org.infinispan.persistence.spi -
Defines an externally persisted entry.
- marshallableEntryFactory - Variable in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.ProtoSchemaOptions
- MarshallableEntryFactory<K,
V> - Interface in org.infinispan.persistence.spi -
Factory for
MarshallableEntry
. - MarshallableFunctionExternalizers - Class in org.infinispan.marshall.core
- MarshallableFunctionExternalizers() - Constructor for class org.infinispan.marshall.core.MarshallableFunctionExternalizers
- MarshallableFunctionExternalizers.ConstantLambdaExternalizer - Class in org.infinispan.marshall.core
- MarshallableFunctionExternalizers.LambdaWithMetasExternalizer - Class in org.infinispan.marshall.core
- MarshallableFunctionExternalizers.SetValueIfEqualsReturnBooleanExternalizer - Class in org.infinispan.marshall.core
- MarshallableFunctions - Class in org.infinispan.marshall.core
- marshallableTypeHints - Variable in class org.infinispan.commons.marshall.AbstractMarshaller
- MarshallableTypeHints - Class in org.infinispan.commons.marshall
-
Class providing hints about marshallable types, such as whether a particular type is marshallable or not, or an accurate approach to the serialized size of a particular type.
- MarshallableTypeHints() - Constructor for class org.infinispan.commons.marshall.MarshallableTypeHints
- marshallArray(E[], ObjectOutput) - Static method in class org.infinispan.commons.marshall.MarshallUtil
-
Marshall arrays.
- marshallByteArray(byte[], ObjectOutput) - Static method in class org.infinispan.commons.marshall.MarshallUtil
-
Same as
MarshallUtil.marshallArray(Object[], ObjectOutput)
but specialized for byte arrays. - marshallCollection(Collection<E>, ObjectOutput) - Static method in class org.infinispan.commons.marshall.MarshallUtil
-
Marshall a
Collection
. - marshallCollection(Collection<E>, ObjectOutput, MarshallUtil.ElementWriter<E>) - Static method in class org.infinispan.commons.marshall.MarshallUtil
-
Marshall a
Collection
. - MARSHALLED_ENTRY_ID - Static variable in interface org.infinispan.commons.marshall.Ids
- MARSHALLED_VALUE_IMPL - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- marshalledEntryPurged(MarshallableEntry<K, V>) - Method in interface org.infinispan.persistence.spi.AdvancedCacheExpirationWriter.ExpirationPurgeListener
-
Deprecated.If possible,
AdvancedCacheExpirationWriter
implementors should invoke this method for every entry that is purged from the store. - MarshalledValue - Interface in org.infinispan.persistence.spi
-
A marshallable object containing serialized representations of cache values and metadata, that can be used to store values, metadata and timestamps as a single entity.
- MarshalledValueByteStream - Class in org.infinispan.io
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.0 requires jboss-marshalling-osgi artifact to be provided at runtime.
- MarshalledValueByteStream() - Constructor for class org.infinispan.io.MarshalledValueByteStream
-
Deprecated.
- marshallEnum(E, ObjectOutput) - Static method in class org.infinispan.commons.marshall.MarshallUtil
- marshaller - Variable in class org.infinispan.cache.impl.CacheImpl
- marshaller - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- marshaller() - Method in class org.infinispan.client.hotrod.configuration.Configuration
- marshaller() - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
- marshaller() - Method in class org.infinispan.client.hotrod.event.impl.ClientListenerNotifier
- marshaller() - Method in class org.infinispan.configuration.global.SerializationConfiguration
- marshaller() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
- marshaller(Class<? extends Marshaller>) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
- marshaller(Class<? extends Marshaller>) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- marshaller(Class<? extends Marshaller>) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
-
Allows you to specify a custom
Marshaller
implementation to serialize and deserialize user objects. - marshaller(Class<? extends Marshaller>) - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfigurationBuilder
-
Specifies a custom
Marshaller
implementation. - marshaller(Class<? extends Marshaller>) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- marshaller(Class<? extends Marshaller>) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- marshaller(Class<? extends Marshaller>) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
-
Allows you to specify a custom
Marshaller
implementation to serialize and deserialize user objects. - marshaller(String) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
- marshaller(String) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- marshaller(String) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
-
Allows you to specify a custom
Marshaller
implementation to serialize and deserialize user objects. - marshaller(String) - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfigurationBuilder
-
Specifies a custom
Marshaller
implementation. - marshaller(String) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- marshaller(String) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- marshaller(String) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
-
Allows you to specify a custom
Marshaller
implementation to serialize and deserialize user objects. - marshaller(Marshaller) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
- marshaller(Marshaller) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- marshaller(Marshaller) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
-
Allows you to specify an instance of
Marshaller
to serialize and deserialize user objects. - marshaller(Marshaller) - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfigurationBuilder
-
Specifies a custom
Marshaller
implementation to serialize and deserialize user objects. - marshaller(Marshaller) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
-
Set the marshaller instance that will marshall and unmarshall cache entries.
- marshaller(Marshaller) - Method in class org.infinispan.tasks.TaskContext
-
The marshaller with which this task should be executed
- Marshaller - Interface in org.infinispan.commons.marshall
-
A marshaller is a class that is able to marshall and unmarshall objects efficiently.
- MARSHALLER - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- MARSHALLER - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- MARSHALLER - Static variable in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
- MARSHALLER - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- MARSHALLER - Static variable in class org.infinispan.configuration.global.SerializationConfiguration
- MARSHALLER_CLASS - Static variable in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
- marshallerClass() - Method in class org.infinispan.client.hotrod.configuration.Configuration
- marshallerClass() - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
- MarshallerEncoder - Class 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.
- MarshallerEncoder(Marshaller) - Constructor for class org.infinispan.commons.dataconversion.MarshallerEncoder
-
Deprecated.
- MarshallerFactory - Class in org.infinispan.factories
-
MarshallerFactory.
- MarshallerFactory() - Constructor for class org.infinispan.factories.MarshallerFactory
- MarshallerRegistry - Class in org.infinispan.client.hotrod.impl
-
A registry of
Marshaller
along with itsMediaType
. - MarshallerRegistry() - Constructor for class org.infinispan.client.hotrod.impl.MarshallerRegistry
- MarshallerUtil - Class in org.infinispan.client.hotrod.marshall
- MarshallingException - Exception in org.infinispan.commons.marshall
-
An exception that can be thrown by a cache if an object cannot be successfully serialized/deserialized.
- MarshallingException() - Constructor for exception org.infinispan.commons.marshall.MarshallingException
- MarshallingException(String) - Constructor for exception org.infinispan.commons.marshall.MarshallingException
- MarshallingException(String, Throwable) - Constructor for exception org.infinispan.commons.marshall.MarshallingException
- MarshallingException(String, Throwable, boolean, boolean) - Constructor for exception org.infinispan.commons.marshall.MarshallingException
- MarshallingException(Throwable) - Constructor for exception org.infinispan.commons.marshall.MarshallingException
- MarshallingTwoWayKey2StringMapper - Interface in org.infinispan.persistence.keymappers
-
MarshallingTwoWayKey2StringMapper.
- marshallIntCollection(Collection<Integer>, ObjectOutput) - Static method in class org.infinispan.commons.marshall.MarshallUtil
-
Marshalls a collection of integers.
- marshallMap(T, ObjectOutput) - Static method in class org.infinispan.commons.marshall.MarshallUtil
-
Marshall the
map
to theObjectOutput
. - marshallMap(T, MarshallUtil.ElementWriter<K>, MarshallUtil.ElementWriter<V>, ObjectOutput) - Static method in class org.infinispan.commons.marshall.MarshallUtil
-
Marshall the
map
to theObjectOutput
. - marshallSize(DataOutput, int) - Static method in class org.infinispan.commons.marshall.MarshallUtil
-
A special marshall implementation for integer.
- marshallString(String, ObjectOutput) - Static method in class org.infinispan.commons.marshall.MarshallUtil
-
Marshall the
String
. - MarshallUtil - Class in org.infinispan.commons.marshall
-
MarshallUtil.
- MarshallUtil() - Constructor for class org.infinispan.commons.marshall.MarshallUtil
- MarshallUtil.ArrayBuilder<E> - Interface in org.infinispan.commons.marshall
- MarshallUtil.CollectionBuilder<E,
T extends Collection<E>> - Interface in org.infinispan.commons.marshall - MarshallUtil.ElementReader<E> - Interface in org.infinispan.commons.marshall
- MarshallUtil.ElementWriter<E> - Interface in org.infinispan.commons.marshall
- MarshallUtil.EnumBuilder<E extends Enum<E>> - Interface in org.infinispan.commons.marshall
- MarshallUtil.MapBuilder<K,
V, T extends Map<K, V>> - Interface in org.infinispan.commons.marshall - MarshallUtil.UnboundedCollectionBuilder<E,
T extends Collection<E>> - Interface in org.infinispan.commons.marshall - marshallUUID(UUID, ObjectOutput, boolean) - Static method in class org.infinispan.commons.marshall.MarshallUtil
-
Marshall the
UUID
by sending the most and lest significant bits. - mask(byte, int) - Static method in class org.infinispan.server.hotrod.BitShift
- massIndexerIndexingInstance(String) - Method in interface org.infinispan.query.logging.Log
- massIndexingEntityFailures(long, EntityReference, String, Throwable) - Method in interface org.infinispan.query.logging.Log
- match(Object, Object, Object) - Method in interface org.infinispan.objectfilter.Matcher
-
Test the given instance against all the subscribed filters and notify all callbacks registered for instances of the same instance type.
- match(MediaType) - Method in class org.infinispan.commons.dataconversion.MediaType
- MATCH_ALL - Static variable in class org.infinispan.commons.dataconversion.MediaType
- MATCH_ALL_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- MATCH_ALWAYS - Enum constant in enum org.infinispan.commons.marshall.ValueMatcherMode
- MATCH_EXPECTED - Enum constant in enum org.infinispan.commons.marshall.ValueMatcherMode
- MATCH_EXPECTED_OR_NEW - Enum constant in enum org.infinispan.commons.marshall.ValueMatcherMode
- MATCH_NEVER - Enum constant in enum org.infinispan.commons.marshall.ValueMatcherMode
- MATCH_NON_NULL - Enum constant in enum org.infinispan.commons.marshall.ValueMatcherMode
- Matchable<T> - Interface in org.infinispan.commons.configuration.attributes
-
An interface for defining non-strict equality, e.g.
- matchDelta(Object, Object, Object, Object, Object, Object, Object) - Method in interface org.infinispan.objectfilter.Matcher
-
Test two instances (which are actually before/after snapshots of the same instance) against all the subscribed filters and notify all callbacks registered for instances of the same instance type.
- Matcher - Interface in org.infinispan.objectfilter
-
An object matcher able to test a given object against multiple registered filters specified either as Ickle queries (a JP-QL subset with full-text support) or using the query DSL (see
org.infinispan.query.dsl
). - matches(int) - Method in enum org.infinispan.security.AuthorizationPermission
- matches(int) - Method in class org.infinispan.security.impl.SubjectACL
- matches(Channel) - Method in class org.infinispan.server.core.transport.CompositeChannelMatcher
- matches(Channel) - Method in class org.infinispan.server.core.transport.IpFilterRuleChannelMatcher
- matches(String) - Method in enum org.infinispan.configuration.parsing.ParsedCacheMode
- matches(String, String, String) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
- matches(InetSocketAddress) - Method in class org.infinispan.server.core.transport.IpSubnetFilterRule
- matches(Attribute<?>) - Method in class org.infinispan.commons.configuration.attributes.Attribute
-
Compares this attribute to another attribute taking into account the
AttributeDefinition.isGlobal()
flag. - matches(AttributeSet) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
- matches(Configuration) - Method in class org.infinispan.configuration.cache.Configuration
- matches(EncodingConfiguration) - Method in class org.infinispan.configuration.cache.EncodingConfiguration
- matches(KeyPartitioner) - Method in interface org.infinispan.distribution.ch.KeyPartitioner
- matches(T) - Method in class org.infinispan.commons.configuration.attributes.ConfigurationElement
- matches(T) - Method in interface org.infinispan.commons.configuration.attributes.Matchable
- matchesAll() - Method in class org.infinispan.commons.dataconversion.MediaType
- MavenArtifact - Class in org.infinispan.commons.maven
-
Maven artifact coordinate specification.
- MavenArtifact(String, String, String) - Constructor for class org.infinispan.commons.maven.MavenArtifact
-
Construct a new instance with an empty classifier.
- MavenArtifact(String, String, String, String) - Constructor for class org.infinispan.commons.maven.MavenArtifact
-
Construct a new instance.
- MavenSettings - Class in org.infinispan.commons.maven
- max() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- max() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- max() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- max() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- max() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- max() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- max(String) - Static method in interface org.infinispan.query.dsl.Expression
-
Deprecated.
- max(Comparator<? super E>) - Static method in class org.infinispan.reactive.publisher.PublisherReducers
- max(Comparator<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
- max(Comparator<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- max(Comparator<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- max(Comparator<? super T>) - Method in interface org.infinispan.functional.Traversable
-
A terminal operation that returns an optional containing the maximum element of this traversable based on the comparator passed in.
- max(TopologyIracVersion, TopologyIracVersion) - Static method in class org.infinispan.container.versioning.irac.TopologyIracVersion
- max(SerializableComparator<? super R>) - Method in interface org.infinispan.CacheStream
-
Same as
Stream.max(Comparator)
except that the Comparator must also implementSerializable
- MAX_ACTIVE - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- MAX_AGE - Static variable in class org.infinispan.rest.configuration.CorsRuleConfiguration
- MAX_BATCH_SIZE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- MAX_BATCH_SIZE - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- MAX_BOOLEAN_CLAUSES_SYS_PROP - Static variable in class org.infinispan.query.impl.LifecycleManager
-
Optional integer system property that sets value of
BooleanQuery.setMaxClauseCount(int)
. - MAX_BUFFERED_ENTRIES - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- MAX_CLEANUP_DELAY - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- MAX_CLEANUP_DELAY - Static variable in class org.infinispan.configuration.cache.SitesConfiguration
- MAX_CONTENT_LENGTH - Static variable in class org.infinispan.rest.configuration.RestServerConfiguration
- MAX_COUNT - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- MAX_COUNT - Static variable in class org.infinispan.configuration.cache.MemoryConfiguration
- MAX_ENTRIES - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- MAX_ENTRIES - Static variable in class org.infinispan.configuration.cache.IndexMergeConfiguration
- MAX_ENTRIES - Static variable in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 13.0, will be removed in 16.0
- MAX_FILE_SIZE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- MAX_FILE_SIZE - Static variable in class org.infinispan.persistence.sifs.configuration.DataConfiguration
- MAX_FORCED_SIZE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- MAX_FORCED_SIZE - Static variable in class org.infinispan.configuration.cache.IndexMergeConfiguration
- MAX_ID - Static variable in interface org.infinispan.commons.marshall.Ids
- MAX_IDLE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- MAX_IDLE - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- MAX_IDLE - Static variable in class org.infinispan.configuration.cache.ExpirationConfiguration
- MAX_IDLE_TIME_HEADER - Enum constant in enum org.infinispan.rest.ResponseHeader
- MAX_NODE_SIZE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- MAX_NODE_SIZE - Static variable in class org.infinispan.persistence.sifs.configuration.IndexConfiguration
- MAX_PENDING_REQUESTS - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- MAX_RESULTS - Static variable in interface org.infinispan.query.remote.json.JSONConstants
- MAX_RETRIES - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- MAX_RETRIES - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- MAX_RETRIES - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- MAX_SIZE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- MAX_SIZE - Static variable in class org.infinispan.configuration.cache.IndexMergeConfiguration
- MAX_SIZE - Static variable in class org.infinispan.configuration.cache.MemoryConfiguration
- MAX_THREADS - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- MAX_TIME_IDLE_HEADER - Enum constant in enum org.infinispan.rest.RequestHeader
- MAX_TOTAL - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- MAX_UNSIGNED_LONG - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- MAX_WAIT - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- maxActive() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfiguration
- maxActive() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
-
Returns the number of configured maximum connections per server that can be allocated.
- maxActive() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
- maxActive(int) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
-
Controls the maximum number of connections per server that are allocated (checked out to client threads, or idle in the pool) at one time.
- maxActive(int) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
-
Controls the maximum number of connections per server that are allocated (checked out to client threads, or idle in the pool) at one time.
- maxAge(int) - Static method in class org.infinispan.rest.CacheControl
-
Returns
max-age
header value. - maxAge(long) - Method in class org.infinispan.rest.configuration.CorsRuleConfigurationBuilder
- maxBatchSize() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- maxBatchSize() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
- maxBatchSize(int) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
- maxBatchSize(int) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
- maxBatchSize(int) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
-
The maximum size of a batch to be inserted/deleted from the store.
- maxBufferedEntries(int) - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
- maxContentLength() - Method in class org.infinispan.rest.configuration.RestServerConfiguration
- maxContentLength() - Method in class org.infinispan.rest.RestServer
- maxContentLength(int) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- maxCount() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
- maxCount() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
- maxCount(long) - Method in class org.infinispan.configuration.cache.MemoryConfiguration
- maxCount(long) - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
- maxEntries() - Method in class org.infinispan.client.hotrod.configuration.NearCacheConfiguration
- maxEntries() - Method in class org.infinispan.configuration.cache.IndexMergeConfiguration
- maxEntries() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 13.0, will be removed in 16.0.
- maxEntries(int) - Method in class org.infinispan.client.hotrod.configuration.NearCacheConfigurationBuilder
-
Specifies the maximum number of entries that will be held in the near cache.
- maxEntries(int) - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
- maxEntries(int) - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 13.0, will be removed in 16.0
- maxFileSize() - Method in class org.infinispan.persistence.sifs.configuration.DataConfiguration
- maxFileSize() - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfiguration
- maxFileSize(int) - Method in class org.infinispan.persistence.sifs.configuration.DataConfigurationBuilder
- maxFileSize(int) - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
-
Sets the maximum size of single data file with entries, in bytes.
- maxForcedSize() - Method in class org.infinispan.configuration.cache.IndexMergeConfiguration
- maxForcedSize(int) - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
- maxIdle - Variable in class org.infinispan.container.entries.TransientCacheEntry
- maxIdle - Variable in class org.infinispan.container.entries.TransientCacheValue
- maxIdle - Variable in class org.infinispan.container.entries.TransientMortalCacheEntry
- maxIdle - Variable in class org.infinispan.container.entries.TransientMortalCacheValue
- maxIdle - Variable in class org.infinispan.metadata.EmbeddedMetadata.Builder
- maxIdle() - Method in class org.infinispan.configuration.cache.ExpirationConfiguration
-
Maximum idle time a cache entry will be maintained in the cache, in milliseconds.
- maxIdle() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
-
Maximum idle time a cache entry will be maintained in the cache, in milliseconds.
- maxIdle() - Method in class org.infinispan.container.entries.RemoteMetadata
- maxIdle() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
- maxIdle() - Method in class org.infinispan.metadata.EmbeddedMetadata.EmbeddedExpirableMetadata
- maxIdle() - Method in class org.infinispan.metadata.EmbeddedMetadata.EmbeddedMaxIdleExpirableMetadata
- maxIdle() - Method in class org.infinispan.metadata.EmbeddedMetadata
- maxIdle() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
-
Deprecated.
- maxIdle() - Method in class org.infinispan.metadata.impl.L1Metadata
- maxIdle() - Method in interface org.infinispan.metadata.Metadata
-
Returns the the maximum amount of time that the cache entry associated with this metadata object is allowed to be idle for before it is considered as expired, in milliseconds.
- maxIdle() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.
- maxIdle(int) - 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. This method has no effect
- maxIdle(long) - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
-
Maximum idle time a cache entry will be maintained in the cache, in milliseconds.
- maxIdle(long) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata.Builder
- maxIdle(long) - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
- maxIdle(long) - Method in interface org.infinispan.metadata.Metadata.Builder
-
Set max idle time assuming that the time unit is milliseconds.
- maxIdle(long) - Method in class org.infinispan.rest.NettyRestResponse.Builder
- maxIdle(long, TimeUnit) - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
-
Maximum idle time a cache entry will be maintained in the cache, in milliseconds.
- maxIdle(long, TimeUnit) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata.Builder
- maxIdle(long, TimeUnit) - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
- maxIdle(long, TimeUnit) - Method in interface org.infinispan.metadata.Metadata.Builder
-
Set max idle time with a given time unit.
- MaxIdleExternalizer() - Constructor for class org.infinispan.marshall.exts.MetaParamExternalizers.MaxIdleExternalizer
- maxIdleUnit - Variable in class org.infinispan.metadata.EmbeddedMetadata.Builder
- maxInactiveIntervalInSeconds() - Element in annotation type org.infinispan.spring.embedded.session.configuration.EnableInfinispanEmbeddedHttpSession
-
This is the session timeout in seconds.
- maxInactiveIntervalInSeconds() - Element in annotation type org.infinispan.spring.remote.session.configuration.EnableInfinispanRemoteHttpSession
-
This is the session timeout in seconds.
- maxNodeSize() - Method in class org.infinispan.persistence.sifs.configuration.IndexConfiguration
- maxNodeSize() - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfiguration
- maxNodeSize(int) - Method in class org.infinispan.persistence.sifs.configuration.IndexConfigurationBuilder
- maxNodeSize(int) - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
-
Max size of node (continuous block on filesystem used in index implementation), in bytes.
- maxNodeSizeLimitedToShort(int) - Method in interface org.infinispan.persistence.sifs.Log
- maxPendingRequests() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfiguration
- maxPendingRequests() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
- maxPendingRequests(int) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
-
Specifies maximum number of requests sent over single connection at one instant.
- maxPendingRequests(int) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
-
Specifies maximum number of requests sent over single connection at one instant.
- maxResults(int) - Method in interface org.infinispan.query.dsl.PaginationContext
-
Deprecated.
- maxResults(int) - Method in interface org.infinispan.query.dsl.Query
- maxResults(int) - Method in interface org.infinispan.query.impl.IndexedQuery
-
Sets the maximum number of results to return from the query.
- maxResults(int) - Method in class org.infinispan.query.impl.IndexedQueryImpl
- maxRetries() - Method in class org.infinispan.client.hotrod.configuration.Configuration
- maxRetries() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- maxRetries(int) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
- maxRetries(int) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- maxRetries(int) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
-
It sets the maximum number of retries for each request.
- maxRetries(int) - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
-
The maximum number of retries when a push state command fails.
- maxSegment - Variable in class org.infinispan.reactive.publisher.impl.LocalPublisherManagerImpl
- maxSize - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
- maxSize() - Method in class org.infinispan.configuration.cache.IndexMergeConfiguration
- maxSize() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
- maxSize() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
- maxSize(int) - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
- maxSize(String) - Method in class org.infinispan.configuration.cache.MemoryConfiguration
- maxSize(String) - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
- maxSizeBytes() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
- maxThreads - Variable in class org.infinispan.factories.threads.AbstractThreadPoolExecutorFactory
- maxThreads() - Method in class org.infinispan.commons.executors.BlockingThreadPoolExecutorFactory
-
Deprecated.
- maxThreads() - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
- maxThreads() - Method in class org.infinispan.factories.threads.AbstractThreadPoolExecutorFactory
- maxThreads(Integer) - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
- maxTombstoneCleanupDelay() - Method in class org.infinispan.configuration.cache.SitesConfiguration
- maxTombstoneCleanupDelay(long) - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
-
Sets the maximum delay, in milliseconds, between which the tombstone cleanup task runs.
- maxTotal(int) - 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. This method has no effect
- maxWait() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfiguration
- maxWait() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
- maxWait(int) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
-
The amount of time in milliseconds to wait for a connection to become available when the exhausted action is
ExhaustedAction.WAIT
, after which aNoSuchElementException
will be thrown. - maxWait(long) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
-
The amount of time in milliseconds to wait for a connection to become available when the exhausted action is
ExhaustedAction.WAIT
, after which aNoSuchElementException
will be thrown. - MBEAN_SERVER_LOOKUP - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- MBEAN_SERVER_LOOKUP - Static variable in class org.infinispan.client.hotrod.configuration.StatisticsConfiguration
- MBEAN_SERVER_LOOKUP - Static variable in class org.infinispan.configuration.global.GlobalJmxConfiguration
- MBeanMetadata - Class in org.infinispan.factories.impl
-
JMX related component metadata, as expressed by
MBean
,ManagedAttribute
andManagedOperation
annotations. - MBeanMetadata(String, String, String, Collection<MBeanMetadata.AttributeMetadata>, Collection<MBeanMetadata.OperationMetadata>) - Constructor for class org.infinispan.factories.impl.MBeanMetadata
- MBeanMetadata.AttributeMetadata - Class in org.infinispan.factories.impl
- MBeanMetadata.OperationMetadata - Class in org.infinispan.factories.impl
- MBeanMetadata.OperationParameterMetadata - Class in org.infinispan.factories.impl
- mbeanServerLookup() - Method in class org.infinispan.client.hotrod.configuration.StatisticsConfiguration
- mbeanServerLookup() - Method in class org.infinispan.configuration.global.GlobalJmxConfiguration
- mbeanServerLookup() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
-
Deprecated.
- mBeanServerLookup(MBeanServerLookup) - Method in class org.infinispan.client.hotrod.configuration.StatisticsConfigurationBuilder
-
Sets the instance of the
MBeanServerLookup
class to be used to bound JMX MBeans to. - mBeanServerLookup(MBeanServerLookup) - Method in class org.infinispan.configuration.global.GlobalJmxConfigurationBuilder
-
Sets the instance of the
MBeanServerLookup
class to be used to bound JMX MBeans to. - mBeanServerLookup(MBeanServerLookup) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
-
Deprecated.Sets the instance of the
MBeanServerLookup
class to be used to bound JMX MBeans to. - MBeanServerLookup - Interface in org.infinispan.commons.jmx
-
Implementors of this should return an MBeanServer to which MBeans will be registered.
- MBeanServerLookup - Interface in org.infinispan.jmx
-
Deprecated, for removal: This API element is subject to removal in a future version.Use
MBeanServerLookup
instead - MEBIBYTES - Enum constant in enum org.infinispan.commons.util.MemoryUnit
-
Deprecated.
- MechanismConfiguration - Class in org.infinispan.persistence.remote.configuration
- MechanismConfiguration(AttributeSet) - Constructor for class org.infinispan.persistence.remote.configuration.MechanismConfiguration
- MechanismConfigurationBuilder - Class in org.infinispan.persistence.remote.configuration
- mechanisms() - Method in class org.infinispan.rest.configuration.AuthenticationConfiguration
- mechanisms() - Method in class org.infinispan.rest.configuration.AuthenticationConfigurationBuilder
- mechanisms() - Method in class org.infinispan.server.hotrod.configuration.SaslConfiguration
- mechanisms() - Method in class org.infinispan.server.hotrod.configuration.SaslConfigurationBuilder
- MECHANISMS - Enum constant in enum org.infinispan.server.hotrod.configuration.Attribute
- MECHANISMS - Static variable in class org.infinispan.rest.configuration.AuthenticationConfiguration
- MECHANISMS - Static variable in class org.infinispan.server.hotrod.configuration.SaslConfiguration
- mechProperties() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfiguration
- mechProperties(Map<String, String>) - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
- MEDIA_TYPE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- MEDIA_TYPE - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- MEDIA_TYPE - Static variable in class org.infinispan.configuration.cache.ContentTypeConfiguration
- mediaType() - Method in class org.infinispan.client.hotrod.marshall.BytesOnlyMarshaller
- mediaType() - Method in class org.infinispan.commons.marshall.IdentityMarshaller
- mediaType() - Method in class org.infinispan.commons.marshall.ImmutableProtoStreamMarshaller
- mediaType() - Method in class org.infinispan.commons.marshall.JavaSerializationMarshaller
- mediaType() - Method in interface org.infinispan.commons.marshall.Marshaller
- mediaType() - Method in interface org.infinispan.commons.marshall.StreamAwareMarshaller
- mediaType() - Method in class org.infinispan.commons.marshall.StringMarshaller
- mediaType() - Method in class org.infinispan.commons.marshall.UTF8StringMarshaller
- mediaType() - Method in class org.infinispan.configuration.cache.ContentTypeConfiguration
- mediaType() - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
- mediaType() - Method in class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller
- mediaType() - Method in class org.infinispan.marshall.core.GlobalMarshaller
- mediaType() - Method in class org.infinispan.persistence.remote.wrapper.HotRodEntryMarshaller
-
Deprecated.
- mediaType(String) - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
- mediaType(String) - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
- mediaType(MediaType) - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
- MediaType - Class in org.infinispan.commons.dataconversion
-
Represent a content type with optional parameters.
- MediaType(String) - Constructor for class org.infinispan.commons.dataconversion.MediaType
- MediaType(String, String) - Constructor for class org.infinispan.commons.dataconversion.MediaType
- MediaType(String, String, Map<String, String>) - Constructor for class org.infinispan.commons.dataconversion.MediaType
- MediaType(String, Map<String, String>) - Constructor for class org.infinispan.commons.dataconversion.MediaType
- MediaType.MediaTypeExternalizer - Class in org.infinispan.commons.dataconversion
- MediaType$___Marshaller_f2fc301543ca54d0326b5d8ce3b7199226a678253252e7ac46f1fad54bd90568 - Class in org.infinispan.commons.dataconversion
-
WARNING: Generated code! Do not edit!
- MediaType$___Marshaller_f2fc301543ca54d0326b5d8ce3b7199226a678253252e7ac46f1fad54bd90568() - Constructor for class org.infinispan.commons.dataconversion.MediaType$___Marshaller_f2fc301543ca54d0326b5d8ce3b7199226a678253252e7ac46f1fad54bd90568
- MediaTypeExternalizer() - Constructor for class org.infinispan.commons.dataconversion.MediaType.MediaTypeExternalizer
- MediaTypeIds - Class in org.infinispan.commons.dataconversion
- MediaTypeIds() - Constructor for class org.infinispan.commons.dataconversion.MediaTypeIds
- MediaTypeMarshaller - Interface in org.infinispan.client.hotrod.marshall
-
A marshaller that takes the
MediaType
decision to marshall/unmarshall. - MediaTypeResolver - Class in org.infinispan.commons.dataconversion
-
Resolve media types for files
- MEDIUM - Enum constant in enum org.infinispan.client.hotrod.configuration.SaslStrength
- MEDIUM - Enum constant in enum org.infinispan.server.hotrod.configuration.Strength
- MEGABYTES - Enum constant in enum org.infinispan.commons.util.MemoryUnit
-
Deprecated.
- members - Variable in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
-
The membership of the cache topology that uses this CH.
- members - Variable in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
- MEMCACHED_LOWER_BOUND - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- MEMCACHED_METADATA - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- MEMCACHED_METADATA - Static variable in class org.infinispan.server.core.ExternalizerIds
- MemcachedDecoder - Class in org.infinispan.server.memcached
-
A Memcached protocol specific decoder
- MemcachedDecoder(AdvancedCache<byte[], byte[]>, ScheduledExecutorService, NettyTransport, Predicate<? super String>, MediaType) - Constructor for class org.infinispan.server.memcached.MemcachedDecoder
- MemcachedDecoderState - Enum in org.infinispan.server.memcached
-
Protocol decoding state
- MemcachedMetadata$___Marshaller_582bc1c0173638c6bfeeee0149c471f14236f1b1d719f55da181f90c415f8bf1 - Class in org.infinispan.server.memcached
-
WARNING: Generated code! Do not edit!
- MemcachedMetadata$___Marshaller_582bc1c0173638c6bfeeee0149c471f14236f1b1d719f55da181f90c415f8bf1() - Constructor for class org.infinispan.server.memcached.MemcachedMetadata$___Marshaller_582bc1c0173638c6bfeeee0149c471f14236f1b1d719f55da181f90c415f8bf1
- MemcachedOperation - Enum in org.infinispan.server.memcached
-
Memcached operations.
- MemcachedServer - Class in org.infinispan.server.memcached
-
Memcached server defining its decoder/encoder settings.
- MemcachedServer() - Constructor for class org.infinispan.server.memcached.MemcachedServer
- MemcachedServerConfiguration - Class in org.infinispan.server.memcached.configuration
-
MemcachedServerConfiguration.
- MemcachedServerConfigurationBuilder - Class in org.infinispan.server.memcached.configuration
-
MemcachedServerConfigurationBuilder.
- MemcachedServerConfigurationBuilder() - Constructor for class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
- memory() - Method in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
- memory() - Method in class org.infinispan.configuration.cache.Configuration
- memory() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- memory() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- MEMORY - Enum constant in enum org.infinispan.configuration.parsing.Element
- MEMORY - Enum constant in enum org.infinispan.eviction.EvictionType
-
Deprecated.
- MEMORY_AVAILABLE - Static variable in interface org.infinispan.stats.ContainerStats
- MEMORY_MAX - Static variable in interface org.infinispan.stats.ContainerStats
- MEMORY_TOTAL - Static variable in interface org.infinispan.stats.ContainerStats
- MEMORY_USED - Static variable in interface org.infinispan.stats.ContainerStats
- MemoryAddressHash - Class in org.infinispan.container.offheap
- MemoryAddressHash(int, OffHeapMemoryAllocator) - Constructor for class org.infinispan.container.offheap.MemoryAddressHash
- memoryAvailable() - Method in class org.infinispan.rest.distribution.NodeDistributionInfo
- MemoryConfiguration - Class in org.infinispan.configuration.cache
-
Controls the memory storage configuration for the cache.
- MemoryConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Controls the data container for the cache.
- memoryEntries() - Method in class org.infinispan.rest.distribution.CacheDistributionInfo
- MemoryStorageConfiguration - Class in org.infinispan.configuration.cache
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 11.0,
MemoryConfiguration
is used to defined the data container memory eviction and sizing. - MemoryStorageConfiguration(AttributeSet) - Constructor for class org.infinispan.configuration.cache.MemoryStorageConfiguration
-
Deprecated.
- MemoryStorageConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Deprecated, for removal: This API element is subject to removal in a future version.since 11.0, use
MemoryConfigurationBuilder
instead. - MemoryUnit - Enum in org.infinispan.commons.util
-
Deprecated, for removal: This API element is subject to removal in a future version.since 11.0, use
ByteQuantity
instead. - memoryUsed() - Method in class org.infinispan.rest.distribution.CacheDistributionInfo
- memoryUsed() - Method in class org.infinispan.rest.distribution.NodeDistributionInfo
- merge() - Method in class org.infinispan.configuration.cache.IndexWriterConfiguration
- merge() - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
- merge(double[], boolean) - Method in class org.infinispan.extendedstats.container.ConcurrentGlobalContainer
- merge(Object, SiteEntry<Object>, SiteEntry<Object>) - Method in enum org.infinispan.xsite.spi.XSiteMergePolicy
- merge(K, SiteEntry<V>, SiteEntry<V>) - Method in class org.infinispan.xsite.spi.AlwaysRemoveXSiteEntryMergePolicy
- merge(K, SiteEntry<V>, SiteEntry<V>) - Method in class org.infinispan.xsite.spi.DefaultXSiteEntryMergePolicy
- merge(K, SiteEntry<V>, SiteEntry<V>) - Method in class org.infinispan.xsite.spi.PreferNonNullXSiteEntryMergePolicy
- merge(K, SiteEntry<V>, SiteEntry<V>) - Method in class org.infinispan.xsite.spi.PreferNullXSiteEntryMergePolicy
- merge(K, SiteEntry<V>, SiteEntry<V>) - Method in interface org.infinispan.xsite.spi.XSiteEntryMergePolicy
-
Resolves conflicts for asynchronous cross-site replication.
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.CacheImpl
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.DecoratedCache
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.EncoderCache
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in interface org.infinispan.Cache
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.security.impl.SecureCacheImpl
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.commons.api.BasicCache
-
An overloaded form of
ConcurrentMap.merge(Object, Object, BiFunction)
which takes in lifespan parameters. - merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.BasicCache
-
An overloaded form of
ConcurrentMap.merge(Object, Object, BiFunction)
which takes in lifespan parameters. - merge(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
-
An overloaded form of
Cache.merge(Object, Object, BiFunction)
, which takes in an instance ofMetadata
which can be used to provide metadata information for the entry being stored, such as lifespan, version of value...etc. - merge(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
- merge(K, V, SerializableBiFunction<? super V, ? super V, ? extends V>) - Method in interface org.infinispan.Cache
-
Overloaded
Cache.merge(Object, Object, BiFunction)
with InfinispanSerializableBiFunction
. - merge(K, V, SerializableBiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.Cache
-
Overloaded
BasicCache.merge(Object, Object, BiFunction, long, TimeUnit)
with InfinispanSerializableBiFunction
. - merge(K, V, SerializableBiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
-
Overloaded
BasicCache.merge(Object, Object, BiFunction, long, TimeUnit, long, TimeUnit)
with InfinispanSerializableBiFunction
. - merge(K, V, SerializableBiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
- merge(K, V, SerializableBiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
- merge(Attribute<T>) - Method in class org.infinispan.commons.configuration.attributes.Attribute
- merge(CacheEntry<K, V>, List<CacheEntry<K, V>>) - Method in interface org.infinispan.conflict.EntryMergePolicy
-
This method is called by
ConflictManager.resolveConflicts()
for each conflict discovered to determine whichCacheEntry
should be utilised. - merge(CacheEntry, List) - Method in enum org.infinispan.conflict.MergePolicy
- merge(CacheEntry, List) - Method in class org.infinispan.conflict.MergePolicy.UnsupportedMergePolicy
- merge(IracEntryVersion) - Method in class org.infinispan.container.versioning.irac.IracEntryVersion
- merge(TransactionStatistics) - Method in class org.infinispan.extendedstats.CacheStatisticCollector
-
Merges a transaction statistics in this cache statistics.
- merge(Metadata) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata.Builder
- merge(Metadata) - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
- merge(Metadata) - Method in interface org.infinispan.metadata.Metadata.Builder
-
Merges the given metadata information into the given builder.
- merge(PrepareResponse) - Method in class org.infinispan.remoting.responses.PrepareResponse
- merge(AutoStateTransferResponse) - Method in class org.infinispan.xsite.response.AutoStateTransferResponseCollector
- merge(StateTransferStatus, StateTransferStatus) - Static method in enum org.infinispan.xsite.statetransfer.StateTransferStatus
- MERGE - Enum constant in enum org.infinispan.commons.configuration.Combine.Attributes
- MERGE - Enum constant in enum org.infinispan.commons.configuration.Combine.RepeatedAttributes
- MERGE_FUNCTION_MAPPER - Static variable in interface org.infinispan.commons.marshall.Ids
- MERGE_POLICY - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- MERGE_POLICY - Static variable in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
- MERGE_POLICY - Static variable in class org.infinispan.configuration.cache.SitesConfiguration
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.CacheImpl
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.DecoratedCache
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.EncoderCache
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
ConcurrentMap.merge(Object, Object, BiFunction)
. - mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.infinispan.security.impl.SecureCacheImpl
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
BasicCache.merge(Object, Object, BiFunction, long, TimeUnit)
. - mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
BasicCache.merge(Object, Object, BiFunction, long, TimeUnit, long, TimeUnit)
. - mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
-
Overloaded
AsyncCache.mergeAsync(Object, Object, BiFunction)
, which takes in an instance ofMetadata
which can be used to provide metadata information for the entry being stored, such as lifespan, version of value...etc. - mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- mergeAsync(K, V, BiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
- mergeAsync(K, V, SerializableBiFunction<? super V, ? super V, ? extends V>) - Method in interface org.infinispan.Cache
-
Overloaded
AsyncCache.mergeAsync(Object, Object, BiFunction)
with InfinispanSerializableBiFunction
. - mergeAsync(K, V, SerializableBiFunction<? super V, ? super V, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.Cache
-
Overloaded
AsyncCache.mergeAsync(Object, Object, BiFunction, long, TimeUnit)
with InfinispanSerializableBiFunction
. - mergeAsync(K, V, SerializableBiFunction<? super V, ? super V, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
-
Overloaded
AsyncCache.mergeAsync(Object, Object, BiFunction, long, TimeUnit, long, TimeUnit)
with InfinispanSerializableBiFunction
. - mergeAsync(K, V, SerializableBiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
- mergeAsync(K, V, SerializableBiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
- mergeBitSets(long, long) - Static method in class org.infinispan.commons.util.EnumUtil
- Merged - Annotation Type in org.infinispan.notifications.cachemanagerlistener.annotation
-
This annotation should be used on methods that need to be notified when the cache is used in a cluster and the cluster topology experiences a merge event after a cluster split.
- MERGED - Enum constant in enum org.infinispan.notifications.cachemanagerlistener.event.Event.Type
- mergeEntryVersions(Map<Object, IncrementableEntryVersion>) - Method in class org.infinispan.remoting.responses.PrepareResponse
- mergeEntryVersions(Map<Object, IncrementableEntryVersion>, Map<Object, IncrementableEntryVersion>) - Static method in class org.infinispan.transaction.impl.WriteSkewHelper
- MergeEvent - Interface in org.infinispan.notifications.cachemanagerlistener.event
-
This event is passed in to any method annotated with
Merged
. - mergeHashMap(ValidResponse, Map<Object, Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
- mergeInPrepareResponse(Map<Object, IncrementableEntryVersion>, PrepareResponse) - Static method in class org.infinispan.transaction.impl.WriteSkewHelper
- mergeInternal(K, V, BiFunction<? super V, ? super V, ? extends V>, SimpleCacheImpl.CacheEntryChange<K, V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- mergeInternal(K, V, BiFunction<? super V, ? super V, ? extends V>, SimpleCacheImpl.CacheEntryChange<K, V>, Metadata) - Method in class org.infinispan.cache.impl.StatsCollectingCache
- mergeList(ValidResponse, List<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
- mergeLists(List<Address>, List<Address>) - Static method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
-
Adds all elements from
src
list that do not already exist indest
list to the latter. - mergeLists(List<T>, List<T>) - Static method in class org.infinispan.commons.util.InfinispanCollections
- mergeMaps(Map<K, V>, Map<K, V>) - Static method in class org.infinispan.commons.util.InfinispanCollections
- mergePolicy() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
- mergePolicy() - Method in class org.infinispan.configuration.cache.SitesConfiguration
- mergePolicy(EntryMergePolicy) - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
- mergePolicy(XSiteEntryMergePolicy<?, ?>) - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
-
Configures the
XSiteEntryMergePolicy
to be used. - MergePolicy - Enum in org.infinispan.conflict
- MergePolicy.UnsupportedMergePolicy - Class in org.infinispan.conflict
- mergePrepareResponses(Response, PrepareResponse) - Static method in class org.infinispan.transaction.impl.WriteSkewHelper
- mergeSegments() - Method in interface org.infinispan.search.mapper.scope.SearchWorkspace
-
Merge all segments of the indexes targeted by this workspace into a single one.
- mergeTo(ConcurrentGlobalContainer) - Method in interface org.infinispan.extendedstats.container.ExtendedStatisticsContainer
-
it merges in
this
the statistic's values inother
. - mergeTo(ConcurrentGlobalContainer) - Method in class org.infinispan.extendedstats.container.LocalExtendedStatisticsContainer
- mergeTo(ConcurrentGlobalContainer) - Method in class org.infinispan.extendedstats.container.RemoteExtendedStatisticsContainer
- MESSAGE - Static variable in interface org.infinispan.query.remote.json.JSONConstants
- MESSAGE_NAME - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
- MESSAGE_NAME - Static variable in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfiguration
- messageName() - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfiguration
- messageName(String) - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfigurationBuilder
-
The protobuf message name to use to marshall the cache entry to the database.
- messageNameRequiredIfEmbeddedKey() - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- Messages - Interface in org.infinispan.rest.logging
-
Informational Scripting messages.
- Messages - Interface in org.infinispan.scripting.logging
-
Informational Scripting messages.
- Messages_$bundle - Class in org.infinispan.rest.logging
-
Warning this class consists of generated code.
- Messages_$bundle - Class in org.infinispan.scripting.logging
-
Warning this class consists of generated code.
- Messages_$bundle() - Constructor for class org.infinispan.rest.logging.Messages_$bundle
- Messages_$bundle() - Constructor for class org.infinispan.scripting.logging.Messages_$bundle
- META_ENTRY_VERSION - Static variable in interface org.infinispan.commons.marshall.Ids
- META_LIFESPAN - Static variable in interface org.infinispan.commons.marshall.Ids
- META_MAX_IDLE - Static variable in interface org.infinispan.commons.marshall.Ids
- META_PARAMS_INTERNAL_METADATA - Static variable in interface org.infinispan.commons.marshall.Ids
- META_PARAMS_INTERNAL_METADATA - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- MetaBoolean(boolean) - Constructor for class org.infinispan.functional.MetaParam.MetaBoolean
- MetaCreated(long) - Constructor for class org.infinispan.functional.MetaParam.MetaCreated
- metadata - Variable in class org.infinispan.container.entries.metadata.MetadataImmortalCacheEntry
- metadata - Variable in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
- metadata - Variable in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
- metadata - Variable in class org.infinispan.container.entries.ReadCommittedEntry
- metadata - Variable in class org.infinispan.io.GridFilesystem
-
Deprecated.
- metadata() - Method in class org.infinispan.metadata.impl.L1Metadata
- metadata() - Method in class org.infinispan.xsite.statetransfer.XSiteState
- Metadata - Interface in org.infinispan.client.hotrod
-
Represents metadata about an entry, such as creation and access times and expiration information.
- Metadata - Interface in org.infinispan.metadata
-
This interface encapsulates metadata information that can be stored alongside values in the cache.
- Metadata() - Constructor for class org.infinispan.io.GridFile.Metadata
-
Deprecated.
- Metadata(int, long, int, byte) - Constructor for class org.infinispan.io.GridFile.Metadata
-
Deprecated.
- METADATA_IMMORTAL_ENTRY - Static variable in interface org.infinispan.commons.marshall.Ids
- METADATA_IMMORTAL_VALUE - Static variable in interface org.infinispan.commons.marshall.Ids
- METADATA_MORTAL_ENTRY - Static variable in interface org.infinispan.commons.marshall.Ids
- METADATA_MORTAL_VALUE - Static variable in interface org.infinispan.commons.marshall.Ids
- METADATA_REMOTE - Static variable in interface org.infinispan.commons.marshall.Ids
- METADATA_TRANSIENT_ENTRY - Static variable in interface org.infinispan.commons.marshall.Ids
- METADATA_TRANSIENT_MORTAL_ENTRY - Static variable in interface org.infinispan.commons.marshall.Ids
- METADATA_TRANSIENT_MORTAL_VALUE - Static variable in interface org.infinispan.commons.marshall.Ids
- METADATA_TRANSIENT_VALUE - Static variable in interface org.infinispan.commons.marshall.Ids
- Metadata.Builder - Interface in org.infinispan.metadata
-
Metadata builder
- MetadataAware - Interface in org.infinispan.container.entries.metadata
-
Marker interface for metadata aware cache entry.
- MetadataAwareCommand - Interface in org.infinispan.commands
-
A command that contains metadata information.
- MetadataCollection<V> - Interface in org.infinispan.client.hotrod.multimap
-
Metadata and collection, used for Multimap
- MetadataImmortalCacheEntry - Class in org.infinispan.container.entries.metadata
-
A form of
ImmortalCacheEntry
that isMetadataAware
- MetadataImmortalCacheEntry(Object, Object, PrivateMetadata, Metadata) - Constructor for class org.infinispan.container.entries.metadata.MetadataImmortalCacheEntry
- MetadataImmortalCacheEntry(Object, Object, Metadata) - Constructor for class org.infinispan.container.entries.metadata.MetadataImmortalCacheEntry
- MetadataImmortalCacheEntry.Externalizer - Class in org.infinispan.container.entries.metadata
- MetadataImmortalCacheValue - Class in org.infinispan.container.entries.metadata
-
A form of
ImmortalCacheValue
that isMetadataAware
. - MetadataImmortalCacheValue(Object, PrivateMetadata, Metadata) - Constructor for class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue
- MetadataImmortalCacheValue(Object, Metadata) - Constructor for class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue
- MetadataImmortalCacheValue.Externalizer - Class in org.infinispan.container.entries.metadata
- MetadataImpl$___Marshaller_b44737a8b6b24b0cd6de162703366becf9e68a2ce287544774acbaaa7268814 - Class in org.infinispan.persistence.rocksdb
-
WARNING: Generated code! Do not edit!
- MetadataImpl$___Marshaller_b44737a8b6b24b0cd6de162703366becf9e68a2ce287544774acbaaa7268814() - Constructor for class org.infinispan.persistence.rocksdb.MetadataImpl$___Marshaller_b44737a8b6b24b0cd6de162703366becf9e68a2ce287544774acbaaa7268814
- metadataIsMissing(ByteString) - Method in interface org.infinispan.counter.logging.Log
- metadataLength() - Method in class org.infinispan.persistence.sifs.EntryHeader
- MetadataMortalCacheEntry - Class in org.infinispan.container.entries.metadata
-
A cache entry that is mortal and is
MetadataAware
- MetadataMortalCacheEntry(Object, Object, PrivateMetadata, Metadata, long) - Constructor for class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
- MetadataMortalCacheEntry(Object, Object, Metadata, long) - Constructor for class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
- MetadataMortalCacheEntry.Externalizer - Class in org.infinispan.container.entries.metadata
- MetadataMortalCacheValue - Class in org.infinispan.container.entries.metadata
-
A mortal cache value, to correspond with
MetadataMortalCacheEntry
- MetadataMortalCacheValue(Object, PrivateMetadata, Metadata, long) - Constructor for class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
- MetadataMortalCacheValue(Object, Metadata, long) - Constructor for class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
- MetadataMortalCacheValue.Externalizer - Class in org.infinispan.container.entries.metadata
- Metadatas - Class in org.infinispan.metadata
-
Utility method for Metadata classes.
- MetadataTransientCacheEntry - Class in org.infinispan.container.entries.metadata
-
A cache entry that is transient, i.e., it can be considered expired after a period of not being used, and
MetadataAware
- MetadataTransientCacheEntry(Object, Object, PrivateMetadata, Metadata, long) - Constructor for class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
- MetadataTransientCacheEntry(Object, Object, Metadata, long) - Constructor for class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
- MetadataTransientCacheEntry.Externalizer - Class in org.infinispan.container.entries.metadata
- MetadataTransientCacheValue - Class in org.infinispan.container.entries.metadata
-
A transient cache value, to correspond with
TransientCacheEntry
which isMetadataAware
- MetadataTransientCacheValue(Object, PrivateMetadata, Metadata, long) - Constructor for class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
- MetadataTransientCacheValue(Object, Metadata, long) - Constructor for class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
- MetadataTransientCacheValue.Externalizer - Class in org.infinispan.container.entries.metadata
- MetadataTransientMortalCacheEntry - Class in org.infinispan.container.entries.metadata
-
A form of
TransientMortalCacheEntry
that storesMetadata
- MetadataTransientMortalCacheEntry(Object, Object, PrivateMetadata, Metadata, long, long) - Constructor for class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
- MetadataTransientMortalCacheEntry(Object, Object, Metadata, long) - Constructor for class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
- MetadataTransientMortalCacheEntry(Object, Object, Metadata, long, long) - Constructor for class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
- MetadataTransientMortalCacheEntry.Externalizer - Class in org.infinispan.container.entries.metadata
- MetadataTransientMortalCacheValue - Class in org.infinispan.container.entries.metadata
-
A form of
TransientMortalCacheValue
that storesMetadata
- MetadataTransientMortalCacheValue(Object, PrivateMetadata, Metadata, long, long) - Constructor for class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue
- MetadataTransientMortalCacheValue(Object, Metadata, long, long) - Constructor for class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue
- MetadataTransientMortalCacheValue.Externalizer - Class in org.infinispan.container.entries.metadata
- MetadataUtils - Class in org.infinispan.server.hotrod
-
Utility class in hotrod server with methods handling cache entries metadata
- MetadataValue<V> - Interface in org.infinispan.client.hotrod
-
Besides the value, also contains a version and expiration information.
- MetadataValueImpl<V> - Class in org.infinispan.client.hotrod.impl
-
MetadataValueImpl.
- MetadataValueImpl(long, int, long, int, long, V) - Constructor for class org.infinispan.client.hotrod.impl.MetadataValueImpl
- MetaEntryVersion(EntryVersion) - Constructor for class org.infinispan.functional.MetaParam.MetaEntryVersion
- MetaLastUsed(long) - Constructor for class org.infinispan.functional.MetaParam.MetaLastUsed
- MetaLifespan(long) - Constructor for class org.infinispan.functional.MetaParam.MetaLifespan
- MetaLong(long) - Constructor for class org.infinispan.functional.MetaParam.MetaLong
- MetaMaxIdle(long) - Constructor for class org.infinispan.functional.MetaParam.MetaMaxIdle
- metamodel() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
- metamodel() - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
- MetaParam<T> - Interface in org.infinispan.functional
-
An easily extensible metadata parameter that's stored along with the value in the the functional map.
- MetaParam.Lookup - Interface in org.infinispan.functional
-
Provides metadata parameter lookup capabilities using
Class
as lookup key. - MetaParam.MetaBoolean - Class in org.infinispan.functional
- MetaParam.MetaCreated - Class in org.infinispan.functional
-
Read only metadata parameter representing a cached entry's created time in milliseconds.
- MetaParam.MetaEntryVersion - Class in org.infinispan.functional
-
Writable metadata parameter representing a cached entry's generic version.
- MetaParam.MetaLastUsed - Class in org.infinispan.functional
-
Read only metadata parameter representing a cached entry's last used time in milliseconds.
- MetaParam.MetaLifespan - Class in org.infinispan.functional
-
Writable metadata parameter representing a cached entry's millisecond lifespan.
- MetaParam.MetaLoadedFromPersistence - Class in org.infinispan.functional
-
Non-writable parameter telling if the entry was loaded from a persistence tier (
CacheLoader
) or not. - MetaParam.MetaLong - Class in org.infinispan.functional
-
Abstract class for numeric long-based metadata parameter instances.
- MetaParam.MetaMaxIdle - Class in org.infinispan.functional
-
Writable metadata parameter representing a cached entry's millisecond max idle time.
- MetaParam.MetaUpdateCreationTime - Class in org.infinispan.functional
-
A parameter to tell if the creation timestamp should be updated for modified entries.
- MetaParam.Writable<T> - Interface in org.infinispan.functional
-
Writable
MetaParam
instances are those that the user can provide to be stored as part of the cache entry. - MetaParamExternalizers - Class in org.infinispan.marshall.exts
- MetaParamExternalizers.EntryVersionParamExternalizer - Class in org.infinispan.marshall.exts
- MetaParamExternalizers.LifespanExternalizer - Class in org.infinispan.marshall.exts
- MetaParamExternalizers.MaxIdleExternalizer - Class in org.infinispan.marshall.exts
- MetaParams - Class in org.infinispan.functional.impl
-
Represents a
MetaParam
collection. - MetaParamsInternalMetadata - Class in org.infinispan.functional.impl
-
Metadata parameters backed internal metadata representation.
- MetaParamsInternalMetadata.Builder - Class in org.infinispan.functional.impl
- MetaParamsInternalMetadata$___Marshaller_d639102389197d7d9d67594c1f4f7cd51d35bdb2ed77d89d90c58b8d63ad3ab0 - Class in org.infinispan.functional.impl
-
WARNING: Generated code! Do not edit!
- MetaParamsInternalMetadata$___Marshaller_d639102389197d7d9d67594c1f4f7cd51d35bdb2ed77d89d90c58b8d63ad3ab0() - Constructor for class org.infinispan.functional.impl.MetaParamsInternalMetadata$___Marshaller_d639102389197d7d9d67594c1f4f7cd51d35bdb2ed77d89d90c58b8d63ad3ab0
- MetaUpdateCreationTime(boolean) - Constructor for class org.infinispan.functional.MetaParam.MetaUpdateCreationTime
- meterRegistry() - Method in class org.infinispan.metrics.config.MicrometerMeterRegistryConfiguration
- meterRegistry(MeterRegistry) - Method in class org.infinispan.metrics.config.MicrometerMeterRegisterConfigurationBuilder
-
Set the
MeterRegistry
instance to use by Infinispan. - method - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
- method() - Method in interface org.infinispan.rest.framework.RestRequest
- method() - Method in class org.infinispan.rest.NettyRestRequest
- method(Method) - Method in class org.infinispan.rest.framework.impl.InvocationImpl.Builder
- Method - Enum in org.infinispan.rest.framework
- methods() - Method in class org.infinispan.rest.framework.impl.InvocationImpl
- methods() - Method in interface org.infinispan.rest.framework.Invocation
-
Returns one or more methods supported.
- methods(Method...) - Method in class org.infinispan.rest.framework.impl.InvocationImpl.Builder
- MetricInfo - Interface in org.infinispan.commons.stat
-
Class that represent the information about a metrics.
- metrics() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
- metrics() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
- metrics() - Method in class org.infinispan.configuration.global.GlobalConfiguration
- metrics() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- metrics() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Global metrics configuration.
- METRICS - Enum constant in enum org.infinispan.configuration.parsing.Element
- METRICS_AUTH - Static variable in class org.infinispan.rest.configuration.AuthenticationConfiguration
- metricsAuth() - Method in class org.infinispan.rest.configuration.AuthenticationConfiguration
- metricsAuth(boolean) - Method in class org.infinispan.rest.configuration.AuthenticationConfigurationBuilder
- metricsManager - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- MetricsResource - Class in org.infinispan.rest.resources
-
Micrometer metrics resource.
- MetricsResource(boolean, InvocationHelper) - Constructor for class org.infinispan.rest.resources.MetricsResource
- MicrometerMeterRegisterConfigurationBuilder - Class in org.infinispan.metrics.config
-
Builder to inject an instance of
MeterRegistry
. - MicrometerMeterRegisterConfigurationBuilder(GlobalConfigurationBuilder) - Constructor for class org.infinispan.metrics.config.MicrometerMeterRegisterConfigurationBuilder
- MicrometerMeterRegistryConfiguration - Class in org.infinispan.metrics.config
-
A configuration class to inject a custom
MeterRegistry
instance. - MicrometerMeterRegistryConfiguration(MeterRegistry) - Constructor for class org.infinispan.metrics.config.MicrometerMeterRegistryConfiguration
- MicrometerMeterRegistryConfigurationSerializer - Class in org.infinispan.metrics.config
-
A
ConfigurationSerializer
implementation to serializeMicrometerMeterRegistryConfiguration
. - MicrometerMeterRegistryConfigurationSerializer() - Constructor for class org.infinispan.metrics.config.MicrometerMeterRegistryConfigurationSerializer
- MICROSECONDS - Enum constant in enum org.infinispan.server.hotrod.TimeUnitValue
- MIGRATION_TASK - Static variable in interface org.infinispan.persistence.remote.ExternalizerIds
- MigrationTask - Class in org.infinispan.persistence.remote.upgrade
- MigrationTask(String, Set<Integer>, int, int) - Constructor for class org.infinispan.persistence.remote.upgrade.MigrationTask
- MigrationTask.EntryWriter<K,
V> - Class in org.infinispan.persistence.remote.upgrade - MigrationTask.EntryWriterExternalizer - Class in org.infinispan.persistence.remote.upgrade
- MigrationTask.Externalizer - Class in org.infinispan.persistence.remote.upgrade
- MILLISECONDS - Enum constant in enum org.infinispan.server.hotrod.TimeUnitValue
- MIME_CACHE_ENTRY - Static variable in interface org.infinispan.commons.marshall.Ids
- MIME_METADATA - Static variable in class org.infinispan.server.core.ExternalizerIds
- min() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- min() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- min() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- min() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- min() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- min() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- min(String) - Static method in interface org.infinispan.query.dsl.Expression
-
Deprecated.
- min(Comparator<? super E>) - Static method in class org.infinispan.reactive.publisher.PublisherReducers
- min(Comparator<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
- min(Comparator<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- min(Comparator<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- min(Comparator<? super T>) - Method in interface org.infinispan.functional.Traversable
-
A terminal operation that returns an optional containing the minimum element of this traversable based on the comparator passed in.
- min(AvailabilityMode) - Method in enum org.infinispan.partitionhandling.AvailabilityMode
- min(SerializableComparator<? super R>) - Method in interface org.infinispan.CacheStream
-
Same as
Stream.min(Comparator)
except that the Comparator must also implementSerializable
- MIN_EVICTABLE_IDLE_TIME - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- MIN_IDLE - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- MIN_NODE_SIZE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- MIN_NODE_SIZE - Static variable in class org.infinispan.persistence.sifs.configuration.IndexConfiguration
- MIN_SIZE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- MIN_SIZE - Static variable in class org.infinispan.configuration.cache.IndexMergeConfiguration
- MIN_TIME_TO_WAIT - Static variable in class org.infinispan.configuration.cache.TakeOfflineConfiguration
- MIN_UNSIGNED - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- MIN_WAIT_FIELD - Static variable in class org.infinispan.rest.resources.XSiteResource
- minEvictableIdleTime() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfiguration
- minEvictableIdleTime() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
- minEvictableIdleTime(long) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
-
Specifies the minimum amount of time that an connection may sit idle in the pool before it is eligible for eviction due to idle time.
- minEvictableIdleTime(long) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
-
Specifies the minimum amount of time that an connection may sit idle in the pool before it is eligible for eviction due to idle time.
- minIdle() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfiguration
- minIdle() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
- minIdle(int) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
-
Sets a target value for the minimum number of idle connections (per server) that should always be available.
- minIdle(int) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
-
Sets a target value for the minimum number of idle connections (per server) that should always be available.
- minNodeSize() - Method in class org.infinispan.persistence.sifs.configuration.IndexConfiguration
- minNodeSize() - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfiguration
- minNodeSize(int) - Method in class org.infinispan.persistence.sifs.configuration.IndexConfigurationBuilder
- minNodeSize(int) - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
-
If the size of the node (continuous block on filesystem used in index implementation) drops below this threshold, the node will try to balance its size with some neighbour node, possibly causing join of multiple nodes.
- minNodeSizeMustBeLessOrEqualToMax(int, int) - Method in interface org.infinispan.persistence.sifs.Log
- minSize() - Method in class org.infinispan.configuration.cache.IndexMergeConfiguration
- minSize() - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
- minSize(int) - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
- minTimeToWait() - Method in class org.infinispan.configuration.cache.TakeOfflineConfiguration
- minTimeToWait(long) - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
-
The minimal number of milliseconds to wait before taking this site offline.
- MINUTES - Enum constant in enum org.infinispan.server.hotrod.TimeUnitValue
- MISS - Static variable in class org.infinispan.functional.impl.StatsEnvelope
- MISSES - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
-
Number of get misses.
- missing() - Method in class org.infinispan.util.concurrent.CountDownRunnable
- missingArgument(String) - Method in interface org.infinispan.rest.logging.Log
- missingArguments(String...) - Method in interface org.infinispan.rest.logging.Log
- missingCacheConfiguration(String, String) - Method in interface org.infinispan.server.core.logging.Log
- missingCacheEventFactory(String, String) - Method in interface org.infinispan.server.hotrod.logging.Log
- missingClientListenerAnnotation(String) - Method in interface org.infinispan.client.hotrod.logging.Log
- missingClusterNameDefinition() - Method in interface org.infinispan.client.hotrod.logging.Log
- missingClusterServersDefinition(String) - Method in interface org.infinispan.client.hotrod.logging.Log
- missingConnectionFactory() - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- missingContent() - Method in interface org.infinispan.rest.logging.Log
- missingCounterName() - Method in interface org.infinispan.counter.logging.Log
- MissingFactoryException - Exception in org.infinispan.server.hotrod
-
Exception thrown when a named factory is chosen that doesn't exist
- MissingFactoryException(String) - Constructor for exception org.infinispan.server.hotrod.MissingFactoryException
- missingHostAddress() - Method in interface org.infinispan.server.hotrod.logging.Log
- missingHostDefinition() - Method in interface org.infinispan.client.hotrod.logging.Log
- missingKeyStorePassword(String) - Method in interface org.infinispan.client.hotrod.logging.Log
- missingKeyStorePassword(String) - Method in interface org.infinispan.server.core.logging.Log
- missingKeyValueFilterConverterFactory(String) - Method in interface org.infinispan.server.hotrod.logging.Log
- MissingMembersException - Exception in org.infinispan.topology
-
Thrown when members are missing after a cluster shutdown.
- MissingMembersException(String) - Constructor for exception org.infinispan.topology.MissingMembersException
- missingMigrationData(String) - Method in interface org.infinispan.persistence.remote.logging.Log
- missingName() - Method in interface org.infinispan.lock.logging.Log
- missingRequired(ConfigurationReader, Set<?>) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Get an exception reporting a missing, required XML attribute.
- missingRequiredAdminTaskParameter(String, String) - Method in interface org.infinispan.server.core.logging.Log
- missingRequiredElement(ConfigurationReader, Set<?>) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Get an exception reporting a missing, required XML child element.
- missingRequiredMediaType(String) - Method in interface org.infinispan.rest.logging.Log
- missingServerName() - Method in interface org.infinispan.server.hotrod.logging.Log
- missingSniHostName() - Method in interface org.infinispan.client.hotrod.logging.Log
- missingTrustStorePassword(String) - Method in interface org.infinispan.client.hotrod.logging.Log
- missingTrustStorePassword(String) - Method in interface org.infinispan.server.core.logging.Log
- MIXED_ELEMENTS - Enum constant in enum org.infinispan.commons.configuration.io.ConfigurationFormatFeature
-
The underlying format supports elements which can have both attributes and an array of child elements.
- MIXED_KEYED_JDBC_STORE - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
- mixedOn(String) - Method in class org.infinispan.xsite.status.ContainerSiteStatusBuilder
-
Adds the cache with an mixed connection to the site.
- mkCachefailoverEvent() - Static method in class org.infinispan.client.hotrod.event.ClientEvents
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.1.2. Will be removed in 11 without replacement.
- mkdir() - Method in class org.infinispan.io.GridFile
-
Deprecated.
- mkdirs() - Method in class org.infinispan.io.GridFile
-
Deprecated.
- mkdirs(Path) - Method in class org.infinispan.server.core.backup.resources.CounterResource
- mod(int, int) - Static method in class org.infinispan.io.ModularArithmetic
-
Deprecated.
- mod(long, int) - Static method in class org.infinispan.io.ModularArithmetic
-
Deprecated.
- modCount - Variable in class org.infinispan.commons.util.ArrayMap
- modCount - Variable in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
- mode() - Method in class org.infinispan.client.hotrod.configuration.NearCacheConfiguration
- mode() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- mode(NearCacheMode) - Method in class org.infinispan.client.hotrod.configuration.NearCacheConfigurationBuilder
-
Specifies the near caching mode.
- mode(XSiteStateTransferMode) - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
-
The cross-site state transfer mode.
- MODE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- MODE - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- Modification - Interface in org.infinispan.persistence.modifications
-
An interface that defines a
CacheWriter
modification - MODIFICATION_QUEUE_SIZE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- MODIFICATION_QUEUE_SIZE - Static variable in class org.infinispan.configuration.cache.AsyncStoreConfiguration
- Modification.Type - Enum in org.infinispan.persistence.modifications
- ModificationList - Class in org.infinispan.transaction.impl
-
A list of
WriteCommand
for a transaction - ModificationList() - Constructor for class org.infinispan.transaction.impl.ModificationList
- ModificationList(int) - Constructor for class org.infinispan.transaction.impl.ModificationList
- modificationQueueSize() - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
-
Sets the size of the modification queue for the async store.
- modificationQueueSize(int) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
-
Sets the size of the modification queue for the async store.
- modifications - Variable in class org.infinispan.transaction.impl.AbstractCacheTransaction
- ModificationsList - Class in org.infinispan.persistence.modifications
-
ModificationsList contains a List
- ModificationsList(List<? extends Modification>) - Constructor for class org.infinispan.persistence.modifications.ModificationsList
- MODIFIED_KEY - Enum constant in enum org.infinispan.client.hotrod.impl.VersionedOperationResponse.RspCode
- ModifiedEventImpl<K> - Class in org.infinispan.client.hotrod.event.impl
- ModifiedEventImpl(byte[], K, long, boolean) - Constructor for class org.infinispan.client.hotrod.event.impl.ModifiedEventImpl
- ModifiedValueFunction<I,
O> - Interface in org.infinispan.reactive.publisher.impl -
This is a special interface that can mark a Function so that a user can know if the actual value will change when the function is applied or not.
- ModularArithmetic - Class in org.infinispan.io
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.0
- ModularArithmetic() - Constructor for class org.infinispan.io.ModularArithmetic
-
Deprecated.
- module(Class<T>) - Method in class org.infinispan.configuration.cache.Configuration
- module(Class<T>) - Method in class org.infinispan.configuration.global.GlobalConfiguration
- module(Class<T>) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- Module - Class in org.infinispan.extendedstats
-
InfinispanModule
annotation is required for component annotation processing - Module() - Constructor for class org.infinispan.extendedstats.Module
- MODULE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- MODULE_COMMAND_FACTORIES - Static variable in class org.infinispan.factories.KnownComponentNames
- moduleCacheRpcCommands() - Method in class org.infinispan.util.ModuleProperties
-
Deprecated.
- moduleCommandFactories() - Method in class org.infinispan.util.ModuleProperties
-
Deprecated.
- ModuleCommandIds - Interface in org.infinispan.query.impl
-
The Query module is using custom RPC commands; to make sure the used command ids are unique all numbers are defined here, and should stay in the range 100-119 which is the reserved range for this module.
- moduleCommands() - Method in class org.infinispan.util.ModuleProperties
-
Deprecated.
- ModuleInitializer() - Constructor for class org.infinispan.factories.GlobalComponentRegistry.ModuleInitializer
- ModuleLifecycle - Interface in org.infinispan.lifecycle
-
ModuleLifecycle is an API hook for delegating lifecycle events to Infinispan sub-modules.
- ModuleMetadataBuilder - Interface in org.infinispan.factories.impl
-
Module metadata.
- ModuleMetadataBuilder.ModuleBuilder - Interface in org.infinispan.factories.impl
- moduleOnlyReplicableCommands() - Method in class org.infinispan.util.ModuleProperties
-
Deprecated.
- ModuleProperties - Class in org.infinispan.util
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 10.0, without replacement. To be removed very soon.
- ModuleProperties() - Constructor for class org.infinispan.util.ModuleProperties
-
Deprecated.
- modules() - Method in class org.infinispan.configuration.cache.Configuration
- modules() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- modules() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
- modules() - Method in class org.infinispan.configuration.global.GlobalConfiguration
- modules() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- modules() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Global modules configuration
- MODULES - Enum constant in enum org.infinispan.configuration.parsing.Element
- MONITOR - Enum constant in enum org.infinispan.security.AuthorizationPermission
-
Allows retrieval of stats
- more() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- MORTAL_ENTRY - Static variable in interface org.infinispan.commons.marshall.Ids
- MORTAL_VALUE - Static variable in interface org.infinispan.commons.marshall.Ids
- MortalCacheEntry - Class in org.infinispan.container.entries
-
A cache entry that is mortal.
- MortalCacheEntry(Object, Object, long, long) - Constructor for class org.infinispan.container.entries.MortalCacheEntry
- MortalCacheEntry(Object, Object, PrivateMetadata, long, long) - Constructor for class org.infinispan.container.entries.MortalCacheEntry
- MortalCacheEntry.Externalizer - Class in org.infinispan.container.entries
- MortalCacheValue - Class in org.infinispan.container.entries
-
A mortal cache value, to correspond with
MortalCacheEntry
- MortalCacheValue(Object, long, long) - Constructor for class org.infinispan.container.entries.MortalCacheValue
- MortalCacheValue(Object, PrivateMetadata, long, long) - Constructor for class org.infinispan.container.entries.MortalCacheValue
- MortalCacheValue.Externalizer - Class in org.infinispan.container.entries
- MOST_CONTENDED_KEYS - Enum constant in enum org.infinispan.extendedstats.topK.StreamSummaryContainer.Stat
- MOST_FAILED_KEYS - Enum constant in enum org.infinispan.extendedstats.topK.StreamSummaryContainer.Stat
- MOST_LOCKED_KEYS - Enum constant in enum org.infinispan.extendedstats.topK.StreamSummaryContainer.Stat
- MOST_WRITE_SKEW_FAILED_KEYS - Enum constant in enum org.infinispan.extendedstats.topK.StreamSummaryContainer.Stat
- mostRecentExpirationTime(long, long) - Static method in class org.infinispan.container.entries.ExpiryHelper
-
Returns the most recent (i.e.
- MSG - Static variable in interface org.infinispan.rest.logging.Messages
- MSG - Static variable in interface org.infinispan.scripting.logging.Messages
- MULTI_HOMED_SERVER_ADDRESS - Static variable in class org.infinispan.server.core.ExternalizerIds
- MultiClusterEventCommand<K,
V> - Class in org.infinispan.notifications.cachelistener.cluster -
This command is used to send cluster events for multiple listeners on the same node
- MultiClusterEventCommand() - Constructor for class org.infinispan.notifications.cachelistener.cluster.MultiClusterEventCommand
- MultiClusterEventCommand(ByteString) - Constructor for class org.infinispan.notifications.cachelistener.cluster.MultiClusterEventCommand
- MultiClusterEventCommand(ByteString, Map<UUID, Collection<ClusterEvent<K, V>>>) - Constructor for class org.infinispan.notifications.cachelistener.cluster.MultiClusterEventCommand
- MultiHomedServerAddress - Class in org.infinispan.server.hotrod
-
A Hot Rod server address which encapsulates a multi-homed server.
- MultiHomedServerAddress(int, boolean) - Constructor for class org.infinispan.server.hotrod.MultiHomedServerAddress
- MultiHomedServerAddress.InetAddressWithNetMask - Class in org.infinispan.server.hotrod
- multiKeyBackupAck(long, Address, int, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
-
Acknowledges a
PutMapCommand
completion in the backup owner. - multimap(HotRodHeader, Subject, boolean) - Method in class org.infinispan.server.hotrod.HotRodServer
- MULTIMAP_BUCKET - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- MULTIMAP_LOWER_BOUND - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- MultimapCache<K,
V> - Interface in org.infinispan.multimap.api.embedded -
Embedded version of MultimapCache.
- MultimapCacheManager<K,
V> - Interface in org.infinispan.client.hotrod.multimap - MultimapCacheManager<K,
V> - Interface in org.infinispan.multimap.api.embedded - multimapCollectionResponse(HotRodHeader, HotRodServer, Channel, OperationStatus, Collection<byte[]>) - Method in class org.infinispan.server.hotrod.Encoder4x
- multimapCollectionResponse(HotRodHeader, HotRodServer, Channel, OperationStatus, Collection<byte[]>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- multimapEntryResponse(HotRodHeader, HotRodServer, Channel, OperationStatus, CacheEntry<byte[], Collection<byte[]>>) - Method in class org.infinispan.server.hotrod.Encoder4x
- multimapEntryResponse(HotRodHeader, HotRodServer, Channel, OperationStatus, CacheEntry<byte[], Collection<byte[]>>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- MultimapModuleLifecycle - Class in org.infinispan.multimap.impl
-
MultimapModuleLifecycle is necessary for the Multimap Cache module.
- MultimapModuleLifecycle() - Constructor for class org.infinispan.multimap.impl.MultimapModuleLifecycle
- multimapProcessor - Variable in class org.infinispan.server.hotrod.HotRodDecoder
- MULTIPART_FORM_DATA - Static variable in class org.infinispan.commons.dataconversion.MediaType
- MULTIPART_FORM_DATA_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- multipleEntityTypesWithSameName(String, Class<?>, Class<?>) - Method in interface org.infinispan.search.mapper.log.impl.Log
- multipleRemoteStores() - Method in interface org.infinispan.rest.logging.Log
- MultiTargetRequest<T> - Class in org.infinispan.remoting.transport.impl
-
Request implementation that waits for responses from multiple target nodes.
- MultiTargetRequest(ResponseCollector<T>, long, RequestRepository, Collection<Address>, Address, JGroupsMetricsManager) - Constructor for class org.infinispan.remoting.transport.impl.MultiTargetRequest
- MURMURHASH_3 - Static variable in interface org.infinispan.commons.marshall.Ids
- MurmurHash3 - Class in org.infinispan.commons.hash
-
MurmurHash3 implementation in Java, based on Austin Appleby's original in C Only implementing x64 version, because this should always be faster on 64 bit native processors, even 64 bit being ran with a 32 bit OS; this should also be as fast or faster than the x86 version on some modern 32 bit processors.
- MurmurHash3_x64_128(byte[], int) - Static method in class org.infinispan.commons.hash.MurmurHash3
-
Hash a value using the x64 128 bit variant of MurmurHash3
- MurmurHash3_x64_128(long[], int) - Static method in class org.infinispan.commons.hash.MurmurHash3
-
Hash a value using the x64 128 bit variant of MurmurHash3
- MurmurHash3_x64_32(byte[], int) - Static method in class org.infinispan.commons.hash.MurmurHash3
-
Hash a value using the x64 32 bit variant of MurmurHash3
- MurmurHash3_x64_32(long[], int) - Static method in class org.infinispan.commons.hash.MurmurHash3
-
Hash a value using the x64 32 bit variant of MurmurHash3
- MurmurHash3_x64_64(byte[], int) - Static method in class org.infinispan.commons.hash.MurmurHash3
-
Hash a value using the x64 64 bit variant of MurmurHash3
- MurmurHash3_x64_64(long[], int) - Static method in class org.infinispan.commons.hash.MurmurHash3
-
Hash a value using the x64 64 bit variant of MurmurHash3
- MurmurHash3.Externalizer - Class in org.infinispan.commons.hash
- MurmurHash3BloomFilter - Class in org.infinispan.commons.util
-
BloomFilter implementation that allows for up to 10 hash functions all using MurmurHash3 with different seeds.
- mutableCopyFrom(Set<Integer>) - Static method in class org.infinispan.commons.util.IntSets
-
Returns an IntSet that contains all ints from the given Set that is mutable.
- mutableEmptySet() - Static method in class org.infinispan.commons.util.IntSets
-
Returns a mutable IntSet with no values set.
- mutableEmptySet(int) - Static method in class org.infinispan.commons.util.IntSets
-
Returns an IntSet that contains no values but is initialized to hold ints equal to the
maxExclusive -1
or smaller. - mutableFrom(Set<Integer>) - Static method in class org.infinispan.commons.util.IntSets
-
Returns an IntSet that is mutable that contains all of the values from the given set.
- MutablePrincipalRoleMapper - Interface in org.infinispan.security
- MutableRolePermissionMapper - Interface in org.infinispan.security
-
A
RolePermissionMapper
with the ability to add/remove roles at runtime - mutableSet(int) - Static method in class org.infinispan.commons.util.IntSets
-
Returns a mutable set with the initial value set.
- mutableSet(int, int) - Static method in class org.infinispan.commons.util.IntSets
-
Returns a mutable IntSet that begins with the initialized values
- MVCCEntry<K,
V> - Interface in org.infinispan.container.entries -
An entry that can be safely copied when updates are made, to provide MVCC semantics
- MXParser - Class in org.infinispan.commons.configuration.io.xml
-
Absolutely minimal implementation of XMLPULL V1 API
- MXParser() - Constructor for class org.infinispan.commons.configuration.io.xml.MXParser
- MXParser(Reader) - Constructor for class org.infinispan.commons.configuration.io.xml.MXParser
- MXParserDriver - Class in org.infinispan.server.core.dataconversion.xml
- MXParserDriver() - Constructor for class org.infinispan.server.core.dataconversion.xml.MXParserDriver
- MXParserReader - Class in org.infinispan.server.core.dataconversion.xml
- MXParserReader(Reader, MXParser) - Constructor for class org.infinispan.server.core.dataconversion.xml.MXParserReader
- MXParserReader(Reader, MXParser, NameCoder) - Constructor for class org.infinispan.server.core.dataconversion.xml.MXParserReader
- MYSQL - Enum constant in enum org.infinispan.persistence.jdbc.common.DatabaseType
N
- name - Variable in class org.infinispan.client.hotrod.counter.impl.BaseCounter
- name() - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
- name() - Method in class org.infinispan.commons.configuration.attributes.Attribute
- name() - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
- name() - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
- name() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
- name() - Method in class org.infinispan.configuration.global.CachedThreadPoolConfigurationBuilder
- name() - Method in interface org.infinispan.configuration.global.NamedStackConfiguration
- name() - Method in class org.infinispan.configuration.global.ScheduledThreadPoolConfigurationBuilder
- name() - Method in class org.infinispan.configuration.global.StackConfiguration
- name() - Method in class org.infinispan.configuration.global.StackFileConfiguration
- name() - Method in class org.infinispan.configuration.global.ThreadFactoryConfigurationBuilder
- name() - Method in class org.infinispan.configuration.global.ThreadPoolConfiguration
- name() - Method in class org.infinispan.counter.configuration.AbstractCounterConfiguration
- name() - Method in class org.infinispan.counter.configuration.StrongCounterConfigurationBuilder
- name() - Method in interface org.infinispan.counter.configuration.CounterConfigurationBuilder
- name() - Element in annotation type org.infinispan.factories.annotations.InfinispanModule
-
The unique name of the module.
- name() - Element in annotation type org.infinispan.filter.NamedFactory
- name() - Method in class org.infinispan.lock.configuration.ClusteredLockConfiguration
- name() - Method in class org.infinispan.rest.distribution.CacheDistributionInfo
- name() - Method in interface org.infinispan.rest.distribution.NodeDataDistribution
- name() - Method in class org.infinispan.rest.distribution.NodeDistributionInfo
- name() - Method in interface org.infinispan.search.mapper.common.EntityReference
- name() - Method in class org.infinispan.search.mapper.common.impl.EntityReferenceImpl
- name() - Method in interface org.infinispan.search.mapper.mapping.SearchIndexedEntity
- name() - Method in interface org.infinispan.search.mapper.session.impl.InfinispanIndexedTypeContext
- name() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- name() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- name(String) - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
- name(String) - Method in class org.infinispan.configuration.global.CachedThreadPoolConfigurationBuilder
- name(String) - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
- name(String) - Method in class org.infinispan.counter.configuration.StrongCounterConfigurationBuilder
- name(String) - Method in interface org.infinispan.counter.configuration.CounterConfigurationBuilder
-
Sets the counter's name.
- name(String) - Method in class org.infinispan.lock.configuration.ClusteredLockConfigurationBuilder
- name(String) - Method in class org.infinispan.rest.configuration.CorsRuleConfigurationBuilder
- name(String) - Method in class org.infinispan.rest.framework.impl.InvocationImpl.Builder
- name(String) - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
- name(String) - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- name(String) - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
-
Specifies a custom name for this protocol server in order to easily distinguish it from others of the same type on the same server, e.g.
- NAME - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- NAME - Enum constant in enum org.infinispan.counter.configuration.Attribute
- NAME - Enum constant in enum org.infinispan.lock.configuration.Attribute
- NAME - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
- NAME - Enum constant in enum org.infinispan.server.hotrod.configuration.Attribute
- NAME - Static variable in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
- NAME - Static variable in interface org.infinispan.jmx.ObjectNameKeys
- NAME - Static variable in class org.infinispan.rest.configuration.CorsRuleConfiguration
- NAME - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- NAMED_CACHE - Enum constant in enum org.infinispan.factories.impl.Scopes
-
Every cache uses a separate instance of the component.
- NAMED_CACHE - Enum constant in enum org.infinispan.factories.scopes.Scopes
-
Every cache uses a separate instance of the component.
- NamedComponentFactory - Class in org.infinispan.factories
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 9.4, please implement
AnyScopeComponentFactory.construct(String)
directly. - NamedComponentFactory() - Constructor for class org.infinispan.factories.NamedComponentFactory
-
Deprecated.
- NamedExecutorsFactory - Class in org.infinispan.factories
-
A factory that specifically knows how to create named executors.
- NamedExecutorsFactory() - Constructor for class org.infinispan.factories.NamedExecutorsFactory
- NamedFactory - Annotation Type in org.infinispan.filter
- namedParamNotReturnedFromSelect(String, String, String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- NamedSocketFactory - Class in org.infinispan.remoting.transport.jgroups
-
A
SocketFactory
which allows setting a callback to configure the sockets using a supplied name. - NamedSocketFactory(Supplier<SocketFactory>, Supplier<ServerSocketFactory>) - Constructor for class org.infinispan.remoting.transport.jgroups.NamedSocketFactory
- NamedStackConfiguration - Interface in org.infinispan.configuration.global
- namedTypesNotSupported(String) - Method in interface org.infinispan.search.mapper.log.impl.Log
- names() - Element in annotation type org.infinispan.factories.annotations.DefaultFactoryFor
- NAMES - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- NAMES - Static variable in class org.infinispan.server.core.security.external.ExternalSaslServerFactory
- NAMES_AS_TAGS - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- NAMES_AS_TAGS - Static variable in class org.infinispan.configuration.global.GlobalMetricsConfiguration
- namesAsTags() - Method in class org.infinispan.configuration.global.GlobalMetricsConfiguration
-
Put the cache manager and cache name in tags rather then include them in the metric name.
- namesAsTags() - Method in class org.infinispan.configuration.global.GlobalMetricsConfigurationBuilder
-
Put the cache manager and cache name in tags rather then include them in the metric name.
- namesAsTags(boolean) - Method in class org.infinispan.configuration.global.GlobalMetricsConfigurationBuilder
-
Put the cache manager and cache name in tags rather then include them in the metric name.
- Namespace - Annotation Type in org.infinispan.configuration.parsing
-
Namespace.
- NAMESPACE - Static variable in class org.infinispan.configuration.parsing.CacheParser
- NAMESPACE - Static variable in class org.infinispan.configuration.parsing.Parser
- namespaceEnd - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- NamespaceMappingParser - Interface in org.infinispan.configuration.parsing
-
NamespaceMappingParser.
- namespacePrefix - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- namespacePrefixHash - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- namespaces - Variable in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- Namespaces - Annotation Type in org.infinispan.configuration.parsing
-
Namespaces.
- namespaceUri - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- naming - Variable in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- namingExceptionLookingUpConnection(String, NamingException) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- namingStrategy - Variable in class org.infinispan.commons.configuration.io.AbstractConfigurationReader
- NamingStrategy - Enum in org.infinispan.commons.configuration.io
- NANOSECONDS - Enum constant in enum org.infinispan.server.hotrod.TimeUnitValue
- nativeCache - Variable in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository
- NativeTransport - Class in org.infinispan.server.core.transport
- NativeTransport() - Constructor for class org.infinispan.server.core.transport.NativeTransport
- NCODING - Static variable in class org.infinispan.commons.configuration.io.xml.MXParser
- NEAR_CACHE_BLOOM_FILTER - Static variable in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
- NEAR_CACHE_BLOOM_FILTER - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- NEAR_CACHE_FACTORY - Static variable in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
- NEAR_CACHE_MAX_ENTRIES - Static variable in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
- NEAR_CACHE_MAX_ENTRIES - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- NEAR_CACHE_MODE - Static variable in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
- NEAR_CACHE_MODE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- NEAR_CACHE_NAME_PATTERN - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- nearCache() - Method in class org.infinispan.client.hotrod.configuration.Configuration
-
Deprecated, for removal: This API element is subject to removal in a future version.
- nearCache() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.since 11.0. To be removed in 14.0. Use
RemoteCacheConfigurationBuilder.nearCacheMode(NearCacheMode)
andRemoteCacheConfigurationBuilder.nearCacheMaxEntries(int)
instead. - NearCache<K,
V> - Interface in org.infinispan.client.hotrod.near -
Near cache contract.
- nearCacheBloomFilter() - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
- NearCacheConfiguration - Class in org.infinispan.client.hotrod.configuration
- NearCacheConfiguration(NearCacheMode, int, boolean) - Constructor for class org.infinispan.client.hotrod.configuration.NearCacheConfiguration
- NearCacheConfiguration(NearCacheMode, int, boolean, Pattern, NearCacheFactory) - Constructor for class org.infinispan.client.hotrod.configuration.NearCacheConfiguration
- NearCacheConfigurationBuilder - Class in org.infinispan.client.hotrod.configuration
- NearCacheConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.client.hotrod.configuration.NearCacheConfigurationBuilder
- nearCacheFactory() - Method in class org.infinispan.client.hotrod.configuration.NearCacheConfiguration
- nearCacheFactory() - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
- nearCacheFactory(NearCacheFactory) - Method in class org.infinispan.client.hotrod.configuration.NearCacheConfigurationBuilder
-
Specifies a
NearCacheFactory
which is responsible for creatingNearCache
instances. - nearCacheFactory(NearCacheFactory) - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfigurationBuilder
-
Specifies a
NearCacheFactory
which is responsible for creatingNearCache
instances. - NearCacheFactory - Interface in org.infinispan.client.hotrod.near
- nearCacheMaxEntries() - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
- nearCacheMaxEntries(int) - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfigurationBuilder
-
Specifies the maximum number of entries that will be held in the near cache.
- nearCacheMaxEntriesPositiveWithBloom(int) - Method in interface org.infinispan.client.hotrod.logging.Log
- nearCacheMaxEntriesUndefined() - Method in interface org.infinispan.client.hotrod.logging.Log
- nearCacheMaxIdleUnsupported() - Method in interface org.infinispan.client.hotrod.logging.Log
- nearCacheMode() - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
- nearCacheMode(NearCacheMode) - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfigurationBuilder
-
Specifies the near caching mode.
- NearCacheMode - Enum in org.infinispan.client.hotrod.configuration
-
Decides how client-side near caching should work.
- NearCacheService<K,
V> - Class in org.infinispan.client.hotrod.near -
Near cache service, manages the lifecycle of the near cache.
- NearCacheService(NearCacheConfiguration, ClientListenerNotifier) - Constructor for class org.infinispan.client.hotrod.near.NearCacheService
- nearCacheUseBloomFilter(boolean) - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfigurationBuilder
-
Specifies whether bloom filter should be used for near cache to limit the number of write notifications for unrelated keys.
- needMoreResponses() - Method in class org.infinispan.remoting.responses.ClusteredGetResponseValidityFilter
- needMoreResponses() - Method in class org.infinispan.remoting.responses.IgnoreExtraResponsesValidityFilter
- needMoreResponses() - Method in interface org.infinispan.remoting.rpc.ResponseFilter
-
Right after calling
ResponseFilter.isAcceptable(Response, Address)
, this method is called to see whether we are done with the request and can unblock the caller - needSegments(Configuration) - Static method in class org.infinispan.configuration.cache.Configurations
- needsStateTransfer() - Method in enum org.infinispan.configuration.cache.CacheMode
- needToDestroyFailedCache() - Method in enum org.infinispan.lifecycle.ComponentStatus
- needToInitializeBeforeStart() - Method in enum org.infinispan.lifecycle.ComponentStatus
- NettyChannelInitializer<A extends ProtocolServerConfiguration> - Class in org.infinispan.server.core.transport
-
Pipeline factory for Netty based channels.
- NettyChannelInitializer(ProtocolServer<A>, NettyTransport, ChannelOutboundHandler, ChannelInboundHandler) - Constructor for class org.infinispan.server.core.transport.NettyChannelInitializer
- NettyEventLoopFactory - Class in org.infinispan.server.core.factories
- NettyEventLoopFactory() - Constructor for class org.infinispan.server.core.factories.NettyEventLoopFactory
- NettyInitializer - Interface in org.infinispan.server.core.transport
- NettyInitializers - Class in org.infinispan.server.core.transport
- NettyInitializers(NettyInitializer...) - Constructor for class org.infinispan.server.core.transport.NettyInitializers
- NettyIOFactory - Class in org.infinispan.server.core.factories
-
Factory to create netty io event loop and replace the non blocking executor with it
- NettyIOFactory() - Constructor for class org.infinispan.server.core.factories.NettyIOFactory
- NettyRestRequest - Class in org.infinispan.rest
-
A
RestRequest
backed by Netty. - NettyRestResponse - Class in org.infinispan.rest
-
A
RestResponse
backed by Netty. - NettyRestResponse.Builder - Class in org.infinispan.rest
- NettyTransport - Class in org.infinispan.server.core.transport
-
A Netty based transport.
- NettyTransport(InetSocketAddress, ProtocolServerConfiguration, String, EmbeddedCacheManager) - Constructor for class org.infinispan.server.core.transport.NettyTransport
- NETWORK_PREFIX_OVERRIDE - Enum constant in enum org.infinispan.server.hotrod.configuration.Attribute
- NETWORK_PREFIX_OVERRIDE - Static variable in class org.infinispan.server.hotrod.configuration.TopologyCacheConfiguration
- networkPrefixOverride() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
- networkPrefixOverride() - Method in class org.infinispan.server.hotrod.configuration.TopologyCacheConfiguration
- networkPrefixOverride(boolean) - Method in class org.infinispan.server.hotrod.configuration.TopologyCacheConfigurationBuilder
- NEVER - Enum constant in enum org.infinispan.configuration.cache.BiasAcquisition
-
The bias is never acquired.
- NEVER - Enum constant in enum org.infinispan.rest.configuration.ExtendedHeaders
- newBuilder() - Static method in class org.infinispan.reactive.publisher.impl.Notifications
- newByteBuffer(byte[]) - Method in interface org.infinispan.commons.io.ByteBufferFactory
- newByteBuffer(byte[]) - Method in class org.infinispan.commons.io.ByteBufferFactoryImpl
- newByteBuffer(byte[], int, int) - Method in interface org.infinispan.commons.io.ByteBufferFactory
- newByteBuffer(byte[], int, int) - Method in class org.infinispan.commons.io.ByteBufferFactoryImpl
- newCacheEntryMapper(DataConversion, DataConversion, InternalEntryFactory) - Static method in class org.infinispan.cache.impl.EncoderEntryMapper
- newCatchThrowableProxy(Object) - Static method in class org.infinispan.commons.util.Proxies
- newCondition() - Method in class org.infinispan.commons.util.concurrent.NonReentrantLock
- newConditionStage(Predicate<T>, long, TimeUnit) - Method in class org.infinispan.util.concurrent.ConditionFuture
- newConditionStage(Predicate<T>, Supplier<Exception>, long, TimeUnit) - Method in class org.infinispan.util.concurrent.ConditionFuture
-
Create a new
CompletionStage
that completes after the firstConditionFuture.update(Object)
call with a value satisfying thetest
predicate. - newConfigurationBuilder(String) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
- newConfigurationFrom(int) - Method in class org.infinispan.configuration.cache.AbstractSegmentedStoreConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.0 - please implement
AbstractSegmentedStoreConfiguration.newConfigurationFrom(int, InitializationContext)
. - newConfigurationFrom(int, InitializationContext) - Method in class org.infinispan.configuration.cache.AbstractSegmentedStoreConfiguration
-
Same as
AbstractSegmentedStoreConfiguration.newConfigurationFrom(int)
except that you can utilize the intialization context when initializing the segmented store object. - newDefaultMetadata(Configuration) - Static method in class org.infinispan.configuration.cache.Configurations
- newEntryMapper(DataConversion, DataConversion, InternalEntryFactory) - Static method in class org.infinispan.cache.impl.EncoderEntryMapper
- newFixedThreadPool(int, int) - Static method in class org.infinispan.util.concurrent.BoundedExecutors
-
Creates a thread pool that reuses a fixed set of threads operating off a shared bounded queue.
- newFixedThreadPool(int, ThreadFactory, int) - Static method in class org.infinispan.util.concurrent.BoundedExecutors
-
Creates a thread pool that reuses a fixed set of threads operating off a shared bounded queue, using the provided ThreadFactory to create new threads when needed.
- newGlobalTransaction(Address, boolean) - Method in class org.infinispan.transaction.xa.TransactionFactory
- newGlobalTransaction(Address, boolean, VersionGenerator, boolean) - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
- newInstance() - Static method in class org.infinispan.commons.util.FileLookupFactory
- newInstance() - Method in class org.infinispan.factories.impl.ComponentAccessor
- newInstance(ComponentRegistry, CacheRpcCommand) - Static method in class org.infinispan.remoting.LocalInvocation
- newInstanceFromCache(Cache<?, ?>, CacheRpcCommand) - Static method in class org.infinispan.remoting.LocalInvocation
- newInstanceOrNull(Class<T>, Class[], Object...) - Static method in class org.infinispan.commons.util.Util
-
Instantiates a class by invoking the constructor that matches the provided parameter types passing the given arguments.
- newKeyAffinityService(Cache<K, V>, Collection<Address>, KeyGenerator<K>, Executor, int) - Static method in class org.infinispan.affinity.KeyAffinityServiceFactory
- newKeyAffinityService(Cache<K, V>, Collection<Address>, KeyGenerator<K>, Executor, int, boolean) - Static method in class org.infinispan.affinity.KeyAffinityServiceFactory
-
Creates a service that would only generate keys for addresses specified in filter.
- newKeyAffinityService(Cache<K, V>, Executor, KeyGenerator<K>, int) - Static method in class org.infinispan.affinity.KeyAffinityServiceFactory
- newKeyAffinityService(Cache<K, V>, Executor, KeyGenerator<K>, int, boolean) - Static method in class org.infinispan.affinity.KeyAffinityServiceFactory
-
Creates an
KeyAffinityService
instance that generates keys mapped to all addresses in the cluster. - newKeyDataConversion() - Static method in class org.infinispan.encoding.DataConversion
- newKeyDataConversion(Class<? extends Encoder>, Class<? extends Wrapper>) - Static 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. Replaced by
DataConversion.newKeyDataConversion()
. - newLeft(A) - Static method in class org.infinispan.commons.util.Either
- NEWLINE - Static variable in class org.infinispan.commons.util.StringPropertyReplacer
-
New line string constant
- newLocalKeyAffinityService(Cache<K, V>, KeyGenerator<K>, Executor, int) - Static method in class org.infinispan.affinity.KeyAffinityServiceFactory
- newLocalKeyAffinityService(Cache<K, V>, KeyGenerator<K>, Executor, int, boolean) - Static method in class org.infinispan.affinity.KeyAffinityServiceFactory
-
Created an service that only generates keys for the local address.
- newLocalTransaction(Transaction, GlobalTransaction, boolean, int) - Method in class org.infinispan.transaction.xa.TransactionFactory
- newLocalTransaction(Transaction, GlobalTransaction, boolean, int, long) - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
- newModuleLifecycle() - Method in interface org.infinispan.factories.impl.ModuleMetadataBuilder
- newNonTxInvocationContext(Address) - Method in class org.infinispan.context.impl.TransactionalInvocationContextFactory
- newPermissionCollection() - Method in class org.infinispan.security.CachePermission
- newRemoteTransaction(List<WriteCommand>, GlobalTransaction, int) - Method in class org.infinispan.transaction.xa.TransactionFactory
- newRemoteTransaction(List<WriteCommand>, GlobalTransaction, int, long) - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
- newRemoteTransaction(WriteCommand[], GlobalTransaction, int) - Method in class org.infinispan.transaction.xa.TransactionFactory
- newRemoteTransaction(WriteCommand[], GlobalTransaction, int, long) - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
- newRemoteTransaction(GlobalTransaction, int) - Method in class org.infinispan.transaction.xa.TransactionFactory
- newRemoteTransaction(GlobalTransaction, int, long) - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
- newRequestId() - Method in class org.infinispan.remoting.transport.impl.RequestRepository
- newResponse(FullHttpRequest) - Method in class org.infinispan.rest.InvocationHelper
- newResponse(RestRequest) - Method in class org.infinispan.rest.InvocationHelper
- newResponse(RestRequest, HttpResponseStatus) - Method in class org.infinispan.rest.InvocationHelper
- newResponse(RestRequest, HttpResponseStatus, Object) - Method in class org.infinispan.rest.InvocationHelper
- newRight(B) - Static method in class org.infinispan.commons.util.Either
- newRole(String, boolean, AuthorizationPermission...) - Static method in interface org.infinispan.security.Role
- newServerAdded(SocketAddress) - Method in interface org.infinispan.client.hotrod.logging.Log
- newString(char[], int, int) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- newStringIntern(char[], int, int) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- newThread(Runnable) - Method in class org.infinispan.factories.threads.DefaultThreadFactory
- newTopology(int, int, int, Collection<? extends SocketAddress>) - Method in interface org.infinispan.client.hotrod.logging.Log
- newValueDataConversion() - Static method in class org.infinispan.encoding.DataConversion
- newValueDataConversion(Class<? extends Encoder>, Class<? extends Wrapper>) - Static 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. Replaced by
DataConversion.newValueDataConversion()
. - newVersion(int) - Static method in class org.infinispan.container.versioning.irac.TopologyIracVersion
- newVersion(ByteString, TopologyIracVersion) - Static method in class org.infinispan.container.versioning.irac.IracEntryVersion
- next - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator
- next() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- next() - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
-
Get next parsing event - element content wil be coalesced and only one TEXT event must be returned for whole element content (comments and processing instructions will be ignored and emtity references must be expanded or exception mus be thrown if entity reerence can not be exapnded).
- next() - Method in class org.infinispan.commons.util.AbstractIterator
- next() - Method in class org.infinispan.commons.util.Immutables.ImmutableIteratorWrapper
- next() - Method in class org.infinispan.commons.util.IteratorMapper
- next() - Method in class org.infinispan.commons.util.RemovableIterator
- next() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator
- next() - Method in class org.infinispan.query.impl.ScrollerIteratorAdaptor
- next() - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- next() - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
- next() - Method in class org.infinispan.util.CloseableSuppliedIterator
- next() - Method in class org.infinispan.util.DataContainerRemoveIterator
- next() - Method in class org.infinispan.util.LazyConcatIterator
- next(int, int) - Method in class org.infinispan.distribution.TriangleOrderManager
- next(String) - Method in class org.infinispan.server.hotrod.iteration.DefaultIterationManager
- next(String) - Method in interface org.infinispan.server.hotrod.iteration.IterationManager
- nextElement() - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
- nextElement() - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationReader
- nextElement() - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationReader
- nextElement() - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader
- nextElement(ConfigurationReader) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- nextImpl() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- nextServer(Set<SocketAddress>) - Method in interface org.infinispan.client.hotrod.FailoverRequestBalancingStrategy
- nextSize(Object) - Method in class org.infinispan.commons.marshall.AdaptiveBufferSizePredictor
- nextSize(Object) - Method in interface org.infinispan.commons.marshall.BufferSizePredictor
-
Provide the next buffer size taking in account the object to store in the buffer.
- nextTag() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- nextTag() - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
-
Call next() and return event if it is START_TAG or END_TAG otherwise throw an exception.
- nextText() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- nextText() - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
-
If current event is START_TAG then if next element is TEXT then element content is returned or if next event is END_TAG then empty string is returned, otherwise exception is thrown.
- nextToken() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- nextToken() - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
-
This method works similarly to next() but will expose additional event types (COMMENT, CDSECT, DOCDECL, ENTITY_REF, PROCESSING_INSTRUCTION, or IGNORABLE_WHITESPACE) if they are available in input.
- nil() - Method in class org.infinispan.commons.dataconversion.internal.Json.DefaultFactory
- nil() - Method in interface org.infinispan.commons.dataconversion.internal.Json.Factory
-
Construct and return an object representing JSON
null
. - nil() - Static method in class org.infinispan.commons.dataconversion.internal.Json
- nl() - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- NO - Static variable in class org.infinispan.commons.configuration.io.xml.MXParser
- NO_ACTIVE - Enum constant in enum org.infinispan.server.hotrod.configuration.Element
- NO_ACTIVE - Enum constant in enum org.infinispan.server.hotrod.configuration.Policy
- NO_ANONYMOUS - Enum constant in enum org.infinispan.server.hotrod.configuration.Element
- NO_ANONYMOUS - Enum constant in enum org.infinispan.server.hotrod.configuration.Policy
- NO_DICTIONARY - Enum constant in enum org.infinispan.server.hotrod.configuration.Element
- NO_DICTIONARY - Enum constant in enum org.infinispan.server.hotrod.configuration.Policy
- NO_ENCODER - Static variable in interface org.infinispan.commons.dataconversion.EncoderIds
-
Deprecated.
- NO_INDEX - Static variable in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NO_NAMESPACE - Static variable in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
-
This constant represents the default namespace (empty string "")
- NO_OP - Static variable in interface org.infinispan.commons.stat.TimerTracker
- NO_OP - Static variable in interface org.infinispan.util.concurrent.locks.KeyAwareLockPromise
- NO_OP - Static variable in interface org.infinispan.util.concurrent.locks.PendingLockPromise
- NO_OP - Static variable in interface org.infinispan.util.ExponentialBackOff
-
Disabled exponential back-off algorithm.
- NO_OP_RUNNABLE - Static variable in class org.infinispan.util.concurrent.CompletionStages
- NO_PLAIN_TEXT - Enum constant in enum org.infinispan.server.hotrod.configuration.Element
- NO_PLAIN_TEXT - Enum constant in enum org.infinispan.server.hotrod.configuration.Policy
- NO_REBALANCE - Enum constant in enum org.infinispan.topology.CacheTopology.Phase
-
Only currentCH should be set, this works as both readCH and writeCH
- NO_REQUEST_ID - Static variable in interface org.infinispan.remoting.transport.impl.Request
- NO_SUCH_KEY - Enum constant in enum org.infinispan.client.hotrod.impl.VersionedOperationResponse.RspCode
- NO_SUCH_SITE - Enum constant in enum org.infinispan.xsite.status.BringSiteOnlineResponse
- NO_SUCH_SITE - Enum constant in enum org.infinispan.xsite.status.TakeSiteOfflineResponse
- NO_TRANSACTION - Enum constant in enum org.infinispan.server.hotrod.tx.table.Status
- NO_VALUE_READ_ONLY_VIEW - Static variable in interface org.infinispan.commons.marshall.Ids
- NO_VERSION - Static variable in class org.infinispan.container.versioning.irac.TopologyIracVersion
- NO_WRAPPER - Static variable in interface org.infinispan.commons.dataconversion.WrapperIds
- noCache() - Static method in class org.infinispan.rest.CacheControl
-
Returns
no-cache
header value. - NoCacheFoundException - Exception in org.infinispan.rest.operations.exceptions
- NoCacheFoundException(String) - Constructor for exception org.infinispan.rest.operations.exceptions.NoCacheFoundException
- noContentResponse(RestRequest) - Method in class org.infinispan.rest.InvocationHelper
- NoDataFoundException - Exception in org.infinispan.rest.operations.exceptions
- NoDataFoundException() - Constructor for exception org.infinispan.rest.operations.exceptions.NoDataFoundException
- NoDataFoundException(String) - Constructor for exception org.infinispan.rest.operations.exceptions.NoDataFoundException
- NODE - Enum constant in enum org.infinispan.distribution.topologyaware.TopologyLevel
- NODE - Enum constant in enum org.infinispan.lock.api.OwnershipLevel
- NODE_NAME - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- NODE_NAME - Static variable in class org.infinispan.configuration.global.TransportConfiguration
- NODE_TAG_NAME - Static variable in interface org.infinispan.metrics.Constants
- NodeDataDistribution - Interface in org.infinispan.rest.distribution
-
Identifies a specific node on a data distribution response.
- NodeDistributionInfo - Class in org.infinispan.rest.distribution
-
Collect node's information and statistics of the local JVM.
- NodeDistributionInfo(String, List<String>, long, long) - Constructor for class org.infinispan.rest.distribution.NodeDistributionInfo
- NodeDistributionInfo$___Marshaller_50bcddd047df75d5979a51292e9db600cc21f4e1e18d6fe36b39e9a26196ea0e - Class in org.infinispan.rest.distribution
-
WARNING: Generated code! Do not edit!
- NodeDistributionInfo$___Marshaller_50bcddd047df75d5979a51292e9db600cc21f4e1e18d6fe36b39e9a26196ea0e() - Constructor for class org.infinispan.rest.distribution.NodeDistributionInfo$___Marshaller_50bcddd047df75d5979a51292e9db600cc21f4e1e18d6fe36b39e9a26196ea0e
- nodeName() - Method in class org.infinispan.configuration.global.ThreadFactoryConfigurationBuilder
- nodeName() - Method in class org.infinispan.configuration.global.TransportConfiguration
- nodeName(String) - Method in class org.infinispan.configuration.global.ThreadFactoryConfigurationBuilder
- nodeName(String) - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
- nodeName(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
-
Name of the current node.
- NodeSuspected - Enum constant in enum org.infinispan.server.hotrod.OperationStatus
- NODLD_NORECOVERY_NOXA - Enum constant in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
- NODLD_NORECOVERY_XA - Enum constant in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
- NODLD_RECOVERY_XA - Enum constant in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
- noEngineForScript(String) - Method in interface org.infinispan.scripting.logging.Log
- noFilter() - Method in interface org.infinispan.manager.ClusterExecutor
-
Applies no filtering and will send any invocations to any/all current nodes.
- NoFlag - Enum constant in enum org.infinispan.server.hotrod.ProtocolFlag
- noFlags() - Method in interface org.infinispan.AdvancedCache
-
Unset all flags set on this cache using
AdvancedCache.withFlags(Flag...)
orAdvancedCache.withFlags(Collection)
methods. - noFlags() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- noFlags() - Method in class org.infinispan.cache.impl.CacheImpl
- noFlags() - Method in class org.infinispan.cache.impl.DecoratedCache
- noFlags() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- noFlags() - Method in class org.infinispan.security.impl.SecureCacheImpl
- noHasHFunctionConfigured(int) - Method in interface org.infinispan.client.hotrod.logging.Log
- NoKeyException - Exception in org.infinispan.rest.operations.exceptions
- NoKeyException() - Constructor for exception org.infinispan.rest.operations.exceptions.NoKeyException
- NoKeyException(String) - Constructor for exception org.infinispan.rest.operations.exceptions.NoKeyException
- noMembersInHashTopology(ConsistentHash, String) - Method in interface org.infinispan.server.hotrod.logging.Log
- noMembersInTopology() - Method in interface org.infinispan.server.hotrod.logging.Log
- noMoreOperationsAllowed() - Method in interface org.infinispan.client.hotrod.logging.Log
- NON_BLOCKING_BOUNDED_QUEUE_THREAD_POOL - Enum constant in enum org.infinispan.configuration.parsing.Element
- NON_BLOCKING_EXECUTOR - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- NON_BLOCKING_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
- NON_BLOCKING_GROUP - Static variable in interface org.infinispan.commons.ThreadGroups
- NON_DURABLE_XA - Enum constant in enum org.infinispan.client.hotrod.configuration.TransactionMode
-
The cache is enlisted as
XAResource
but it doesn't keep any recovery information. - NON_DURABLE_XA - Enum constant in enum org.infinispan.configuration.cache.TransactionMode
- NON_DURABLE_XA - Enum constant in enum org.infinispan.configuration.parsing.CacheParser.TransactionMode
- NON_EXISTING - Enum constant in enum org.infinispan.server.hotrod.tx.ControlByte
- NON_OWNER - Enum constant in enum org.infinispan.distribution.Ownership
-
This node is not an owner.
- NON_TRANSACTIONAL - Enum constant in enum org.infinispan.transaction.TransactionMode
- NON_XA - Enum constant in enum org.infinispan.client.hotrod.configuration.TransactionMode
-
The cache is enlisted as
Synchronization
. - NON_XA - Enum constant in enum org.infinispan.configuration.cache.TransactionMode
- NON_XA - Enum constant in enum org.infinispan.configuration.parsing.CacheParser.TransactionMode
- noNamedScript(String) - Method in interface org.infinispan.scripting.logging.Log
- nonBackupAddresses - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
- nonBlocking(Boolean) - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
- nonBlockingExecutor - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- nonBlockingExecutor - Variable in class org.infinispan.util.concurrent.locks.impl.PerKeyLockContainer
- nonBlockingExecutor(String) - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
- NonBlockingManager - Interface in org.infinispan.util.concurrent
-
Manager utility for non-blocking operations.
- NonBlockingManagerImpl - Class in org.infinispan.util.concurrent
- NonBlockingManagerImpl() - Constructor for class org.infinispan.util.concurrent.NonBlockingManagerImpl
- NonBlockingRejectedExecutionHandler - Class in org.infinispan.commons.util.concurrent
-
A handler for rejected tasks that runs the task if the current thread is a non blocking thread otherwise it blocks until the task can be added to the underlying queue
- NonBlockingResource - Interface in org.infinispan.commons.executors
-
Interface to designate the resource is a non blocking one
- nonBlockingScheduler - Variable in class org.infinispan.reactive.publisher.impl.LocalPublisherManagerImpl
- NonBlockingSoftIndexFileStore<K,
V> - Class in org.infinispan.persistence.sifs -
Local file-based cache store, optimized for write-through use with strong consistency guarantees (ability to flush disk operations before returning from the store call).
- NonBlockingSoftIndexFileStore() - Constructor for class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
- NonBlockingSoftIndexFileStore.EntryCreator<K,
V> - Interface in org.infinispan.persistence.sifs - NonBlockingStore<K,
V> - Interface in org.infinispan.persistence.spi -
The contract for defining how caches interface with external sources of data, such as databases or filesystems.
- NonBlockingStore.Characteristic - Enum in org.infinispan.persistence.spi
-
Enumeration defining the various characteristics of the underlying store to communicate what features it may or may not support.
- NonBlockingStore.SegmentedPublisher<Type> - Interface in org.infinispan.persistence.spi
-
A Publisher that provides a stream of values and the segments to which those values map.
- NonBlockingStoreAdapter<K,
V> - Class in org.infinispan.persistence.support - NonBlockingStoreAdapter(Lifecycle) - Constructor for class org.infinispan.persistence.support.NonBlockingStoreAdapter
- NonBlockingThreadFactory - Class in org.infinispan.factories.threads
- NonBlockingThreadFactory(int, String, String, String) - Constructor for class org.infinispan.factories.threads.NonBlockingThreadFactory
- NonBlockingThreadFactory(String, String, int, String, String, String) - Constructor for class org.infinispan.factories.threads.NonBlockingThreadFactory
- nonBlockingThreadPool() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
- nonBlockingThreadPool() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
- nonBlockingThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfiguration
- nonBlockingThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- nonBlockingThreadPool() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Configuration for the non blocking thread pool
- nonBlockingThreadPool() - Method in class org.infinispan.configuration.global.ThreadsConfiguration
- nonBlockingThreadPool() - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
- NonBlockingThreadPoolExecutorFactory - Class in org.infinispan.factories.threads
-
Executor Factory used for non blocking executors which utilizes
ThreadPoolExecutor
internally. - NonBlockingThreadPoolExecutorFactory(int, int, int, long) - Constructor for class org.infinispan.factories.threads.NonBlockingThreadPoolExecutorFactory
- nonBlockingThreadPoolName() - Method in class org.infinispan.configuration.global.GlobalConfiguration
- nonBlockingThreadPoolName(String) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- nonClusteredDefault() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
- nonClusteredDefault() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
-
Helper method that gets you a default constructed GlobalConfiguration, preconfigured for use in LOCAL mode
- NONE - Enum constant in enum org.infinispan.client.hotrod.configuration.TransactionMode
-
The cache is not transactional
- NONE - Enum constant in enum org.infinispan.configuration.cache.Index
-
Deprecated.No indexing is performed.
- NONE - Enum constant in enum org.infinispan.configuration.cache.IndexStartupMode
-
No mass-indexing operation is triggered at cache startup time.
- NONE - Enum constant in enum org.infinispan.configuration.cache.TransactionMode
- NONE - Enum constant in enum org.infinispan.configuration.cache.VersioningScheme
- NONE - Enum constant in enum org.infinispan.configuration.parsing.CacheParser.TransactionMode
- NONE - Enum constant in enum org.infinispan.conflict.MergePolicy
- NONE - Enum constant in enum org.infinispan.eviction.EvictionStrategy
-
Eviction Strategy where nothing is done by the cache and the user is probably not going to use eviction manually
- NONE - Enum constant in enum org.infinispan.factories.impl.Scopes
-
The component is not cached between requests, but a subclass may be either
GLOBAL
orNAMED_CACHE
. - NONE - Enum constant in enum org.infinispan.factories.scopes.Scopes
-
The component is not cached between requests, but a subclass may be either
GLOBAL
orNAMED_CACHE
. - NONE - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.CompressionType
- NONE - Enum constant in enum org.infinispan.security.AuthorizationPermission
-
No permissions
- NONE - Enum constant in enum org.infinispan.util.concurrent.IsolationLevel
-
No isolation.
- noneMatch(DoublePredicate) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- noneMatch(DoublePredicate) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- noneMatch(IntPredicate) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- noneMatch(IntPredicate) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- noneMatch(LongPredicate) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- noneMatch(LongPredicate) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- noneMatch(Predicate<? super E>) - Static method in class org.infinispan.reactive.publisher.PublisherReducers
- noneMatch(Predicate<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
- noneMatch(Predicate<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- noneMatch(Predicate<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- noneMatch(Predicate<? super T>) - Method in interface org.infinispan.functional.Traversable
-
A terminal operation that returns whether no elements of this traversable match the provided predicate.
- noneMatch(SerializableDoublePredicate) - Method in interface org.infinispan.DoubleCacheStream
-
Same as
DoubleStream.noneMatch(DoublePredicate)
except that the DoublePredicate must also implementSerializable
- noneMatch(SerializableIntPredicate) - Method in interface org.infinispan.IntCacheStream
-
Same as
IntStream.noneMatch(IntPredicate)
except that the IntPredicate must also implementSerializable
- noneMatch(SerializableLongPredicate) - Method in interface org.infinispan.LongCacheStream
-
Same as
LongStream.noneMatch(LongPredicate)
except that the LongPredicate must also implement Serializable. - noneMatch(SerializablePredicate<? super R>) - Method in interface org.infinispan.CacheStream
-
Same as
Stream.noneMatch(Predicate)
except that the Predicate must also implementSerializable
- noneOf(long, long) - Static method in class org.infinispan.commons.util.EnumUtil
- nonExistingVersion() - Method in class org.infinispan.container.versioning.NumericVersionGenerator
- nonExistingVersion() - Method in class org.infinispan.container.versioning.SimpleClusteredVersionGenerator
- nonExistingVersion() - Method in interface org.infinispan.container.versioning.VersionGenerator
- nonNullPredicate() - Static method in class org.infinispan.stream.StreamMarshalling
-
Predicate that returns true if the object passed to it is not null.
- NonRecursiveEventLoopGroup - Class in org.infinispan.server.core.transport
-
This event loop group prevents any tasks submitted via the
Executor.execute(Runnable)
},ExecutorService.submit(Runnable)
,ExecutorService.submit(Callable)
,ExecutorService.submit(Runnable, Object)
API methods from being ran on the same event loop that submitted it. - NonRecursiveEventLoopGroup(MultithreadEventLoopGroup) - Constructor for class org.infinispan.server.core.transport.NonRecursiveEventLoopGroup
- NonReentrantLock - Class in org.infinispan.commons.util.concurrent
-
A simplistic non-reentrant lock that does not use ownership by thread.
- NonReentrantLock() - Constructor for class org.infinispan.commons.util.concurrent.NonReentrantLock
- nonTerminatedNamedParamInSql(int, String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- NonTransactionalInvocationContextFactory - Class in org.infinispan.context.impl
-
Invocation Context container to be used for non-transactional caches.
- NonTransactionalInvocationContextFactory() - Constructor for class org.infinispan.context.impl.NonTransactionalInvocationContextFactory
- NonTxInvocationContext - Class in org.infinispan.context.impl
-
Context to be used for non transactional calls, both remote and local.
- NonTxInvocationContext(int, Address) - Constructor for class org.infinispan.context.impl.NonTxInvocationContext
- NonTxInvocationContext(Address) - Constructor for class org.infinispan.context.impl.NonTxInvocationContext
- noOpenTelemetryAPI() - Method in interface org.infinispan.client.hotrod.logging.Log
- NoOpIracManager - Enum in org.infinispan.xsite.irac
-
A no-op implementation of
IracManager
for cache without asynchronous remote site backups. - NoOpIracTombstoneManager - Class in org.infinispan.container.versioning.irac
-
No-op implementation for
IracTombstoneManager
. - NoOpIracVersionGenerator - Class in org.infinispan.container.versioning.irac
-
A no-op implementation of
IracVersionGenerator
for caches without asynchronous remote site backups. - NoOpJGroupsMetricManager - Class in org.infinispan.remoting.transport.jgroups
-
An empty implementation of
JGroupsMetricsManager
. - NoOpPendingLockManager - Class in org.infinispan.util.concurrent.locks.impl
-
An
PendingLockManager
implementation that does nothing. - NoOpTakeOfflineManager - Class in org.infinispan.xsite.status
-
An empty
TakeOfflineManager
implementation for caches which don't backup any data to remote sites. - NoOpXSiteEventsManager - Class in org.infinispan.xsite.events
-
A no-op implementation of
XSiteEventsManager
. - NoOpXSiteMetricsCollector - Class in org.infinispan.xsite.metrics
-
An no-op implementation for
XSiteMetricsCollector
. - NoOpXSiteStateProvider - Class in org.infinispan.xsite.statetransfer
-
A no-op implementation of
XSiteStateProvider
. - NoOpXSiteStateTransferManager - Class in org.infinispan.xsite.statetransfer
-
A no-op implementation of
XSiteStateTransferManager
. - NoOpXSiteStateTransferManager() - Constructor for class org.infinispan.xsite.statetransfer.NoOpXSiteStateTransferManager
- noPrimaryKeysFoundForTable(String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- noScriptEngineForScript(String) - Method in interface org.infinispan.scripting.logging.Log
- noSniDomainConfigured() - Method in interface org.infinispan.server.core.logging.Log
- noSSLKeyManagerConfiguration() - Method in interface org.infinispan.server.core.logging.Log
- noSSLTrustManagerConfiguration() - Method in interface org.infinispan.client.hotrod.logging.Log
- NoStateExternalizer<T> - Class in org.infinispan.commons.marshall.exts
-
An externalizer that writes no state.
- NoStateExternalizer() - Constructor for class org.infinispan.commons.marshall.exts.NoStateExternalizer
- noSuchScript(String) - Method in interface org.infinispan.rest.logging.Log
- not() - Method in interface org.infinispan.query.dsl.FilterConditionBeginContext
-
Deprecated.
- not() - Method in interface org.infinispan.query.dsl.QueryFactory
-
Deprecated.since 10.1. See deprecation note on
QueryBuilder
. - not(FilterConditionContext) - Method in interface org.infinispan.query.dsl.FilterConditionBeginContext
-
Deprecated.
- not(FilterConditionContext) - Method in interface org.infinispan.query.dsl.QueryFactory
-
Deprecated.since 10.1. See deprecation note on
QueryBuilder
. - NOT_COMPLETED - Enum constant in enum org.infinispan.transaction.impl.TransactionTable.CompletedTransactionStatus
- NOT_FOUND - Enum constant in enum org.infinispan.rest.framework.LookupResult.Status
-
A resource was not found
- NOT_FOUND - Enum constant in enum org.infinispan.server.core.BackupManager.Status
- NOT_FOUND - Enum constant in enum org.infinispan.xsite.status.SiteState
- NOT_FOUND - Static variable in class org.infinispan.marshall.core.GlobalMarshaller
- NOT_FOUND - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- NOT_LOADED - Static variable in class org.infinispan.functional.MetaParam.MetaLoadedFromPersistence
- NOT_LOCAL - Enum constant in enum org.infinispan.distribution.DataLocality
-
Deprecated.
- NOT_LOCAL_UNCERTAIN - Enum constant in enum org.infinispan.distribution.DataLocality
-
Deprecated.
- NOT_OWNED - Enum constant in enum org.infinispan.scattered.ScatteredVersionManager.SegmentState
- NOT_READ - Enum constant in enum org.infinispan.server.hotrod.tx.ControlByte
- NOT_READY - Enum constant in enum org.infinispan.remoting.inboundhandler.action.ActionStatus
-
The action isn't completed yet.
- NOT_STORED - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- notADirectory(String) - Method in interface org.infinispan.rest.logging.Log
- notaHotRodURI(String) - Method in interface org.infinispan.client.hotrod.logging.Log
- NotAllowedException - Exception in org.infinispan.rest.operations.exceptions
- NotAllowedException() - Constructor for exception org.infinispan.rest.operations.exceptions.NotAllowedException
- NoTelemetry() - Constructor for class org.infinispan.server.core.telemetry.TelemetryService.NoTelemetry
- notExecutedResponse(HotRodHeader, HotRodServer, Channel, CacheEntry<byte[], byte[]>) - Method in class org.infinispan.server.hotrod.Encoder4x
- notExecutedResponse(HotRodHeader, HotRodServer, Channel, CacheEntry<byte[], byte[]>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- NotExecutedWithPrevious - Enum constant in enum org.infinispan.server.hotrod.OperationStatus
- NotExecutedWithPreviousObjStorage - Enum constant in enum org.infinispan.server.hotrod.OperationStatus
- notExistResponse(HotRodHeader, HotRodServer, Channel) - Method in class org.infinispan.server.hotrod.Encoder4x
- notExistResponse(HotRodHeader, HotRodServer, Channel) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- notFoundResponse(RestRequest) - Method in class org.infinispan.rest.InvocationHelper
- NOTHING - Static variable in interface org.infinispan.transaction.xa.recovery.RecoveryManager.RecoveryIterator
- NotificationManager - Class in org.infinispan.client.hotrod.counter.impl
-
A Hot Rod client notification manager for a single
CounterManager
. - notifications() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
- notifications(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
- Notifications - Class in org.infinispan.reactive.publisher.impl
- NOTIFICATIONS - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- NOTIFICATIONS - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
- Notifications.NotificationBuilder<R> - Interface in org.infinispan.reactive.publisher.impl
- NOTIFIED - Static variable in interface org.infinispan.notifications.cachelistener.QueueingSegmentListener
- notifier - Variable in class org.infinispan.cache.impl.CacheImpl
- notifier - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- notifyAsyncAck(XSiteAsyncAckListener) - Method in class org.infinispan.remoting.transport.AggregateBackupResponse
- notifyAsyncAck(XSiteAsyncAckListener) - Method in interface org.infinispan.remoting.transport.BackupResponse
-
Invokes
XSiteAsyncAckListener
for each ack received from an asynchronous cross site request. - notifyAsyncAck(XSiteAsyncAckListener) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsBackupResponse
- notifyCacheEntriesEvicted(Collection<Map.Entry<K, V>>, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
-
Notifies all registered listeners of a
CacheEntriesEvictedEvent
event. - notifyCacheEntriesEvicted(Collection<Map.Entry<K, V>>, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- notifyCacheEntryActivated(K, V, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
-
Notifies all registered listeners of a
CacheEntryActivatedEvent
event. - notifyCacheEntryActivated(K, V, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- notifyCacheEntryCreated(K, V, Metadata, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
-
Notifies all registered listeners of a
CacheEntryCreatedEvent
event. - notifyCacheEntryCreated(K, V, Metadata, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- notifyCacheEntryExpired(K, V, Metadata, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
-
Notifies all registered listeners of a CacheEntryExpired event.
- notifyCacheEntryExpired(K, V, Metadata, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- notifyCacheEntryInvalidated(K, V, Metadata, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
-
Notifies all registered listeners of a
CacheEntryInvalidatedEvent
event. - notifyCacheEntryInvalidated(K, V, Metadata, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- notifyCacheEntryLoaded(K, V, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
-
Notifies all registered listeners of a
CacheEntryLoadedEvent
event. - notifyCacheEntryLoaded(K, V, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- notifyCacheEntryModified(K, V, Metadata, V, Metadata, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
-
Notifies all registered listeners of a
CacheEntryModifiedEvent
event. - notifyCacheEntryModified(K, V, Metadata, V, Metadata, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- notifyCacheEntryPassivated(K, V, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
-
Notifies all registered listeners of a
CacheEntryPassivatedEvent
event. - notifyCacheEntryPassivated(K, V, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- notifyCacheEntryRemoved(K, V, Metadata, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
-
Notifies all registered listeners of a
CacheEntryRemovedEvent
event. - notifyCacheEntryRemoved(K, V, Metadata, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- notifyCacheEntryVisited(K, V, boolean, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
-
Notifies all registered listeners of a
CacheEntryVisitedEvent
event. - notifyCacheEntryVisited(K, V, boolean, InvocationContext, FlagAffectedCommand) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- notifyCacheStarted(String) - Method in class org.infinispan.factories.GlobalComponentRegistry
- notifyCacheStarted(String) - Method in interface org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifier
- notifyCacheStarted(String) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
- notifyCacheStopped(String) - Method in interface org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifier
- notifyCacheStopped(String) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
- notifyClusterListeners(Collection<ClusterEvent<K, V>>, UUID) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- notifyClusterListeners(Collection<ClusterEvent<K, V>>, UUID) - Method in interface org.infinispan.notifications.cachelistener.cluster.ClusterCacheNotifier
-
Method that is invoked on the node that has the given cluster listener that when registered generated the given listenerId.
- notifyConfigurationChanged(ConfigurationChangedEvent.EventType, String, String) - Method in interface org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifier
-
Notifies all registered listeners of a configurationChange event.
- notifyConfigurationChanged(ConfigurationChangedEvent.EventType, String, String) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
- notifyCrossSiteViewChanged(Collection<String>, Collection<String>, Collection<String>) - Method in interface org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifier
-
Notifies all registered listeners of a sites view change event
- notifyCrossSiteViewChanged(Collection<String>, Collection<String>, Collection<String>) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
- notifyDataRehashed(ConsistentHash, ConsistentHash, ConsistentHash, int, boolean) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
- notifyDataRehashed(ConsistentHash, ConsistentHash, ConsistentHash, int, boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- notifyFinish(LongConsumer) - Method in class org.infinispan.remoting.transport.AggregateBackupResponse
- notifyFinish(LongConsumer) - Method in interface org.infinispan.remoting.transport.BackupResponse
-
Registers a listener that is notified when the cross-site request is finished.
- notifyFinish(LongConsumer) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsBackupResponse
- NotifyHelper - Class in org.infinispan.notifications.cachelistener
- NotifyHelper() - Constructor for class org.infinispan.notifications.cachelistener.NotifyHelper
- notifyKeyTransferFinished(int, boolean, boolean) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
- notifyKeyTransferFinished(int, boolean, boolean) - Method in interface org.infinispan.scattered.ScatteredVersionManager
-
All key + version data from given segment have been received, or the key transfer failed.
- notifyMerge(List<Address>, List<Address>, Address, int, List<List<Address>>) - Method in interface org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifier
- notifyMerge(List<Address>, List<Address>, Address, int, List<List<Address>>) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
- notifyOnCreate(CacheEntry) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
- notifyOnCreate(CacheEntry<K, V>) - Method in interface org.infinispan.functional.impl.FunctionalNotifier
-
Notify registered
Listeners.ReadWriteListeners.ReadWriteListener
instances of the created entry. - notifyOnModify(CacheEntry<K, V>, V, Metadata) - Method in interface org.infinispan.functional.impl.FunctionalNotifier
-
Notify registered
Listeners.ReadWriteListeners.ReadWriteListener
instances of the modified entry passing the previous and new value. - notifyOnModify(CacheEntry<K, V>, V, Metadata) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
- notifyOnRemove(EntryView.ReadEntryView<K, V>) - Method in interface org.infinispan.functional.impl.FunctionalNotifier
-
Notify registered
Listeners.ReadWriteListeners.ReadWriteListener
instances of the removed entry passing in the removed entry. - notifyOnRemove(EntryView.ReadEntryView<K, V>) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
- notifyOnTransactionFinished() - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
- notifyOnTransactionFinished() - Method in interface org.infinispan.transaction.xa.CacheTransaction
- notifyOnWrite(CacheEntry<K, V>) - Method in interface org.infinispan.functional.impl.FunctionalNotifier
- notifyOnWrite(CacheEntry<K, V>) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
- notifyOnWriteRemove(K) - Method in interface org.infinispan.functional.impl.FunctionalNotifier
-
Notify registered
Listeners.WriteListeners.WriteListener
instances of the written entry. - notifyOnWriteRemove(K) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
- notifyPartitionStatusChanged(AvailabilityMode, boolean) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
- notifyPartitionStatusChanged(AvailabilityMode, boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- notifyPersistenceAvailabilityChanged(boolean) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
- notifyPersistenceAvailabilityChanged(boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- notifyStatePushFinished(String, Address, boolean) - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateTransferManager
- notifyStatePushFinished(String, Address, boolean) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
-
It receives the notifications from local site when some node finishes pushing the state to the remote site.
- notifyStatePushFinished(String, Address, boolean) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
- notifyStateTransferEnd(String, Address, boolean) - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateProvider
- notifyStateTransferEnd(String, Address, boolean) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateProvider
-
Notifies
XSiteStatePushTask
has completed the send. - notifyStateTransferEnd(String, Address, boolean) - Method in class org.infinispan.xsite.statetransfer.XSiteStateProviderImpl
- notifyTopologyChanged(CacheTopology, CacheTopology, int, boolean) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
- notifyTopologyChanged(CacheTopology, CacheTopology, int, boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- notifyTransactionCompleted(GlobalTransaction, boolean, InvocationContext) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
-
Notifies all registered listeners of a transaction completion event.
- notifyTransactionCompleted(GlobalTransaction, boolean, InvocationContext) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- notifyTransactionRegistered(GlobalTransaction, boolean) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
-
Notifies all registered listeners of a transaction registration event.
- notifyTransactionRegistered(GlobalTransaction, boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- notifyValueTransferFinished() - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
- notifyValueTransferFinished() - Method in interface org.infinispan.scattered.ScatteredVersionManager
-
All entries have been received and we can put segments owned according to consistent hash to
ScatteredVersionManager.SegmentState.OWNED
state. - notifyViewChange(List<Address>, List<Address>, Address, int) - Method in interface org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifier
-
Notifies all registered listeners of a viewChange event.
- notifyViewChange(List<Address>, List<Address>, Address, int) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
- notNullCacheEntryPredicate() - Static method in class org.infinispan.filter.CacheFilters
-
Provides a predicate that can be used to filter out null cache entry objects as well as placeholder "null" entries of
NullCacheEntry
that can be returned from methods such asCacheFilters.converterToFunction(KeyValueFilterConverter)
. - noTransactionFound() - Method in class org.infinispan.server.hotrod.tx.operation.CommitTransactionOperation
- noTransactionFound() - Method in interface org.infinispan.server.hotrod.tx.table.CacheNameCollector
-
Notifies that no transaction is found.
- noTransformerForKey(String) - Method in interface org.infinispan.query.logging.Log
- NotSerializableException - Exception in org.infinispan.commons.marshall
-
An exception that hides inner stacktrace lines for non serializable exceptions.
- NotSerializableException(String) - Constructor for exception org.infinispan.commons.marshall.NotSerializableException
- NotSerializableException(String, Throwable) - Constructor for exception org.infinispan.commons.marshall.NotSerializableException
- noTypeIsIndexed(String) - Method in interface org.infinispan.query.logging.Log
- noValue(Object) - Static method in class org.infinispan.functional.impl.EntryViews
- noValue(Object, DataConversion) - Static method in class org.infinispan.functional.impl.EntryViews
- noValueColumnForTable(String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- NoValueReadOnlyViewExternalizer() - Constructor for class org.infinispan.functional.impl.EntryViews.NoValueReadOnlyViewExternalizer
- NULL - Static variable in class org.infinispan.commons.util.NullValue
- NULL_VALUE - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- NULL_VALUE_WRAPPER - Static variable in class org.infinispan.spring.common.provider.SpringCache
- NullAuditLogger - Class in org.infinispan.security.audit
-
NullAuditLogger.
- NullAuditLogger - Class in org.infinispan.security.impl
-
Deprecated, for removal: This API element is subject to removal in a future version.use
NullAuditLogger
instead - NullAuditLogger() - Constructor for class org.infinispan.security.audit.NullAuditLogger
- NullAuditLogger() - Constructor for class org.infinispan.security.impl.NullAuditLogger
-
Deprecated.
- NullCacheEntry<K,
V> - Class in org.infinispan.container.entries - NullValue - Class in org.infinispan.commons.util
-
A placeholder for null in a cache, because caches do not allow null values.
- NullValue$___Marshaller_a83283d4dbbe8b8520f457699d99f19344b973d04786829de1e22c08915e6e56 - Class in org.infinispan.commons.util
-
WARNING: Generated code! Do not edit!
- NullValue$___Marshaller_a83283d4dbbe8b8520f457699d99f19344b973d04786829de1e22c08915e6e56() - Constructor for class org.infinispan.commons.util.NullValue$___Marshaller_a83283d4dbbe8b8520f457699d99f19344b973d04786829de1e22c08915e6e56
- NUM_ABORTED_RO_TX - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_ABORTED_WR_TX - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_ASYNC_COMPLETE_NOTIFY - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_COMMIT_COMMAND - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_COMMITTED_RO_TX - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_COMMITTED_TX - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_COMMITTED_WR_TX - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_GET - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_GETS_RO_TX - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_GETS_WR_TX - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_HELD_LOCKS - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_HELD_LOCKS_SUCCESS_LOCAL_TX - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_LOCAL_COMMITTED_TX - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_LOCK_FAILED_DEADLOCK - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_LOCK_FAILED_TIMEOUT - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_LOCK_PER_LOCAL_TX - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_LOCK_PER_REMOTE_TX - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_NODES_COMMIT - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_NODES_COMPLETE_NOTIFY - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_NODES_GET - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_NODES_PREPARE - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_NODES_ROLLBACK - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_OWNERS - Enum constant in enum org.infinispan.counter.configuration.Attribute
- NUM_OWNERS - Enum constant in enum org.infinispan.lock.configuration.Attribute
- NUM_OWNERS - Static variable in class org.infinispan.configuration.cache.HashConfiguration
- NUM_PREPARE_COMMAND - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_PUT - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_PUTS_WR_TX - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_REMOTE_GET - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_REMOTE_GETS_RO_TX - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_REMOTE_GETS_WR_TX - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_REMOTE_PUT - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_REMOTE_PUTS_WR_TX - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_ROLLBACK_COMMAND - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_SEGMENTS - Static variable in class org.infinispan.configuration.cache.HashConfiguration
- NUM_SYNC_COMMIT - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_SYNC_GET - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_SYNC_PREPARE - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_SYNC_ROLLBACK - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_WAITED_FOR_LOCKS - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- NUM_WRITE_SKEW - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- number(Number) - Method in class org.infinispan.commons.dataconversion.internal.Json.DefaultFactory
- number(Number) - Method in interface org.infinispan.commons.dataconversion.internal.Json.Factory
-
Construct and return a JSON number.
- NUMERIC_VERSION - Static variable in interface org.infinispan.commons.marshall.Ids
- NUMERIC_VERSION - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- NumericVersion - Class in org.infinispan.container.versioning
-
Numeric version
- NumericVersion(long) - Constructor for class org.infinispan.container.versioning.NumericVersion
- NumericVersion.Externalizer - Class in org.infinispan.container.versioning
- NumericVersion$___Marshaller_54e14f07f0b2d32fc02dc14b15442c6b41ee1d50304f1e61ddb56d9feb6975b1 - Class in org.infinispan.container.versioning
-
WARNING: Generated code! Do not edit!
- NumericVersion$___Marshaller_54e14f07f0b2d32fc02dc14b15442c6b41ee1d50304f1e61ddb56d9feb6975b1() - Constructor for class org.infinispan.container.versioning.NumericVersion$___Marshaller_54e14f07f0b2d32fc02dc14b15442c6b41ee1d50304f1e61ddb56d9feb6975b1
- NumericVersionGenerator - Class in org.infinispan.container.versioning
-
Generates unique numeric versions for both local and clustered environments.
- NumericVersionGenerator() - Constructor for class org.infinispan.container.versioning.NumericVersionGenerator
- numOwner(int) - Method in class org.infinispan.counter.configuration.CounterManagerConfigurationBuilder
-
Sets the number of copies of the counter's value available in the cluster.
- numOwner(int) - Method in class org.infinispan.lock.configuration.ClusteredLockManagerConfigurationBuilder
-
Sets the number of copies of the counter's value available in the cluster.
- numOwners() - Method in class org.infinispan.configuration.cache.HashConfiguration
-
Number of cluster-wide replicas for each cache entry.
- numOwners() - Method in class org.infinispan.counter.configuration.CounterManagerConfiguration
- numOwners() - Method in class org.infinispan.lock.configuration.ClusteredLockManagerConfiguration
- numOwners(int) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
-
Number of cluster-wide replicas for each cache entry.
- numRecords - Variable in class org.infinispan.persistence.sifs.EntryInfo
- numSegments - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
- numSegments() - Method in class org.infinispan.configuration.cache.HashConfiguration
-
Controls the total number of hash space segments (per cluster).
- numSegments(int) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
-
Controls the total number of hash space segments (per cluster).
O
- oauthBearerWithoutToken() - Method in interface org.infinispan.client.hotrod.logging.Log
- obj2bytes(Marshaller, Object, boolean, int, int) - Static method in class org.infinispan.client.hotrod.marshall.MarshallerUtil
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 12.0, will be removed in 15.0
- obj2bytes(Marshaller, Object, BufferSizePredictor) - Static method in class org.infinispan.client.hotrod.marshall.MarshallerUtil
- object() - Method in class org.infinispan.commons.dataconversion.internal.Json.DefaultFactory
- object() - Method in interface org.infinispan.commons.dataconversion.internal.Json.Factory
-
Construct and return a JSON object.
- object() - Static method in class org.infinispan.commons.dataconversion.internal.Json
- object(Object...) - Static method in class org.infinispan.commons.dataconversion.internal.Json
-
Return a new JSON object initialized from the passed list of name/value pairs.
- OBJECT - 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, use
StorageType.HEAP
instead. - OBJECT - Enum constant in enum org.infinispan.configuration.parsing.Element
- OBJECT_NAME - Static variable in class org.infinispan.cache.impl.CacheImpl
- OBJECT_NAME - Static variable in interface org.infinispan.health.jmx.HealthJMXExposer
-
JMX Object name.
- OBJECT_NAME - Static variable in class org.infinispan.manager.DefaultCacheManager
- OBJECT_NAME - Static variable in interface org.infinispan.query.remote.client.ProtobufMetadataManagerConstants
-
The 'component' key property of ProtobufMetadataManager's ObjectName.
- OBJECT_NAME - Static variable in class org.infinispan.remoting.rpc.RpcManagerImpl
- OBJECT_NAME - Static variable in interface org.infinispan.stats.CacheContainerStats
-
Deprecated.
- OBJECT_NAME - Static variable in interface org.infinispan.stats.ClusterCacheStats
- OBJECT_NAME - Static variable in interface org.infinispan.stats.ClusterContainerStats
- OBJECT_SIZE - Static variable in class org.infinispan.commons.util.AbstractEntrySizeCalculatorHelper
- objectArray(int) - Static method in class org.infinispan.commons.util.Util
- ObjectDuplicator - Class in org.infinispan.commons.util
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 12, will be removed in version 15.0
- ObjectDuplicator() - Constructor for class org.infinispan.commons.util.ObjectDuplicator
-
Deprecated.
- ObjectFieldMetamodel - Class in org.infinispan.search.mapper.mapping.metamodel
- ObjectFieldMetamodel(boolean, boolean, IndexObjectFieldDescriptor) - Constructor for class org.infinispan.search.mapper.mapping.metamodel.ObjectFieldMetamodel
- ObjectFilter - Interface in org.infinispan.objectfilter
-
A filter that tests if an object matches a pre-defined condition and returns either the original instance or the projection, depending on how the filter was created.
- ObjectFilter.FilterResult - Interface in org.infinispan.objectfilter
-
The output of the
ObjectFilter.filter(java.lang.Object)
method. - objectFromByteBuffer(byte[]) - Method in class org.infinispan.client.hotrod.marshall.BytesOnlyMarshaller
- objectFromByteBuffer(byte[]) - Method in class org.infinispan.commons.marshall.AbstractMarshaller
- objectFromByteBuffer(byte[]) - Method in interface org.infinispan.commons.marshall.Marshaller
-
Unmarshalls an object from a byte array.
- objectFromByteBuffer(byte[]) - Method in class org.infinispan.marshall.core.GlobalMarshaller
- objectFromByteBuffer(byte[]) - Method in class org.infinispan.persistence.remote.wrapper.HotRodEntryMarshaller
-
Deprecated.
- objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.client.hotrod.marshall.BytesOnlyMarshaller
- objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.commons.marshall.IdentityMarshaller
- objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.commons.marshall.ImmutableProtoStreamMarshaller
- objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.commons.marshall.JavaSerializationMarshaller
- objectFromByteBuffer(byte[], int, int) - Method in interface org.infinispan.commons.marshall.Marshaller
-
Unmarshalls an object from a specific portion of a byte array.
- objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.commons.marshall.StringMarshaller
- objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller
- objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.marshall.core.GlobalMarshaller
- objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.persistence.remote.wrapper.HotRodEntryMarshaller
-
Deprecated.
- objectFromInputStream(InputStream) - Method in class org.infinispan.commons.marshall.AbstractMarshaller
-
This method implements
StreamingMarshaller.objectFromInputStream(java.io.InputStream)
, but its implementation has been moved here rather that keeping under a class that implements StreamingMarshaller in order to avoid code duplication. - objectFromInputStream(InputStream) - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
-
Deprecated.Unmarshall an object from an
InputStream
- objectFromInputStream(InputStream) - Method in class org.infinispan.marshall.core.GlobalMarshaller
- objectFromObjectStream(ObjectInput) - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
-
Deprecated.Unmarshalls an object from an
ObjectInput
- objectFromObjectStream(ObjectInput) - Method in class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller
- objectFromObjectStream(ObjectInput) - Method in class org.infinispan.marshall.core.GlobalMarshaller
- objectInput - Variable in class org.infinispan.commons.marshall.DelegatingObjectInput
- ObjectNameKeys - Interface in org.infinispan.jmx
- objectOutput - Variable in class org.infinispan.commons.marshall.DelegatingObjectOutput
- objectToBuffer(Object) - Method in class org.infinispan.client.hotrod.marshall.BytesOnlyMarshaller
- objectToBuffer(Object) - Method in class org.infinispan.commons.marshall.AbstractMarshaller
- objectToBuffer(Object) - Method in interface org.infinispan.commons.marshall.Marshaller
-
A method that returns an instance of
ByteBuffer
, which allows direct access to the byte array with minimal array copying - objectToBuffer(Object) - Method in class org.infinispan.marshall.core.GlobalMarshaller
- objectToBuffer(Object) - Method in class org.infinispan.persistence.remote.wrapper.HotRodEntryMarshaller
-
Deprecated.
- objectToBuffer(Object, int) - Method in class org.infinispan.commons.marshall.AbstractMarshaller
-
This is a convenience method for converting an object into a
ByteBuffer
which takes an estimated size as parameter. - objectToBuffer(Object, int) - Method in class org.infinispan.commons.marshall.IdentityMarshaller
- objectToBuffer(Object, int) - Method in class org.infinispan.commons.marshall.ImmutableProtoStreamMarshaller
- objectToBuffer(Object, int) - Method in class org.infinispan.commons.marshall.JavaSerializationMarshaller
- objectToBuffer(Object, int) - Method in class org.infinispan.commons.marshall.StringMarshaller
- objectToBuffer(Object, int) - Method in class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller
- objectToByteBuffer(Object) - Method in class org.infinispan.client.hotrod.marshall.BytesOnlyMarshaller
- objectToByteBuffer(Object) - Method in class org.infinispan.commons.marshall.AbstractMarshaller
- objectToByteBuffer(Object) - Method in interface org.infinispan.commons.marshall.Marshaller
-
Marshalls an object to a byte array.
- objectToByteBuffer(Object) - Method in class org.infinispan.marshall.core.GlobalMarshaller
- objectToByteBuffer(Object) - Method in class org.infinispan.persistence.remote.wrapper.HotRodEntryMarshaller
-
Deprecated.
- objectToByteBuffer(Object, int) - Method in class org.infinispan.client.hotrod.marshall.BytesOnlyMarshaller
- objectToByteBuffer(Object, int) - Method in class org.infinispan.commons.marshall.AbstractMarshaller
- objectToByteBuffer(Object, int) - Method in interface org.infinispan.commons.marshall.Marshaller
-
Marshalls an object to a byte array.
- objectToByteBuffer(Object, int) - Method in class org.infinispan.marshall.core.GlobalMarshaller
- objectToByteBuffer(Object, int) - Method in class org.infinispan.persistence.remote.wrapper.HotRodEntryMarshaller
-
Deprecated.
- objectToObjectStream(Object, ObjectOutput) - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
-
Deprecated.Marshalls an object to a given
ObjectOutput
- objectToObjectStream(Object, ObjectOutput) - Method in class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller
- objectToObjectStream(Object, ObjectOutput) - Method in class org.infinispan.marshall.core.GlobalMarshaller
- observation - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
- observation() - Element in annotation type org.infinispan.notifications.Listener
-
Returns the type of observation level this listener defines.
- of(boolean) - Static method in class org.infinispan.functional.MetaParam.MetaLoadedFromPersistence
- of(boolean) - Static method in class org.infinispan.functional.MetaParam.MetaUpdateCreationTime
- of(int) - Static method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- of(int...) - Static method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- of(int, int) - Static method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- of(int, int, int) - Static method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- of(Class<?>) - Static method in class org.infinispan.factories.impl.ComponentAlias
- of(Process) - Static method in class org.infinispan.commons.jdkspecific.ProcessInfo
- of(String) - Static method in class org.infinispan.factories.impl.ComponentAlias
- of(String, String, String, Object...) - Static method in class org.infinispan.factories.impl.MBeanMetadata
- of(PrimitiveIterator.OfInt) - Static method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- of(Stream<T>) - Static method in class org.infinispan.functional.impl.Traversables
- of(K, V) - Static method in class org.infinispan.util.KeyValuePair
- of(CacheType, boolean) - Static method in enum org.infinispan.configuration.cache.CacheMode
- OFF_HEAP - Enum constant in enum org.infinispan.configuration.cache.StorageType
-
Entries are stored in internal memory off the normal Java heap.
- OFF_HEAP - Enum constant in enum org.infinispan.configuration.parsing.Element
- OffHeapConcurrentMap - Class in org.infinispan.container.offheap
-
A
ConcurrentMap
implementation that stores the keys and values off the JVM heap in native heap. - OffHeapConcurrentMap(OffHeapMemoryAllocator, OffHeapEntryFactory, OffHeapConcurrentMap.EntryListener) - Constructor for class org.infinispan.container.offheap.OffHeapConcurrentMap
- OffHeapConcurrentMap.EntryListener - Interface in org.infinispan.container.offheap
-
Listener interface that is notified when certain operations occur for various memory addresses.
- OffHeapDataContainer - Class in org.infinispan.container.offheap
- OffHeapDataContainer() - Constructor for class org.infinispan.container.offheap.OffHeapDataContainer
- offHeapEntryFactory - Variable in class org.infinispan.container.offheap.OffHeapDataContainer
- offHeapEntryFactory - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
- OffHeapEntryFactory - Interface in org.infinispan.container.offheap
-
Factory that can create
InternalCacheEntry
objects that use off-heap heap memory. - OffHeapEntryFactoryImpl - Class in org.infinispan.container.offheap
-
Factory that can create CacheEntry instances from off-heap memory.
- OffHeapEntryFactoryImpl() - Constructor for class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
- offHeapEntrySize(boolean, boolean, int, int) - Static method in class org.infinispan.container.offheap.UnpooledOffHeapMemoryAllocator
- offHeapEntrySize(boolean, boolean, int, int, int, int) - Static method in class org.infinispan.container.offheap.UnpooledOffHeapMemoryAllocator
-
It returns the off-heap size of an entry without alignment.
- OffHeapMemoryAllocator - Interface in org.infinispan.container.offheap
-
Allows for allocation of memory outside of the heap as well additional functionality surrounding it if necessary.
- offline - Variable in class org.infinispan.xsite.status.AbstractMixedSiteStatus
- OFFLINE - Enum constant in enum org.infinispan.xsite.status.SiteState
- offlineOn(E) - Method in class org.infinispan.xsite.status.AbstractSiteStatusBuilder
-
Adds the member with an offline connection to the site.
- OfflineSiteStatus - Class in org.infinispan.xsite.status
-
SiteStatus
implementation for offline sites. - offset - Variable in class org.infinispan.persistence.sifs.EntryInfo
- OFFSET - Static variable in interface org.infinispan.query.remote.json.JSONConstants
- OK - Enum constant in enum org.infinispan.server.hotrod.counter.listener.ListenerOperationStatus
-
The operation is completed but it won't use the channel used in the request.
- OK - Enum constant in enum org.infinispan.server.hotrod.tx.table.Status
- OK - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- OK_AND_CHANNEL_IN_USE - Enum constant in enum org.infinispan.server.hotrod.counter.listener.ListenerOperationStatus
-
The operation is completed and it will use (or remove) the channel.
- oldMetadata - Variable in class org.infinispan.container.entries.ReadCommittedEntry
- oldValue - Variable in class org.infinispan.container.entries.ReadCommittedEntry
- ON_DEMAND - Enum constant in enum org.infinispan.rest.configuration.ExtendedHeaders
- ON_READ - Enum constant in enum org.infinispan.configuration.cache.BiasAcquisition
-
Bias is acquired when the entry is read TODO: Not implemented yet
- ON_REHASH - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- ON_WRITE - Enum constant in enum org.infinispan.configuration.cache.BiasAcquisition
-
Bias is acquired by the writing entry.
- onAckReceived(long, String, Throwable) - Method in interface org.infinispan.remoting.transport.XSiteAsyncAckListener
-
Invoked when an ack for an asynchronous request is received.
- onCacheEvent(CacheEntryEvent<?, ?>) - Method in class org.infinispan.rest.resources.CacheResourceV2.BaseCacheListener
- onCacheStarted(CacheStartedEvent) - Method in class org.infinispan.xsite.events.XSiteEventsManagerImpl
- onChannelConnected(JChannel, boolean) - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsMetricsManager
-
Registers metrics for a
JChannel
. - onChannelConnected(JChannel, boolean) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsMetricsManagerImpl
- onChannelConnected(JChannel, boolean) - Method in class org.infinispan.remoting.transport.jgroups.NoOpJGroupsMetricManager
- onChannelDisconnected(JChannel) - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsMetricsManager
-
Unregisters metrics for a
JChannel
. - onChannelDisconnected(JChannel) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsMetricsManagerImpl
- onChannelDisconnected(JChannel) - Method in class org.infinispan.remoting.transport.jgroups.NoOpJGroupsMetricManager
- onClose(Runnable) - Method in interface org.infinispan.CacheStream
- onClose(Runnable) - Method in interface org.infinispan.DoubleCacheStream
- onClose(Runnable) - Method in interface org.infinispan.IntCacheStream
- onClose(Runnable) - Method in interface org.infinispan.LongCacheStream
- onClose(Runnable) - Method in class org.infinispan.stream.impl.AbstractCacheStream
- onClose(Runnable) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- onClose(Runnable) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- onClose(Runnable) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- onClose(Runnable) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- onClose(Runnable) - Method in class org.infinispan.stream.impl.LockedStreamImpl
- onClose(Runnable) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- onClusterViewChange(AvailabilityStrategyContext, List<Address>) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategy
-
Called when the cluster view changed (e.g.
- onClusterViewChange(AvailabilityStrategyContext, List<Address>) - Method in class org.infinispan.partitionhandling.impl.PreferAvailabilityStrategy
- onClusterViewChange(AvailabilityStrategyContext, List<Address>) - Method in class org.infinispan.partitionhandling.impl.PreferConsistencyStrategy
- onComplete() - Method in interface org.infinispan.remoting.inboundhandler.action.ActionListener
-
Invoked when an
Action
is completed. - onComplete() - Method in class org.infinispan.remoting.inboundhandler.action.DefaultReadyAction
- onComplete() - Method in interface org.infinispan.remoting.transport.jgroups.RequestTracker
-
The reply was just received.
- onCompleted(XSiteBackup, long, long, Throwable) - Method in interface org.infinispan.remoting.transport.XSiteResponse.XSiteResponseCompleted
- onCompleted(XSiteBackup, long, long, Throwable) - Method in class org.infinispan.xsite.status.DefaultTakeOfflineManager
- onCompletedSegment(int, InboundTransferTask) - Method in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
- onCompletion() - Method in interface org.infinispan.transaction.xa.CacheTransaction.TransactionCompletedListener
- onConfigurationEvent(ConfigurationChangedEvent) - Method in class org.infinispan.rest.resources.ContainerResource.ConfigurationListener
- onCreate(Consumer<EntryView.ReadEntryView<K, V>>) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
- onCreate(Consumer<EntryView.ReadEntryView<K, V>>) - Method in interface org.infinispan.functional.Listeners.ReadWriteListeners
-
Add a create event specific listener by passing in a
Consumer
to be called back each time a new cache entry is created, passing in aEntryView.ReadEntryView
of that new entry. - onCreate(EntryView.ReadEntryView<K, V>) - Method in interface org.infinispan.functional.Listeners.ReadWriteListeners.ReadWriteListener
-
Entry created event callback that receives a
EntryView.ReadEntryView
of the created entry. - onDataLogged(EventLog) - Method in class org.infinispan.rest.resources.ContainerResource.ConfigurationListener
- ONE_NODE - Enum constant in enum org.infinispan.tasks.TaskExecutionMode
- onEntryActivated(Object) - Method in interface org.infinispan.commons.util.EvictionListener
-
Deprecated.Called back when an entry has been activated
- onEntryChosenForEviction(Map.Entry<K, V>) - Method in interface org.infinispan.commons.util.EvictionListener
-
Deprecated.Called back before an entry is evicted
- onEntryEviction(Map<K, Map.Entry<K, V>>) - Method in interface org.infinispan.eviction.EvictionManager
-
Handles notifications of evicted entries
- onEntryEviction(Map<K, Map.Entry<K, V>>, FlagAffectedCommand) - Method in interface org.infinispan.eviction.EvictionManager
-
Handles notifications of evicted entries based on if the command allow them
- onEntryEviction(Map<K, Map.Entry<K, V>>, FlagAffectedCommand) - Method in class org.infinispan.eviction.impl.EvictionManagerImpl
- onEntryEviction(Map<K, V>) - Method in interface org.infinispan.commons.util.EvictionListener
-
Deprecated.Called back after entries have been evicted
- onEntryRemoved(Map.Entry<K, V>) - Method in interface org.infinispan.commons.util.EvictionListener
-
Deprecated.Called when an entry is specifically removed from the container.
- onePhaseCommitRemoteTransaction(GlobalTransaction, List<WriteCommand>) - Method in class org.infinispan.server.hotrod.tx.PrepareCoordinator
-
Commits a remote 1PC transaction that is already in MARK_COMMIT state
- OneToManyTranscoder - Class in org.infinispan.commons.dataconversion
-
Base class for
Transcoder
that converts between a single format and multiple other formats and back. - OneToManyTranscoder(MediaType, MediaType...) - Constructor for class org.infinispan.commons.dataconversion.OneToManyTranscoder
- onEvent(Object, LockState) - Method in interface org.infinispan.util.concurrent.locks.KeyAwareLockListener
-
Invoked when the lock is available.
- onEvent(LockState) - Method in interface org.infinispan.util.concurrent.locks.LockListener
-
Invoked when the lock is available.
- onException() - Method in class org.infinispan.remoting.inboundhandler.action.DefaultReadyAction
- onException() - Method in interface org.infinispan.remoting.inboundhandler.action.ReadyAction
-
Cleanup when the command throws an exception while executing.
- onException(ActionState) - Method in interface org.infinispan.remoting.inboundhandler.action.Action
-
Invoked when an exception occurs while processing the command.
- onFilterResult(Object, Object, Object, Object[], Comparable[]) - Method in interface org.infinispan.objectfilter.FilterCallback
-
Receives notification that an instance matches the filter.
- onFinally() - Method in class org.infinispan.remoting.inboundhandler.action.DefaultReadyAction
- onFinally() - Method in interface org.infinispan.remoting.inboundhandler.action.ReadyAction
-
Invoked always after the command is executed and the reply is sent.
- onFinally(ActionState) - Method in interface org.infinispan.remoting.inboundhandler.action.Action
-
Invoked always after the command is executed.
- onFinally(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.TriangleOrderAction
- onGracefulLeave(AvailabilityStrategyContext, Address) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategy
-
Called when a node leaves gracefully.
- onGracefulLeave(AvailabilityStrategyContext, Address) - Method in class org.infinispan.partitionhandling.impl.PreferAvailabilityStrategy
- onGracefulLeave(AvailabilityStrategyContext, Address) - Method in class org.infinispan.partitionhandling.impl.PreferConsistencyStrategy
- onJoin(AvailabilityStrategyContext, Address) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategy
-
Called when a node joins.
- onJoin(AvailabilityStrategyContext, Address) - Method in class org.infinispan.partitionhandling.impl.PreferAvailabilityStrategy
- onJoin(AvailabilityStrategyContext, Address) - Method in class org.infinispan.partitionhandling.impl.PreferConsistencyStrategy
- online - Variable in class org.infinispan.xsite.status.AbstractMixedSiteStatus
- ONLINE - Enum constant in enum org.infinispan.xsite.status.SiteState
- onlineOn(E) - Method in class org.infinispan.xsite.status.AbstractSiteStatusBuilder
-
Adds the element with an online connection to the site.
- OnlineSiteStatus - Class in org.infinispan.xsite.status
-
SiteStatus
implementation for online sites. - onLocalEvents(List<XSiteEvent>) - Method in class org.infinispan.xsite.events.NoOpXSiteEventsManager
- onLocalEvents(List<XSiteEvent>) - Method in interface org.infinispan.xsite.events.XSiteEventsManager
-
Handles a list of
XSiteEvent
from another node in the local site. - onLocalEvents(List<XSiteEvent>) - Method in class org.infinispan.xsite.events.XSiteEventsManagerImpl
- onlyPrimary - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
- onManualAvailabilityChange(AvailabilityStrategyContext, AvailabilityMode) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategy
-
Called when the administrator manually changes the availability status.
- onManualAvailabilityChange(AvailabilityStrategyContext, AvailabilityMode) - Method in class org.infinispan.partitionhandling.impl.PreferAvailabilityStrategy
- onManualAvailabilityChange(AvailabilityStrategyContext, AvailabilityMode) - Method in class org.infinispan.partitionhandling.impl.PreferConsistencyStrategy
- onMembersChange(Collection<Address>) - Method in class org.infinispan.util.concurrent.CommandAckCollector
-
Notifies a change in member list.
- onModify(BiConsumer<EntryView.ReadEntryView<K, V>, EntryView.ReadEntryView<K, V>>) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
- onModify(BiConsumer<EntryView.ReadEntryView<K, V>, EntryView.ReadEntryView<K, V>>) - Method in interface org.infinispan.functional.Listeners.ReadWriteListeners
-
Add a modify/update event specific listener by passing in a
BiConsumer
to be called back each time an entry is modified or updated, passing in aEntryView.ReadEntryView
of the previous entry as first parameter, and aEntryView.ReadEntryView
of the new value as second parameter. - onModify(EntryView.ReadEntryView<K, V>, EntryView.ReadEntryView<K, V>) - Method in interface org.infinispan.functional.Listeners.ReadWriteListeners.ReadWriteListener
-
Entry modify/update event callback that receives
EntryView.ReadEntryView
of the previous entry as first parameter, and theEntryView.ReadEntryView
of the new entry. - onNewView(Set<Address>) - Method in class org.infinispan.remoting.transport.impl.MultiTargetRequest
- onNewView(Set<Address>) - Method in interface org.infinispan.remoting.transport.impl.Request
-
Called when the node received a new cluster view.
- onNewView(Set<Address>) - Method in class org.infinispan.remoting.transport.impl.SingleTargetRequest
- onNewView(Set<Address>) - Method in class org.infinispan.remoting.transport.jgroups.SingleSiteRequest
- onNext(Output) - Method in class org.infinispan.commons.reactive.AbstractAsyncPublisherHandler
-
Method that should be called for each emitted output value.
- onPartitionMerge(AvailabilityStrategyContext, Map<Address, CacheStatusResponse>) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategy
-
Called when two or more partitions merge, to compute the stable and current cache topologies for the merged cluster.
- onPartitionMerge(AvailabilityStrategyContext, Map<Address, CacheStatusResponse>) - Method in class org.infinispan.partitionhandling.impl.PreferAvailabilityStrategy
- onPartitionMerge(AvailabilityStrategyContext, Map<Address, CacheStatusResponse>) - Method in class org.infinispan.partitionhandling.impl.PreferConsistencyStrategy
- onPrepareCommand() - Method in class org.infinispan.extendedstats.LocalTransactionStatistics
- onPrepareCommand() - Method in class org.infinispan.extendedstats.RemoteTransactionStatistics
- onPrepareCommand() - Method in class org.infinispan.extendedstats.TransactionStatistics
-
Signals the reception of the
PrepareCommand
. - onPrepareCommand(GlobalTransaction, boolean) - Method in class org.infinispan.extendedstats.CacheStatisticManager
-
Invoked when a
PrepareCommand
is received for a transaction. - onReady() - Method in interface org.infinispan.util.concurrent.locks.PendingLockListener
-
Invoked when
PendingLockPromise
is ready. - onRebalanceEnd(AvailabilityStrategyContext) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategy
-
Called when a rebalance ends.
- onRebalanceEnd(AvailabilityStrategyContext) - Method in class org.infinispan.partitionhandling.impl.PreferAvailabilityStrategy
- onRebalanceEnd(AvailabilityStrategyContext) - Method in class org.infinispan.partitionhandling.impl.PreferConsistencyStrategy
- onRemoteEvents(List<XSiteEvent>) - Method in class org.infinispan.xsite.events.NoOpXSiteEventsManager
- onRemoteEvents(List<XSiteEvent>) - Method in interface org.infinispan.xsite.events.XSiteEventsManager
-
Handles a list of
XSiteEvent
from another site. - onRemoteEvents(List<XSiteEvent>) - Method in class org.infinispan.xsite.events.XSiteEventsManagerImpl
- onRemove(Consumer<EntryView.ReadEntryView<K, V>>) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
- onRemove(Consumer<EntryView.ReadEntryView<K, V>>) - Method in interface org.infinispan.functional.Listeners.ReadWriteListeners
-
Add a remove event specific listener by passing in a
Consumer
to be called back each time an entry is removed, passing in theEntryView.ReadEntryView
of the removed entry. - onRemove(EntryView.ReadEntryView<K, V>) - Method in interface org.infinispan.functional.Listeners.ReadWriteListeners.ReadWriteListener
-
Entry removed event callback that receives a
EntryView.ReadEntryView
of the removed entry. - onResponse(Address, Response) - Method in class org.infinispan.remoting.transport.impl.MultiTargetRequest
- onResponse(Address, Response) - Method in interface org.infinispan.remoting.transport.impl.Request
-
Called when a response is received for this response.
- onResponse(Address, Response) - Method in class org.infinispan.remoting.transport.impl.SingleTargetRequest
- onResponse(Address, Response) - Method in class org.infinispan.remoting.transport.jgroups.SingleSiteRequest
- onResponse(Address, Response) - Method in class org.infinispan.remoting.transport.jgroups.StaggeredRequest
- onResponseCompleted(IracBatchSendResult, Collection<IracManagerKeyState>) - Method in interface org.infinispan.xsite.irac.IracResponseCollector.IracResponseCompleted
- onSiteViewChanged(SitesViewChangedEvent) - Method in class org.infinispan.xsite.events.XSiteEventsManagerImpl
- onTaskCompletion(InboundTransferTask) - Method in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
- onTimeout() - Method in class org.infinispan.remoting.transport.AbstractRequest
-
Called when the timeout task scheduled with
AbstractRequest.setTimeout(ScheduledExecutorService, long, TimeUnit)
expires. - onTimeout() - Method in class org.infinispan.remoting.transport.impl.MultiTargetRequest
- onTimeout() - Method in class org.infinispan.remoting.transport.impl.SingleTargetRequest
- onTimeout() - Method in interface org.infinispan.remoting.transport.jgroups.RequestTracker
-
The request timed-out before receiving the reply.
- onTimeout() - Method in class org.infinispan.remoting.transport.jgroups.SingleSiteRequest
- onTimeout() - Method in class org.infinispan.remoting.transport.jgroups.StaggeredRequest
- onTopologyChange(TopologyChangedEvent) - Method in class org.infinispan.scattered.impl.BiasManagerImpl
- onTopologyChange(TopologyChangedEvent<?, ?>) - Method in class org.infinispan.container.versioning.SimpleClusteredVersionGenerator.TopologyIdUpdater
- onTopologyChange(TopologyChangedEvent<?, ?>) - Method in class org.infinispan.transaction.impl.TransactionTable
- onTopologyChange(CacheTopology) - Method in class org.infinispan.container.versioning.irac.DefaultIracVersionGenerator
- onTopologyChange(CacheTopology) - Method in interface org.infinispan.container.versioning.irac.IracVersionGenerator
-
Invoked when a topology change occurs in the cluster.
- onTopologyChange(CacheTopology) - Method in class org.infinispan.container.versioning.irac.NoOpIracVersionGenerator
- onTopologyUpdate(CacheTopology) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
- onTopologyUpdate(CacheTopology) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
-
Notifies the
PartitionHandlingManager
that the cache topology was update. - onTopologyUpdate(CacheTopology) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
- onTopologyUpdate(CacheTopology, boolean) - Method in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
- onTopologyUpdate(CacheTopology, boolean) - Method in class org.infinispan.scattered.impl.ScatteredStateProviderImpl
- onTopologyUpdate(CacheTopology, CacheTopology) - Method in class org.infinispan.xsite.irac.DefaultIracManager
- onTopologyUpdate(CacheTopology, CacheTopology) - Method in interface org.infinispan.xsite.irac.IracManager
-
Notifies a topology changed.
- onTopologyUpdate(CacheTopology, CacheTopology) - Method in enum org.infinispan.xsite.irac.NoOpIracManager
- onTopologyUpdated(CacheTopology, boolean) - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateTransferManager
- onTopologyUpdated(CacheTopology, boolean) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
-
Notifies
XSiteStateTransferManager
that a newCacheTopology
is installed and if the local cluster state transfer is in progress (or about to start) - onTopologyUpdated(CacheTopology, boolean) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
- onUpdate(CounterEvent) - Method in interface org.infinispan.counter.api.CounterListener
- onViewChange(ViewChangedEvent) - Method in class org.infinispan.transaction.impl.TransactionTable
- onViewChanged(ViewChangedEvent) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsMetricsManagerImpl
- onWrite(Consumer<EntryView.ReadEntryView<K, V>>) - Method in class org.infinispan.functional.impl.FunctionalNotifierImpl
- onWrite(Consumer<EntryView.ReadEntryView<K, V>>) - Method in interface org.infinispan.functional.Listeners.WriteListeners
-
Add a write event listener by passing in a
Consumer
to be called each time a cache entry is created, modified/updated or removed. - onWrite(EntryView.ReadEntryView<K, V>) - Method in interface org.infinispan.functional.Listeners.WriteListeners.WriteListener
-
Entry write event callback that receives a
EntryView.ReadEntryView
of the written entry. - open() - Method in class org.infinispan.util.concurrent.ReclosableLatch
- OPEN_FILES_LIMIT - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- OPEN_FILES_LIMIT - Static variable in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfiguration
- openChannel(int) - Method in class org.infinispan.persistence.sifs.FileProvider
- openChannel(File, boolean, boolean) - Method in class org.infinispan.persistence.sifs.FileProvider
- openConnection(URL) - Method in class org.infinispan.commons.maven.MavenSettings
-
Opens a connection with appropriate proxy and credentials, if required.
- openDatabase(Path, Options) - Static method in class org.infinispan.persistence.rocksdb.RocksDBStore
-
Creates database if it doesn't exist.
- openFilesLimit() - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfiguration
-
The maximum number of files that will be open at a given time for all the data and index files, which does not include compactor and current log file (which will always be 2).
- openFilesLimit(int) - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
-
Sets the maximum number of open files.
- openPublishers() - Method in class org.infinispan.reactive.publisher.impl.PublisherHandler
-
Returns how many publishers are currently open
- openTelemetryPropagationDisabled() - Method in interface org.infinispan.client.hotrod.logging.Log
- openTelemetryPropagationEnabled() - Method in interface org.infinispan.client.hotrod.logging.Log
- OpenTelemetryService - Class in org.infinispan.server.core.telemetry.impl
- OpenTelemetryService(OpenTelemetry) - Constructor for class org.infinispan.server.core.telemetry.impl.OpenTelemetryService
- OPERATION_HOTROD - Enum constant in enum org.infinispan.context.Flag
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 10.0, not in use.
- OPERATION_HOTROD - Static variable in class org.infinispan.context.impl.FlagBitSets
-
Deprecated, for removal: This API element is subject to removal in a future version.
- OPERATION_MEMCACHED - Enum constant in enum org.infinispan.context.Flag
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 10.0, not in use.
- OPERATION_MEMCACHED - Static variable in class org.infinispan.context.impl.FlagBitSets
-
Deprecated, for removal: This API element is subject to removal in a future version.
- OPERATION_READ_TIMEOUT - Static variable in class org.infinispan.spring.remote.ConfigurationPropertiesOverrides
- OPERATION_WRITE_TIMEOUT - Static variable in class org.infinispan.spring.remote.ConfigurationPropertiesOverrides
- operationComplete(Future<? super Void>) - Method in class org.infinispan.server.hotrod.iteration.IterationReaper
- operationIsNotAddClientListener(long, String) - Method in interface org.infinispan.client.hotrod.logging.Log
- OperationMetadata(String, String, String, String, MBeanMetadata.OperationParameterMetadata...) - Constructor for class org.infinispan.factories.impl.MBeanMetadata.OperationMetadata
- OperationNotExecuted - Enum constant in enum org.infinispan.server.hotrod.OperationStatus
- OperationParameterMetadata(String, String, String) - Constructor for class org.infinispan.factories.impl.MBeanMetadata.OperationParameterMetadata
- operationsFactory - Variable in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- OperationStatus - Enum in org.infinispan.server.hotrod
-
Hot Rod operation possible status outcomes.
- OperationTimedOut - Enum constant in enum org.infinispan.server.hotrod.OperationStatus
- OPTIMISTIC - Enum constant in enum org.infinispan.transaction.LockingMode
- optional(Map<String, String>) - Method in enum org.infinispan.server.core.admin.AdminOperationParameter
- OPTIONAL - Static variable in interface org.infinispan.commons.marshall.Ids
- optionalArray(ByteBuf) - Static method in class org.infinispan.server.hotrod.Intrinsics
- OptionalExternalizer - Class in org.infinispan.marshall.exts
- OptionalExternalizer() - Constructor for class org.infinispan.marshall.exts.OptionalExternalizer
- optionalModules() - Element in annotation type org.infinispan.factories.annotations.InfinispanModule
-
The set of optional dependencies (module names).
- optionalString(ByteBuf) - Static method in class org.infinispan.server.hotrod.Intrinsics
- OPTIONS - Enum constant in enum org.infinispan.rest.framework.Method
- or() - Method in interface org.infinispan.query.dsl.FilterConditionContext
-
Deprecated.Creates a new context and connects it with the current one using boolean OR.
- or() - Static method in class org.infinispan.reactive.publisher.PublisherReducers
- or(FilterConditionContext) - Method in interface org.infinispan.query.dsl.FilterConditionContext
-
Deprecated.Connects a given context with the current one using boolean OR.
- ORACLE - Enum constant in enum org.infinispan.persistence.jdbc.common.DatabaseType
- ORACLE_XE - Enum constant in enum org.infinispan.persistence.jdbc.common.DatabaseType
- orBooleanAggregateCompletionStage() - Static method in class org.infinispan.util.concurrent.CompletionStages
- orderBy(String) - Method in interface org.infinispan.query.dsl.QueryBuilder
-
Deprecated.
- orderBy(String, SortOrder) - Method in interface org.infinispan.query.dsl.QueryBuilder
-
Deprecated.
- orderBy(Expression) - Method in interface org.infinispan.query.dsl.QueryBuilder
-
Deprecated.
- orderBy(Expression, SortOrder) - Method in interface org.infinispan.query.dsl.QueryBuilder
-
Deprecated.
- orderer - Variable in class org.infinispan.container.impl.AbstractInternalDataContainer
- orderer - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
- orderOn(Object, CompletionStage<DataOperationOrderer.Operation>) - Method in class org.infinispan.util.concurrent.DataOperationOrderer
-
Registers the provided Stage to be next in line to do an operation on behalf of the provided key.
- orderOnKey(Object, Callable<? extends CompletionStage<T>>) - Method in class org.infinispan.util.concurrent.ActionSequencer
- orderOnKeys(Collection<?>, Callable<? extends CompletionStage<T>>) - Method in class org.infinispan.util.concurrent.ActionSequencer
-
It order a non-blocking action.
- orElse(T) - Method in class org.infinispan.commons.configuration.attributes.Attribute
- org.infinispan - package org.infinispan
-
This is the core of Infinispan, a distributed, transactional, highly scalable data grid platform.
- org.infinispan.affinity - package org.infinispan.affinity
-
This package contains the
KeyAffinityService
interfaces which allow user code to determine mapping of keys onto nodes - org.infinispan.affinity.impl - package org.infinispan.affinity.impl
- org.infinispan.batch - package org.infinispan.batch
-
Support for batching calls using the
BatchingCache.startBatch()
andBatchingCache.endBatch(boolean)
API. - org.infinispan.cache.impl - package org.infinispan.cache.impl
- org.infinispan.client.hotrod - package org.infinispan.client.hotrod
-
Hot Rod client API.
- org.infinispan.client.hotrod.annotation - package org.infinispan.client.hotrod.annotation
-
Hot Rod client annotations.
- org.infinispan.client.hotrod.configuration - package org.infinispan.client.hotrod.configuration
-
Hot Rod client configuration API.
- org.infinispan.client.hotrod.counter.impl - package org.infinispan.client.hotrod.counter.impl
- org.infinispan.client.hotrod.counter.operation - package org.infinispan.client.hotrod.counter.operation
- org.infinispan.client.hotrod.event - package org.infinispan.client.hotrod.event
-
Hot Rod client remote event API.
- org.infinispan.client.hotrod.event.impl - package org.infinispan.client.hotrod.event.impl
- org.infinispan.client.hotrod.exceptions - package org.infinispan.client.hotrod.exceptions
-
Hot Rod client exceptions.
- org.infinispan.client.hotrod.filter - package org.infinispan.client.hotrod.filter
- org.infinispan.client.hotrod.impl - package org.infinispan.client.hotrod.impl
- org.infinispan.client.hotrod.jmx - package org.infinispan.client.hotrod.jmx
- org.infinispan.client.hotrod.logging - package org.infinispan.client.hotrod.logging
- org.infinispan.client.hotrod.marshall - package org.infinispan.client.hotrod.marshall
- org.infinispan.client.hotrod.multimap - package org.infinispan.client.hotrod.multimap
- org.infinispan.client.hotrod.near - package org.infinispan.client.hotrod.near
- org.infinispan.client.hotrod.security - package org.infinispan.client.hotrod.security
- org.infinispan.client.hotrod.telemetry.impl - package org.infinispan.client.hotrod.telemetry.impl
- org.infinispan.client.hotrod.transaction.lookup - package org.infinispan.client.hotrod.transaction.lookup
- org.infinispan.client.hotrod.transaction.manager - package org.infinispan.client.hotrod.transaction.manager
- org.infinispan.commands - package org.infinispan.commands
-
Commands that operate on the cache, either locally or remotely.
- org.infinispan.commons - package org.infinispan.commons
-
Commons package
- org.infinispan.commons.api - package org.infinispan.commons.api
-
Commons API package
- org.infinispan.commons.configuration - package org.infinispan.commons.configuration
-
Commons Configuration package
- org.infinispan.commons.configuration.attributes - package org.infinispan.commons.configuration.attributes
- org.infinispan.commons.configuration.io - package org.infinispan.commons.configuration.io
- org.infinispan.commons.configuration.io.json - package org.infinispan.commons.configuration.io.json
- org.infinispan.commons.configuration.io.xml - package org.infinispan.commons.configuration.io.xml
- org.infinispan.commons.configuration.io.yaml - package org.infinispan.commons.configuration.io.yaml
- org.infinispan.commons.dataconversion - package org.infinispan.commons.dataconversion
- org.infinispan.commons.dataconversion.internal - package org.infinispan.commons.dataconversion.internal
- org.infinispan.commons.executors - package org.infinispan.commons.executors
-
Commons Executors package
- org.infinispan.commons.hash - package org.infinispan.commons.hash
-
Commons Hash package
- org.infinispan.commons.internal - package org.infinispan.commons.internal
- org.infinispan.commons.io - package org.infinispan.commons.io
-
Commons IO package
- org.infinispan.commons.jdkspecific - package org.infinispan.commons.jdkspecific
- org.infinispan.commons.jmx - package org.infinispan.commons.jmx
-
Pluggable lookup for MBeanServer.
- org.infinispan.commons.logging - package org.infinispan.commons.logging
- org.infinispan.commons.marshall - package org.infinispan.commons.marshall
-
Provides Infinispan-specific input and output streams, buffers and related utilities.
- org.infinispan.commons.marshall.exts - package org.infinispan.commons.marshall.exts
-
Provides Infinispan-specific extensions to the marshallers.
- org.infinispan.commons.maven - package org.infinispan.commons.maven
- org.infinispan.commons.persistence - package org.infinispan.commons.persistence
- org.infinispan.commons.reactive - package org.infinispan.commons.reactive
- org.infinispan.commons.stat - package org.infinispan.commons.stat
- org.infinispan.commons.time - package org.infinispan.commons.time
- org.infinispan.commons.tx - package org.infinispan.commons.tx
- org.infinispan.commons.tx.lookup - package org.infinispan.commons.tx.lookup
- org.infinispan.commons.util - package org.infinispan.commons.util
-
Commons package providing various utility classes
- org.infinispan.commons.util.concurrent - package org.infinispan.commons.util.concurrent
-
Provides commons interfaces and classes related to concurrency
- org.infinispan.commons.util.logging - package org.infinispan.commons.util.logging
- org.infinispan.configuration - package org.infinispan.configuration
- org.infinispan.configuration.cache - package org.infinispan.configuration.cache
-
Cache
configuration - org.infinispan.configuration.format - package org.infinispan.configuration.format
- org.infinispan.configuration.global - package org.infinispan.configuration.global
-
EmbeddedCacheManager
configuration - org.infinispan.configuration.parsing - package org.infinispan.configuration.parsing
- org.infinispan.configuration.serializing - package org.infinispan.configuration.serializing
- org.infinispan.conflict - package org.infinispan.conflict
-
This package contains the APIs that enable users to search for, and amend, data inconsistencies within their cache.
- org.infinispan.container - package org.infinispan.container
-
Package that contains the interface describing the underlyling API for storage in Infinispan
- org.infinispan.container.entries - package org.infinispan.container.entries
-
Entries which are stored in data containers.
- org.infinispan.container.entries.metadata - package org.infinispan.container.entries.metadata
- org.infinispan.container.entries.versioned - package org.infinispan.container.entries.versioned
- org.infinispan.container.impl - package org.infinispan.container.impl
-
Data containers which store cache entries.
- org.infinispan.container.offheap - package org.infinispan.container.offheap
- org.infinispan.container.versioning - package org.infinispan.container.versioning
- org.infinispan.container.versioning.irac - package org.infinispan.container.versioning.irac
- org.infinispan.context - package org.infinispan.context
-
Contexts contain information of a specific invocation on the cache, such as its origins, scope (transactional or non-transactional), as well as invocation-specific flags.
- org.infinispan.context.impl - package org.infinispan.context.impl
-
This package contains different context implementations, selected dynamically based on the type of invocation.
- org.infinispan.counter - package org.infinispan.counter
- org.infinispan.counter.api - package org.infinispan.counter.api
-
Clustered Counters API.
- org.infinispan.counter.configuration - package org.infinispan.counter.configuration
- org.infinispan.counter.exception - package org.infinispan.counter.exception
-
Clustered Counters Exceptions.
- org.infinispan.counter.impl - package org.infinispan.counter.impl
- org.infinispan.counter.logging - package org.infinispan.counter.logging
- org.infinispan.counter.util - package org.infinispan.counter.util
- org.infinispan.distribution - package org.infinispan.distribution
-
Classes relating to the distributed cache mode.
- org.infinispan.distribution.ch - package org.infinispan.distribution.ch
-
Consistent Hash interfaces
- org.infinispan.distribution.ch.impl - package org.infinispan.distribution.ch.impl
- org.infinispan.distribution.group - package org.infinispan.distribution.group
-
Groups allow keys with differeing hash codes to be co-located on the same node.
- org.infinispan.distribution.group.impl - package org.infinispan.distribution.group.impl
- org.infinispan.distribution.impl - package org.infinispan.distribution.impl
- org.infinispan.distribution.topologyaware - package org.infinispan.distribution.topologyaware
- org.infinispan.distribution.util - package org.infinispan.distribution.util
- org.infinispan.encoding - package org.infinispan.encoding
- org.infinispan.encoding.impl - package org.infinispan.encoding.impl
- org.infinispan.eviction - package org.infinispan.eviction
-
Classes related to eviction.
- org.infinispan.eviction.impl - package org.infinispan.eviction.impl
- org.infinispan.executors - package org.infinispan.executors
-
Implementations of different executors used for asynchronous operation.
- org.infinispan.expiration - package org.infinispan.expiration
-
Cache expiration.
- org.infinispan.expiration.impl - package org.infinispan.expiration.impl
- org.infinispan.extendedstats - package org.infinispan.extendedstats
-
Infinispan Extended Statistics.
- org.infinispan.extendedstats.container - package org.infinispan.extendedstats.container
- org.infinispan.extendedstats.logging - package org.infinispan.extendedstats.logging
- org.infinispan.extendedstats.percentiles - package org.infinispan.extendedstats.percentiles
- org.infinispan.extendedstats.topK - package org.infinispan.extendedstats.topK
- org.infinispan.extendedstats.wrappers - package org.infinispan.extendedstats.wrappers
- org.infinispan.external - package org.infinispan.external
- org.infinispan.factories - package org.infinispan.factories
-
Factories are internal components used to create other components based on a cache's configuration.
- org.infinispan.factories.annotations - package org.infinispan.factories.annotations
-
Internal annotations to control the lifecycle of cache components.
- org.infinispan.factories.impl - package org.infinispan.factories.impl
- org.infinispan.factories.scopes - package org.infinispan.factories.scopes
-
Scopes of components within the lifespan of a cache manager and its caches, and related utilities.
- org.infinispan.factories.threads - package org.infinispan.factories.threads
- org.infinispan.filter - package org.infinispan.filter
-
Provides capabilities around filtering and converting entries that are found in the cache or cache store/loader.
- org.infinispan.functional - package org.infinispan.functional
-
Functional API package
- org.infinispan.functional.impl - package org.infinispan.functional.impl
- org.infinispan.globalstate - package org.infinispan.globalstate
-
Global configuration state.
- org.infinispan.globalstate.impl - package org.infinispan.globalstate.impl
- org.infinispan.health - package org.infinispan.health
- org.infinispan.health.impl - package org.infinispan.health.impl
- org.infinispan.health.jmx - package org.infinispan.health.jmx
- org.infinispan.interceptors - package org.infinispan.interceptors
-
Infinispan is designed around a set of interceptors around a data container.
- org.infinispan.io - package org.infinispan.io
-
Provides Infinispan-specific input and output streams, buffers and related utilities.
- org.infinispan.jboss.marshalling - package org.infinispan.jboss.marshalling
- org.infinispan.jboss.marshalling.commons - package org.infinispan.jboss.marshalling.commons
-
Hooks to bridge Infinispan's marshalling APIs with JBoss Marshalling internals.
- org.infinispan.jboss.marshalling.core - package org.infinispan.jboss.marshalling.core
- org.infinispan.jboss.marshalling.dataconversion - package org.infinispan.jboss.marshalling.dataconversion
- org.infinispan.jmx - package org.infinispan.jmx
-
Helpers that allow easy exposure of attributes and operations via JMX.
- org.infinispan.lifecycle - package org.infinispan.lifecycle
-
Module and component lifecycle.
- org.infinispan.lock - package org.infinispan.lock
-
Embedded Clustered Locks.
- org.infinispan.lock.api - package org.infinispan.lock.api
-
Clustered Locks API.
- org.infinispan.lock.configuration - package org.infinispan.lock.configuration
- org.infinispan.lock.exception - package org.infinispan.lock.exception
-
Clustered Locks Exceptions.
- org.infinispan.lock.impl - package org.infinispan.lock.impl
- org.infinispan.lock.logging - package org.infinispan.lock.logging
- org.infinispan.manager - package org.infinispan.manager
-
Cache manager API.
- org.infinispan.manager.impl - package org.infinispan.manager.impl
- org.infinispan.marshall.core - package org.infinispan.marshall.core
- org.infinispan.marshall.exts - package org.infinispan.marshall.exts
-
Externalizers for various JDK types that are marshalled using the marshalling framework.
- org.infinispan.marshall.persistence - package org.infinispan.marshall.persistence
- org.infinispan.metadata - package org.infinispan.metadata
-
Metadata interfaces
- org.infinispan.metadata.impl - package org.infinispan.metadata.impl
- org.infinispan.metrics - package org.infinispan.metrics
-
Micrometer based metrics.
- org.infinispan.metrics.config - package org.infinispan.metrics.config
- org.infinispan.multimap.api - package org.infinispan.multimap.api
-
MultimapCache API.
- org.infinispan.multimap.api.embedded - package org.infinispan.multimap.api.embedded
-
Embedded Multimap Cache.
- org.infinispan.multimap.impl - package org.infinispan.multimap.impl
- org.infinispan.notifications - package org.infinispan.notifications
-
Notifications and eventing for listeners on both the Cache and CacheManager interfaces.
- org.infinispan.notifications.cachelistener - package org.infinispan.notifications.cachelistener
-
Cache
-specific notifications and eventing. - org.infinispan.notifications.cachelistener.annotation - package org.infinispan.notifications.cachelistener.annotation
-
Cache
-specific listener annotations - org.infinispan.notifications.cachelistener.cluster - package org.infinispan.notifications.cachelistener.cluster
- org.infinispan.notifications.cachelistener.cluster.impl - package org.infinispan.notifications.cachelistener.cluster.impl
- org.infinispan.notifications.cachelistener.event - package org.infinispan.notifications.cachelistener.event
-
Cache
-specific listener events - org.infinispan.notifications.cachelistener.event.impl - package org.infinispan.notifications.cachelistener.event.impl
- org.infinispan.notifications.cachelistener.filter - package org.infinispan.notifications.cachelistener.filter
-
Cache
-specific notifications and eventing filtering classes. - org.infinispan.notifications.cachemanagerlistener - package org.infinispan.notifications.cachemanagerlistener
-
CacheManager
-specific notifications and eventing. - org.infinispan.notifications.cachemanagerlistener.annotation - package org.infinispan.notifications.cachemanagerlistener.annotation
-
EmbeddedCacheManager
-specific listener annotations - org.infinispan.notifications.cachemanagerlistener.event - package org.infinispan.notifications.cachemanagerlistener.event
-
EmbeddedCacheManager
-specific listener events - org.infinispan.notifications.cachemanagerlistener.event.impl - package org.infinispan.notifications.cachemanagerlistener.event.impl
- org.infinispan.notifications.impl - package org.infinispan.notifications.impl
- org.infinispan.objectfilter - package org.infinispan.objectfilter
-
Querying on plain Java objects.
- org.infinispan.partitionhandling - package org.infinispan.partitionhandling
- org.infinispan.partitionhandling.impl - package org.infinispan.partitionhandling.impl
- org.infinispan.persistence - package org.infinispan.persistence
-
Persistence API.
- org.infinispan.persistence.async - package org.infinispan.persistence.async
- org.infinispan.persistence.cluster - package org.infinispan.persistence.cluster
-
A
CacheLoader
(notCacheWriter
) that polls other nodes in the cluster for state. - org.infinispan.persistence.file - package org.infinispan.persistence.file
-
Simple filesystem-based
CacheWriter
implementation. - org.infinispan.persistence.internal - package org.infinispan.persistence.internal
- org.infinispan.persistence.jdbc - package org.infinispan.persistence.jdbc
-
This package contains a
AdvancedLoadWriteStore
implementation based on a JDBC database connection. - org.infinispan.persistence.jdbc.common - package org.infinispan.persistence.jdbc.common
-
This package contains a
AdvancedLoadWriteStore
implementation based on a JDBC database connection. - org.infinispan.persistence.jdbc.common.configuration - package org.infinispan.persistence.jdbc.common.configuration
-
Common configuration for JDBC cache stores.
- org.infinispan.persistence.jdbc.common.connectionfactory - package org.infinispan.persistence.jdbc.common.connectionfactory
- org.infinispan.persistence.jdbc.common.impl - package org.infinispan.persistence.jdbc.common.impl
- org.infinispan.persistence.jdbc.common.logging - package org.infinispan.persistence.jdbc.common.logging
- org.infinispan.persistence.jdbc.common.sql - package org.infinispan.persistence.jdbc.common.sql
- org.infinispan.persistence.jdbc.configuration - package org.infinispan.persistence.jdbc.configuration
-
Configuration for the JDBC CacheStore.
- org.infinispan.persistence.jdbc.impl - package org.infinispan.persistence.jdbc.impl
- org.infinispan.persistence.jdbc.stringbased - package org.infinispan.persistence.jdbc.stringbased
-
JDBC CacheStore implementation which maps keys to strings.
- org.infinispan.persistence.keymappers - package org.infinispan.persistence.keymappers
- org.infinispan.persistence.modifications - package org.infinispan.persistence.modifications
-
Modifications that are used to encapsulate cache operations for application to a
CacheStore
. - org.infinispan.persistence.remote - package org.infinispan.persistence.remote
-
Hot Rod-based
AdvancedLoadWriteStore
. - org.infinispan.persistence.remote.configuration - package org.infinispan.persistence.remote.configuration
-
Configuration for
RemoteStore
. - org.infinispan.persistence.remote.internal - package org.infinispan.persistence.remote.internal
- org.infinispan.persistence.remote.logging - package org.infinispan.persistence.remote.logging
- org.infinispan.persistence.remote.upgrade - package org.infinispan.persistence.remote.upgrade
- org.infinispan.persistence.remote.wrapper - package org.infinispan.persistence.remote.wrapper
- org.infinispan.persistence.rocksdb - package org.infinispan.persistence.rocksdb
-
RocksDB-based
AdvancedLoadWriteStore
. - org.infinispan.persistence.rocksdb.configuration - package org.infinispan.persistence.rocksdb.configuration
-
Configuration for
RocksDBStore
. - org.infinispan.persistence.rocksdb.internal - package org.infinispan.persistence.rocksdb.internal
- org.infinispan.persistence.rocksdb.logging - package org.infinispan.persistence.rocksdb.logging
- org.infinispan.persistence.sifs - package org.infinispan.persistence.sifs
-
Soft Index
AdvancedLoadWriteStore
. - org.infinispan.persistence.sifs.configuration - package org.infinispan.persistence.sifs.configuration
-
Configuration for
org.infinispan.persistence.sifs.SoftIndexFileStore
. - org.infinispan.persistence.sifs.pmem - package org.infinispan.persistence.sifs.pmem
- org.infinispan.persistence.spi - package org.infinispan.persistence.spi
-
The Persistence SPI.
- org.infinispan.persistence.sql - package org.infinispan.persistence.sql
-
This package contains a
AdvancedLoadWriteStore
implementation based on a JDBC database connection. - org.infinispan.persistence.sql.configuration - package org.infinispan.persistence.sql.configuration
- org.infinispan.persistence.support - package org.infinispan.persistence.support
- org.infinispan.persistence.util - package org.infinispan.persistence.util
- org.infinispan.query - package org.infinispan.query
-
Query API that lets you perform Ickle queries and look up values in caches.
- org.infinispan.query.api.continuous - package org.infinispan.query.api.continuous
-
Continuous querying API.
- org.infinispan.query.dsl - package org.infinispan.query.dsl
-
Query DSL API.
- org.infinispan.query.impl - package org.infinispan.query.impl
-
Query module internals.
- org.infinispan.query.internal - package org.infinispan.query.internal
- org.infinispan.query.logging - package org.infinispan.query.logging
- org.infinispan.query.remote - package org.infinispan.query.remote
-
Server-side remote query components.
- org.infinispan.query.remote.client - package org.infinispan.query.remote.client
-
Query client support classes.
- org.infinispan.query.remote.json - package org.infinispan.query.remote.json
- org.infinispan.query.stats.impl - package org.infinispan.query.stats.impl
- org.infinispan.reactive - package org.infinispan.reactive
- org.infinispan.reactive.publisher - package org.infinispan.reactive.publisher
- org.infinispan.reactive.publisher.impl - package org.infinispan.reactive.publisher.impl
- org.infinispan.registry.impl - package org.infinispan.registry.impl
- org.infinispan.remoting - package org.infinispan.remoting
-
Remote communication between cache instances.
- org.infinispan.remoting.inboundhandler.action - package org.infinispan.remoting.inboundhandler.action
- org.infinispan.remoting.responses - package org.infinispan.remoting.responses
-
Abstractions of the different response types allowed during RPC.
- org.infinispan.remoting.rpc - package org.infinispan.remoting.rpc
-
Remote Procedure Call (RPC) interfaces and components used to invoke remote methods on cache instances.
- org.infinispan.remoting.transport - package org.infinispan.remoting.transport
-
Transports handle the low-level networking, used by the remoting components.
- org.infinispan.remoting.transport.impl - package org.infinispan.remoting.transport.impl
- org.infinispan.remoting.transport.jgroups - package org.infinispan.remoting.transport.jgroups
-
A transport implementation based on JGroups.
- org.infinispan.rest - package org.infinispan.rest
-
REST Server bootstrap and Netty bridge classes.
- org.infinispan.rest.authentication - package org.infinispan.rest.authentication
-
Authentication API for REST.
- org.infinispan.rest.authentication.impl - package org.infinispan.rest.authentication.impl
- org.infinispan.rest.cachemanager.exceptions - package org.infinispan.rest.cachemanager.exceptions
- org.infinispan.rest.configuration - package org.infinispan.rest.configuration
-
REST Server Configuration API
- org.infinispan.rest.distribution - package org.infinispan.rest.distribution
- org.infinispan.rest.framework - package org.infinispan.rest.framework
- org.infinispan.rest.framework.impl - package org.infinispan.rest.framework.impl
- org.infinispan.rest.logging - package org.infinispan.rest.logging
- org.infinispan.rest.operations.exceptions - package org.infinispan.rest.operations.exceptions
- org.infinispan.rest.operations.mediatypes - package org.infinispan.rest.operations.mediatypes
- org.infinispan.rest.resources - package org.infinispan.rest.resources
- org.infinispan.rest.stream - package org.infinispan.rest.stream
- org.infinispan.rest.tracing - package org.infinispan.rest.tracing
- org.infinispan.scattered - package org.infinispan.scattered
-
SCATTERED CACHE DESIGN
- org.infinispan.scattered.impl - package org.infinispan.scattered.impl
- org.infinispan.scripting - package org.infinispan.scripting
- org.infinispan.scripting.logging - package org.infinispan.scripting.logging
- org.infinispan.scripting.utils - package org.infinispan.scripting.utils
- org.infinispan.search.mapper.common - package org.infinispan.search.mapper.common
- org.infinispan.search.mapper.common.impl - package org.infinispan.search.mapper.common.impl
- org.infinispan.search.mapper.impl - package org.infinispan.search.mapper.impl
- org.infinispan.search.mapper.log.impl - package org.infinispan.search.mapper.log.impl
- org.infinispan.search.mapper.mapping - package org.infinispan.search.mapper.mapping
- org.infinispan.search.mapper.mapping.impl - package org.infinispan.search.mapper.mapping.impl
- org.infinispan.search.mapper.mapping.metamodel - package org.infinispan.search.mapper.mapping.metamodel
- org.infinispan.search.mapper.model.impl - package org.infinispan.search.mapper.model.impl
- org.infinispan.search.mapper.scope - package org.infinispan.search.mapper.scope
- org.infinispan.search.mapper.scope.impl - package org.infinispan.search.mapper.scope.impl
- org.infinispan.search.mapper.search.loading.context.impl - package org.infinispan.search.mapper.search.loading.context.impl
- org.infinispan.search.mapper.session - package org.infinispan.search.mapper.session
- org.infinispan.search.mapper.session.impl - package org.infinispan.search.mapper.session.impl
- org.infinispan.search.mapper.work - package org.infinispan.search.mapper.work
- org.infinispan.search.mapper.work.impl - package org.infinispan.search.mapper.work.impl
- org.infinispan.security - package org.infinispan.security
-
Security API.
- org.infinispan.security.actions - package org.infinispan.security.actions
- org.infinispan.security.audit - package org.infinispan.security.audit
- org.infinispan.security.impl - package org.infinispan.security.impl
- org.infinispan.security.mappers - package org.infinispan.security.mappers
- org.infinispan.server.core - package org.infinispan.server.core
- org.infinispan.server.core.admin - package org.infinispan.server.core.admin
- org.infinispan.server.core.admin.embeddedserver - package org.infinispan.server.core.admin.embeddedserver
- org.infinispan.server.core.backup - package org.infinispan.server.core.backup
- org.infinispan.server.core.backup.resources - package org.infinispan.server.core.backup.resources
- org.infinispan.server.core.configuration - package org.infinispan.server.core.configuration
-
Core Server Configuration API
- org.infinispan.server.core.dataconversion - package org.infinispan.server.core.dataconversion
- org.infinispan.server.core.dataconversion.json - package org.infinispan.server.core.dataconversion.json
- org.infinispan.server.core.dataconversion.xml - package org.infinispan.server.core.dataconversion.xml
- org.infinispan.server.core.factories - package org.infinispan.server.core.factories
- org.infinispan.server.core.logging - package org.infinispan.server.core.logging
- org.infinispan.server.core.security - package org.infinispan.server.core.security
- org.infinispan.server.core.security.external - package org.infinispan.server.core.security.external
- org.infinispan.server.core.security.simple - package org.infinispan.server.core.security.simple
- org.infinispan.server.core.telemetry - package org.infinispan.server.core.telemetry
- org.infinispan.server.core.telemetry.impl - package org.infinispan.server.core.telemetry.impl
- org.infinispan.server.core.transport - package org.infinispan.server.core.transport
- org.infinispan.server.core.utils - package org.infinispan.server.core.utils
- org.infinispan.server.hotrod - package org.infinispan.server.hotrod
- org.infinispan.server.hotrod.command - package org.infinispan.server.hotrod.command
- org.infinispan.server.hotrod.command.tx - package org.infinispan.server.hotrod.command.tx
- org.infinispan.server.hotrod.configuration - package org.infinispan.server.hotrod.configuration
-
HotRod Server Configuration API
- org.infinispan.server.hotrod.counter.listener - package org.infinispan.server.hotrod.counter.listener
- org.infinispan.server.hotrod.event - package org.infinispan.server.hotrod.event
- org.infinispan.server.hotrod.iteration - package org.infinispan.server.hotrod.iteration
- org.infinispan.server.hotrod.logging - package org.infinispan.server.hotrod.logging
- org.infinispan.server.hotrod.tracing - package org.infinispan.server.hotrod.tracing
- org.infinispan.server.hotrod.transport - package org.infinispan.server.hotrod.transport
- org.infinispan.server.hotrod.tx - package org.infinispan.server.hotrod.tx
- org.infinispan.server.hotrod.tx.operation - package org.infinispan.server.hotrod.tx.operation
- org.infinispan.server.hotrod.tx.table - package org.infinispan.server.hotrod.tx.table
- org.infinispan.server.hotrod.tx.table.functions - package org.infinispan.server.hotrod.tx.table.functions
- org.infinispan.server.memcached - package org.infinispan.server.memcached
- org.infinispan.server.memcached.configuration - package org.infinispan.server.memcached.configuration
-
Memcached Server Configuration API
- org.infinispan.server.memcached.logging - package org.infinispan.server.memcached.logging
- org.infinispan.spring.common - package org.infinispan.spring.common
-
Spring Infinispan - Shared classes.
- org.infinispan.spring.common.config - package org.infinispan.spring.common.config
- org.infinispan.spring.common.provider - package org.infinispan.spring.common.provider
-
Spring Infinispan - An implementation of Spring's Cache SPI based on JBoss Infinispan.
- org.infinispan.spring.common.session - package org.infinispan.spring.common.session
- org.infinispan.spring.embedded - package org.infinispan.spring.embedded
- org.infinispan.spring.embedded.provider - package org.infinispan.spring.embedded.provider
- org.infinispan.spring.embedded.session - package org.infinispan.spring.embedded.session
- org.infinispan.spring.embedded.session.configuration - package org.infinispan.spring.embedded.session.configuration
- org.infinispan.spring.embedded.support - package org.infinispan.spring.embedded.support
- org.infinispan.spring.remote - package org.infinispan.spring.remote
- org.infinispan.spring.remote.provider - package org.infinispan.spring.remote.provider
- org.infinispan.spring.remote.session - package org.infinispan.spring.remote.session
- org.infinispan.spring.remote.session.configuration - package org.infinispan.spring.remote.session.configuration
- org.infinispan.spring.remote.support - package org.infinispan.spring.remote.support
- org.infinispan.stats - package org.infinispan.stats
-
Cache statistics.
- org.infinispan.stats.impl - package org.infinispan.stats.impl
- org.infinispan.stream - package org.infinispan.stream
-
Cache stream processing.
- org.infinispan.stream.impl - package org.infinispan.stream.impl
- org.infinispan.tasks - package org.infinispan.tasks
-
Server tasks API.
- org.infinispan.topology - package org.infinispan.topology
- org.infinispan.transaction - package org.infinispan.transaction
-
JTA transaction support.
- org.infinispan.transaction.impl - package org.infinispan.transaction.impl
- org.infinispan.transaction.lookup - package org.infinispan.transaction.lookup
-
Interfaces and implementations of lookup classes to locate and/or instantiate JTA
TransactionManager
s. - org.infinispan.transaction.synchronization - package org.infinispan.transaction.synchronization
- org.infinispan.transaction.tm - package org.infinispan.transaction.tm
-
Infinispan's bare-bones internal transaction manager, used for batching calls as well as as a dummy, unit-test-only transaction manager.
- org.infinispan.transaction.xa - package org.infinispan.transaction.xa
-
XA transaction support.
- org.infinispan.transaction.xa.recovery - package org.infinispan.transaction.xa.recovery
- org.infinispan.upgrade - package org.infinispan.upgrade
- org.infinispan.util - package org.infinispan.util
-
General utilities that are not specific to Infinispan, including string parsing helpers, reflection tools and collections and containers designed to supplement the JDK-provided containers.
- org.infinispan.util.concurrent - package org.infinispan.util.concurrent
-
Thread-safe containers and other concurrency-related utilities, designed to supplement JDK concurrency utilities and containers.
- org.infinispan.util.concurrent.locks - package org.infinispan.util.concurrent.locks
-
Lock and synchronization related classes, tools and utilities.
- org.infinispan.util.concurrent.locks.impl - package org.infinispan.util.concurrent.locks.impl
- org.infinispan.util.function - package org.infinispan.util.function
- org.infinispan.util.logging - package org.infinispan.util.logging
-
Infinispan's logging abstractions that delegate to either JDK or Log4J logging engines.
- org.infinispan.util.stream - package org.infinispan.util.stream
- org.infinispan.xsite.commands - package org.infinispan.xsite.commands
- org.infinispan.xsite.commands.remote - package org.infinispan.xsite.commands.remote
- org.infinispan.xsite.events - package org.infinispan.xsite.events
- org.infinispan.xsite.irac - package org.infinispan.xsite.irac
- org.infinispan.xsite.metrics - package org.infinispan.xsite.metrics
- org.infinispan.xsite.notification - package org.infinispan.xsite.notification
- org.infinispan.xsite.response - package org.infinispan.xsite.response
- org.infinispan.xsite.spi - package org.infinispan.xsite.spi
-
Cross-Site Replication conflict resolution.
- org.infinispan.xsite.statetransfer - package org.infinispan.xsite.statetransfer
- org.infinispan.xsite.status - package org.infinispan.xsite.status
- OS - Enum in org.infinispan.commons.util
-
Operating system family.
- OTHER_THAN_FIRST_OR_LAST - Enum constant in enum org.infinispan.configuration.cache.InterceptorConfiguration.Position
-
Specifies that the new interceptor can be placed anywhere, except first or last.
- OUTBOUND_SOCKET_BINDING - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- outcomeOnUnexistingTransaction(String, String) - Method in interface org.infinispan.extendedstats.logging.Log
- outdent() - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- OVERLAY - Enum constant in enum org.infinispan.globalstate.ConfigurationStorage
-
Persists cache configurations to the
GlobalStateConfiguration.persistentLocation()
in a - OVERLAY_CONFIGURATION_STORAGE - Enum constant in enum org.infinispan.configuration.parsing.Element
- OverlayLocalConfigurationStorage - Class in org.infinispan.globalstate.impl
-
An implementation of
LocalConfigurationStorage
which stores non-CacheContainerAdmin.AdminFlag.VOLATILE
- OverlayLocalConfigurationStorage() - Constructor for class org.infinispan.globalstate.impl.OverlayLocalConfigurationStorage
- override(Properties) - Method in class org.infinispan.spring.remote.ConfigurationPropertiesOverrides
- OVERRIDE - Enum constant in enum org.infinispan.commons.configuration.Combine.Attributes
- OVERRIDE - Enum constant in enum org.infinispan.commons.configuration.Combine.RepeatedAttributes
- overrideMarshaller(Marshaller) - Method in class org.infinispan.commons.dataconversion.BinaryTranscoder
-
Deprecated.
- overrideWrapper(Class<? extends Wrapper>, ComponentRegistry) - Method in class org.infinispan.encoding.DataConversion
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 11.0, will be removed with no replacement
- overrideWrapper(Wrapper, Wrapper) - Method in class org.infinispan.encoding.impl.StorageConfigurationManager
- overviewReport() - Method in class org.infinispan.server.core.BaseServerManagement
- overviewReport() - Method in interface org.infinispan.server.core.ServerManagement
- OWNED - Enum constant in enum org.infinispan.scattered.ScatteredVersionManager.SegmentState
- OWNER - Enum constant in enum org.infinispan.commands.VisitableCommand.LoadType
-
In non-transactional cache, load previous value on both primary and backups.
- OWNERS - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- ownersConsistentHash(CacheTopology, ConsistentHashFactory) - Static method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategy
-
Compute the read consistent hash for a topology with a
null
union consistent hash. - Ownership - Enum in org.infinispan.distribution
- OwnershipLevel - Enum in org.infinispan.lock.api
-
Ownership level is a configuration parameter for
ClusteredLock
. - OwnershipStatistics - Class in org.infinispan.distribution.ch.impl
-
This class holds statistics about a consistent hash.
- OwnershipStatistics(List<Address>) - Constructor for class org.infinispan.distribution.ch.impl.OwnershipStatistics
- OwnershipStatistics(ConsistentHash) - Constructor for class org.infinispan.distribution.ch.impl.OwnershipStatistics
- OwnershipStatistics(ConsistentHash, List<Address>) - Constructor for class org.infinispan.distribution.ch.impl.OwnershipStatistics
- OwnershipStatistics(OwnershipStatistics) - Constructor for class org.infinispan.distribution.ch.impl.OwnershipStatistics
- ownsLock(Object) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
- ownsLock(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
- ownsLock(Object, Object) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticLockManager
- ownsLock(Object, Object) - Method in class org.infinispan.extendedstats.wrappers.TopKeyLockManager
- ownsLock(Object, Object) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
- ownsLock(Object, Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
-
Tests if the
lockOwner
owns a lock on thekey
.
P
- PACKAGE - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
- PACKAGE - Static variable in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfiguration
- packageName() - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfiguration
- packageName(String) - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfigurationBuilder
-
Sets the package name to be used when determining which schemas are used with
SchemaJdbcConfigurationBuilder.messageName(String)
andSchemaJdbcConfigurationBuilder.keyMessageName(String)
. - pad(String) - Method in class org.infinispan.commons.dataconversion.internal.Json
-
Json-pad this object as an argument to a callback function.
- padString(String, int) - Static method in class org.infinispan.commons.util.Util
- PaginationContext<Context extends PaginationContext> - Interface in org.infinispan.query.dsl
-
Deprecated.since 10.1. See deprecation note on
QueryBuilder
. - parallel - Variable in class org.infinispan.stream.impl.AbstractCacheStream
- parallel() - Method in interface org.infinispan.CacheStream
- parallel() - Method in interface org.infinispan.DoubleCacheStream
- parallel() - Method in interface org.infinispan.IntCacheStream
- parallel() - Method in interface org.infinispan.LongCacheStream
- parallel() - Method in class org.infinispan.stream.impl.AbstractCacheStream
- parallel() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- parallel() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- parallel() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- parallel() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- parallel() - Method in class org.infinispan.stream.impl.LockedStreamImpl
- parallel() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- parallelDistribution - Variable in class org.infinispan.stream.impl.AbstractCacheStream
- parallelDistribution() - Method in interface org.infinispan.BaseCacheStream
-
This would enable sending requests to all other remote nodes when a terminal operator is performed.
- parallelDistribution() - Method in interface org.infinispan.CacheStream
- parallelDistribution() - Method in interface org.infinispan.DoubleCacheStream
- parallelDistribution() - Method in interface org.infinispan.IntCacheStream
- parallelDistribution() - Method in interface org.infinispan.LockedStream
-
This would enable sending requests to all other remote nodes when a terminal operator is performed.
- parallelDistribution() - Method in interface org.infinispan.LongCacheStream
- parallelDistribution() - Method in class org.infinispan.stream.impl.DistributedCacheStream
- parallelDistribution() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- parallelDistribution() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- parallelDistribution() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- parallelDistribution() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- parallelDistribution() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- parallelDistribution() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- parallelDistribution() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- parallelDistribution() - Method in class org.infinispan.stream.impl.LockedStreamImpl
- parallelDistribution() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- parallelizePublisher(IntSet, Scheduler, IntFunction<Publisher<R>>) - Static method in class org.infinispan.persistence.internal.PersistenceUtil
- parallelizePublisher(IntSet, Executor, IntFunction<Publisher<R>>) - Static method in class org.infinispan.persistence.PersistenceUtil
-
Will create a publisher that parallelizes each publisher returned from the publisherFunction by executing them on the executor as needed.
- ParallelOperationException - Exception in org.infinispan.client.hotrod.exceptions
- ParallelOperationException(String) - Constructor for exception org.infinispan.client.hotrod.exceptions.ParallelOperationException
- ParallelOperationException(String, Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.ParallelOperationException
- ParallelOperationException(Throwable) - Constructor for exception org.infinispan.client.hotrod.exceptions.ParallelOperationException
- parallelStream() - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
- parallelStream() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntrySet
- parallelStream() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySet
- parallelStream() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.KeySet
- parallelStream() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.Values
- parallelStream() - Method in interface org.infinispan.CacheCollection
- parallelStream() - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
- parallelStream() - Method in interface org.infinispan.commons.util.CloseableIteratorCollection
- parallelStream() - Method in class org.infinispan.InternalCacheSet
- parallelStream() - Method in class org.infinispan.util.CacheSetMapper
- parallelStream() - Method in class org.infinispan.util.CollectionMapper
- parallelStream() - Method in class org.infinispan.util.WriteableCacheCollectionMapper
- param(String) - Static method in interface org.infinispan.query.dsl.Expression
-
Deprecated.
- Param<P> - Interface in org.infinispan.functional
-
An easily extensible parameter that allows functional map operations to be tweaked.
- Param.ExecutionMode - Enum in org.infinispan.functional
-
Defines where is the command executed.
- Param.LockingMode - Enum in org.infinispan.functional
-
Normally the cache has to acquire locks during any write operation to guarantee its correctness.
- Param.PersistenceMode - Enum in org.infinispan.functional
-
When a persistence store is attached to a cache, by default all write operations, regardless of whether they are inserts, updates or removes, are persisted to the store.
- Param.ReplicationMode - Enum in org.infinispan.functional
- Param.StatisticsMode - Enum in org.infinispan.functional
-
Defines how statistics are gathered for this command.
- ParameterContext<Context extends ParameterContext> - Interface in org.infinispan.query.dsl
-
Deprecated.since 10.1. See deprecation note on
QueryBuilder
. - parameters() - Method in interface org.infinispan.rest.framework.RestRequest
- parameters() - Method in class org.infinispan.rest.NettyRestRequest
- parameters(Map<String, ?>) - Method in class org.infinispan.tasks.TaskContext
-
A map of named parameters that will be passed to the task.
- parametersNotArray() - Method in interface org.infinispan.scripting.logging.Log
- ParamIds - Class in org.infinispan.functional
-
Parameter identifiers.
- ParamKeyValueFilterConverterFactory<K,
V, C> - Interface in org.infinispan.filter -
Factory for
KeyValueFilterConverter
instances supporting parameters. - params - Variable in class org.infinispan.functional.impl.ReadWriteMapImpl
- params - Variable in class org.infinispan.server.core.backup.resources.CounterResource
- params - Variable in class org.infinispan.server.memcached.MemcachedDecoder
- Params - Class in org.infinispan.functional.impl
-
Internal class that encapsulates collection of parameters used to tweak functional map operations.
- parse(InputStream, ConfigurationResourceResolver, MediaType) - Method in class org.infinispan.configuration.parsing.ParserRegistry
-
Parses the supplied
InputStream
returning a newConfigurationBuilderHolder
- parse(InputStream, MediaType) - Method in class org.infinispan.configuration.parsing.ParserRegistry
-
Parses the supplied
InputStream
returning a newConfigurationBuilderHolder
. - parse(InputStream, ConfigurationBuilderHolder, ConfigurationResourceResolver, MediaType) - Method in class org.infinispan.configuration.parsing.ParserRegistry
- parse(Class, String) - Method in interface org.infinispan.commons.configuration.attributes.AttributeParser
- parse(String) - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
- parse(String) - Static method in class org.infinispan.commons.dataconversion.MediaType
-
Deprecated, for removal: This API element is subject to removal in a future version.replaced by
MediaType.fromString(java.lang.String)
- parse(String) - Static method in class org.infinispan.commons.util.ByteQuantity
-
Parses the byte quantity representation composed of a number plus a unit.
- parse(String) - Method in class org.infinispan.configuration.parsing.ParserRegistry
- parse(String, MediaType) - Method in class org.infinispan.configuration.parsing.ParserRegistry
- parse(URL) - Method in class org.infinispan.configuration.parsing.ParserRegistry
- parse(URL, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.ParserRegistry
- parse(Path) - Method in class org.infinispan.configuration.parsing.ParserRegistry
- parse(ConfigurationReader, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.ParserRegistry
- parseAttribute() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- parseAttribute(ConfigurationReader, int, ConfigurationBuilderHolder) - Method in interface org.infinispan.configuration.parsing.NamespaceMappingParser
-
Handle a namespaced attribute
- parseAttribute(ConfigurationReader, int, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.ParserRegistry
- parseAttributes(ConfigurationReader, Builder<?>) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- parseBoolean(String) - Static method in class org.infinispan.commons.util.Util
- parseBoolean(ConfigurationReader, int, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- parseBoundedQueueThreadPool(ConfigurationReader, ConfigurationBuilderHolder, String, boolean) - Method in class org.infinispan.configuration.parsing.Parser
- parseBytes(String) - Static method in enum org.infinispan.commons.util.MemoryUnit
-
Deprecated.
- parseCacheElement(ConfigurationReader, Element, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.CacheParser
- parseCapacityFactors(ScopedPersistentState) - Static method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
- parseCDSect(boolean) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- parseComment() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- parseConfigurations(InputStream) - Method in class org.infinispan.counter.configuration.CounterConfigurationParser
-
Reads a list of counter's configuration from an
InputStream
. - parseConnectionPoolAttributes(ConfigurationReader, PooledConnectionFactoryConfigurationBuilder<?>) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationParser
- Parsed(int) - Constructor for class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader.Parsed
- parseDataSourceAttributes(ConfigurationReader, ManagedConnectionFactoryConfigurationBuilder<?>) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationParser
- ParsedCacheMode - Enum in org.infinispan.configuration.parsing
- parsedConfigToConfig(AbstractCounterConfiguration) - Static method in class org.infinispan.counter.configuration.ConvertUtil
- parseDistributedCache(ConfigurationReader, ConfigurationBuilderHolder, String, boolean) - Method in class org.infinispan.configuration.parsing.CacheParser
- parseDocdecl() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- parseElement(ConfigurationReader, ConfigurationBuilderHolder) - Method in interface org.infinispan.configuration.parsing.NamespaceMappingParser
-
Recursively parses the current element of an XML stream using an appropriate
ConfigurationParser
depending on the element's namespace. - parseElement(ConfigurationReader, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.ParserRegistry
- parseEndTag() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- parseEntityRef() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- parseEnum(Class<T>, String) - Static method in class org.infinispan.commons.util.Util
- parseEnum(ConfigurationReader, int, Class<T>, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- parseEpilog() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- ParseError - Enum constant in enum org.infinispan.server.hotrod.OperationStatus
- parseErrorServerAddress(String) - Method in interface org.infinispan.client.hotrod.logging.Log
- parseFile(File) - Method in class org.infinispan.configuration.parsing.ParserRegistry
- parseFile(String) - Method in class org.infinispan.configuration.parsing.ParserRegistry
- parseFileStore(ConfigurationReader, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.CacheParser
- parseHashFunction(ScopedPersistentState) - Static method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
- parseInnerBeanDefinition(Element, ParserContext) - Static method in class org.infinispan.spring.common.config.InfinispanNamespaceUtils
- parseInt(ConfigurationReader, int, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- parseInternal(Element, ParserContext) - Method in class org.infinispan.spring.common.config.InfinispanContainerCacheManagerBeanDefinitionParser
- parseInternal(Element, ParserContext) - Method in class org.infinispan.spring.common.config.InfinispanEmbeddedCacheManagerBeanDefinitionParser
- parseInternal(Element, ParserContext) - Method in class org.infinispan.spring.common.config.InfinispanRemoteCacheManagerBeanDefinitionParser
- parseInvalidationCache(ConfigurationReader, ConfigurationBuilderHolder, String, boolean) - Method in class org.infinispan.configuration.parsing.CacheParser
- parseList(String) - Static method in class org.infinispan.commons.dataconversion.MediaType
-
Parse a comma separated list of media type trees.
- parseLocalCache(ConfigurationReader, ConfigurationBuilderHolder, String, boolean) - Method in class org.infinispan.configuration.parsing.CacheParser
- parseLong(ConfigurationReader, int, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- parseMembers(ScopedPersistentState) - Static method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
- parseNumSegments(ScopedPersistentState) - Static method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
- parsePI() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- parseProlog() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- parseProperties(ConfigurationReader, Enum<?>) - Static method in class org.infinispan.configuration.parsing.CacheParser
- parseProperties(ConfigurationReader, Enum<?>, Enum<?>, Enum<?>) - Static method in class org.infinispan.configuration.parsing.CacheParser
- parseProperties(ConfigurationReader, String, String, String) - Static method in class org.infinispan.configuration.parsing.CacheParser
- parser(AttributeParser<? super T>) - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition.Builder
- Parser - Class in org.infinispan.configuration.parsing
-
This class implements the parser for Infinispan/AS7/EAP/JDG schema files
- Parser() - Constructor for class org.infinispan.configuration.parsing.Parser
- parseReplicatedCache(ConfigurationReader, ConfigurationBuilderHolder, String, boolean) - Method in class org.infinispan.configuration.parsing.CacheParser
- parseRFC1123(String) - Static method in class org.infinispan.rest.DateUtils
- parserRegistry - Variable in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
- ParserRegistry - Class in org.infinispan.configuration.parsing
-
ParserRegistry is a namespace-mapping-aware meta-parser which provides a way to delegate the parsing of multi-namespace XML files to appropriate parsers, defined by the
ConfigurationParser
interface. - ParserRegistry() - Constructor for class org.infinispan.configuration.parsing.ParserRegistry
- ParserRegistry(ClassLoader) - Constructor for class org.infinispan.configuration.parsing.ParserRegistry
- ParserRegistry(ClassLoader, boolean, Properties) - Constructor for class org.infinispan.configuration.parsing.ParserRegistry
- ParserRegistry.NamespaceParserPair - Class in org.infinispan.configuration.parsing
- ParserRegistry.QName - Class in org.infinispan.configuration.parsing
- ParserResults(String, List<String>) - Constructor for class org.infinispan.persistence.sql.QueryNamedParameterParser.ParserResults
- ParserScope - Enum in org.infinispan.configuration.parsing
-
ParserScope indicates the configuration parser scope.
- parseScatteredCache(ConfigurationReader, ConfigurationBuilderHolder, String, boolean) - Method in class org.infinispan.configuration.parsing.CacheParser
- parseServers(String, BiConsumer<String, Integer>) - Static method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- parseSimpleConnectionAttributes(ConfigurationReader, SimpleConnectionFactoryConfigurationBuilder<?>) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationParser
- parseSingleFileStore(ConfigurationReader, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.CacheParser
- parseSqlStatement(String) - Static method in class org.infinispan.persistence.sql.QueryNamedParameterParser
-
Parse the SQL statement and locate any placeholders or named parameters.
- parseStartTag() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- parseStoreAttribute(ConfigurationReader, int, AbstractStoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.CacheParser
-
This method is public static so that it can be reused by custom cache store/loader configuration parsers
- parseStoreAttribute(ConfigurationReader, int, AbstractStoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.Parser
-
Deprecated, for removal: This API element is subject to removal in a future version.
- parseStoreElement(ConfigurationReader, StoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.CacheParser
- parseStoreElement(ConfigurationReader, StoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.Parser
-
Deprecated, for removal: This API element is subject to removal in a future version.
- parseStoreProperties(ConfigurationReader, StoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.CacheParser
- parseStoreProperty(ConfigurationReader, StoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.CacheParser
- parseStoreProperty(ConfigurationReader, StoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.Parser
-
Deprecated, for removal: This API element is subject to removal in a future version.
- parseStoreWriteBehind(ConfigurationReader, AsyncStoreConfigurationBuilder<?>) - Static method in class org.infinispan.configuration.parsing.CacheParser
- parseStoreWriteBehind(ConfigurationReader, AsyncStoreConfigurationBuilder<?>) - Static method in class org.infinispan.configuration.parsing.Parser
-
Deprecated, for removal: This API element is subject to removal in a future version.
- ParseUtils - Class in org.infinispan.configuration.parsing
- parseVersion(String) - Static method in enum org.infinispan.client.hotrod.ProtocolVersion
- parseXmlDecl(char) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- parseXmlDeclWithVersion(int, int) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- parsingComplete(ConfigurationBuilderHolder) - Method in interface org.infinispan.configuration.parsing.ConfigurationParserListener
- ParsingException - Exception in org.infinispan.objectfilter
-
Thrown in case of syntax errors during parsing or during the processing of the parse tree.
- ParsingException(String) - Constructor for exception org.infinispan.objectfilter.ParsingException
- ParsingException(String, Throwable) - Constructor for exception org.infinispan.objectfilter.ParsingException
- ParsingException(Throwable) - Constructor for exception org.infinispan.objectfilter.ParsingException
- partition - Variable in class org.infinispan.stream.impl.AbstractCacheStream
- PARTITION_HANDLING - Enum constant in enum org.infinispan.configuration.parsing.Element
- PARTITION_STATUS_CHANGED - Enum constant in enum org.infinispan.notifications.cachelistener.event.Event.Type
- PartitionAwareClusterPublisherManager<K,
V> - Class in org.infinispan.reactive.publisher.impl -
Cluster stream manager that also pays attention to partition status and properly closes iterators and throws exceptions when the availability mode changes.
- PartitionAwareClusterPublisherManager() - Constructor for class org.infinispan.reactive.publisher.impl.PartitionAwareClusterPublisherManager
- partitionHandling() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
- partitionHandling() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
-
Configures cluster's behaviour in the presence of partitions or node failures.
- partitionHandling() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
- partitionHandling() - Method in interface org.infinispan.configuration.cache.ClusteringConfigurationChildBuilder
-
Configures how the cache will react to cluster partitions.
- PartitionHandling - Enum in org.infinispan.partitionhandling
- PartitionHandlingConfiguration - Class in org.infinispan.configuration.cache
-
Controls how the cache handles partitioning and/or multiple node failures.
- PartitionHandlingConfiguration(AttributeSet) - Constructor for class org.infinispan.configuration.cache.PartitionHandlingConfiguration
- PartitionHandlingConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Controls how the cache handles partitioning and/or multiple node failures.
- PartitionHandlingConfigurationBuilder(ClusteringConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
- PartitionHandlingInterceptor - Class in org.infinispan.partitionhandling.impl
- PartitionHandlingInterceptor() - Constructor for class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
- partitionHandlingManager - Variable in class org.infinispan.transaction.impl.TransactionTable
- PartitionHandlingManager - Interface in org.infinispan.partitionhandling.impl
- PartitionHandlingManagerFactory - Class in org.infinispan.factories
- PartitionHandlingManagerFactory() - Constructor for class org.infinispan.factories.PartitionHandlingManagerFactory
- PartitionHandlingManagerImpl - Class in org.infinispan.partitionhandling.impl
- PartitionHandlingManagerImpl(Configuration) - Constructor for class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
- partitionHandlingSupport - Variable in class org.infinispan.query.impl.IndexedQueryImpl
- PartitionStatusChanged - Annotation Type in org.infinispan.notifications.cachelistener.annotation
-
This annotation should be used on methods that need to be notified when the
AvailabilityMode
in use by thePartitionHandlingManager
changes due to a change in cluster topology. - PartitionStatusChangedEvent<K,
V> - Interface in org.infinispan.notifications.cachelistener.event -
The event passed in to methods annotated with
PartitionStatusChanged
. - PASS_CREDENTIALS - Enum constant in enum org.infinispan.server.hotrod.configuration.Element
- PASS_CREDENTIALS - Enum constant in enum org.infinispan.server.hotrod.configuration.Policy
- passivateAll() - Method in class org.infinispan.eviction.impl.AbstractPassivationManager
-
Passivates all entries that are in memory.
- passivateAll() - Method in class org.infinispan.eviction.impl.PassivationManagerImpl
- passivateAll() - Method in class org.infinispan.eviction.impl.PassivationManagerStub
- passivateAllAsync() - Method in interface org.infinispan.eviction.impl.PassivationManager
-
Start passivating all entries that are in memory.
- passivateAllAsync() - Method in class org.infinispan.eviction.impl.PassivationManagerImpl
- passivateAllAsync() - Method in class org.infinispan.eviction.impl.PassivationManagerStub
- passivateAsync(InternalCacheEntry) - Method in class org.infinispan.eviction.impl.PassivationManagerStub
- passivateAsync(InternalCacheEntry<?, ?>) - Method in interface org.infinispan.eviction.impl.PassivationManager
-
Passivates the entry in a non blocking fashion.
- passivateAsync(InternalCacheEntry<?, ?>) - Method in class org.infinispan.eviction.impl.PassivationManagerImpl
- passivation() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
-
If true, data is only written to the cache store when it is evicted from memory, a phenomenon known as 'passivation'.
- passivation(boolean) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
- PASSIVATION - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- PASSIVATION - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
- PASSIVATION - Static variable in class org.infinispan.configuration.cache.PersistenceConfiguration
- PassivationManager - Interface in org.infinispan.eviction.impl
-
A passivation manager
- PassivationManagerImpl - Class in org.infinispan.eviction.impl
- PassivationManagerImpl() - Constructor for class org.infinispan.eviction.impl.PassivationManagerImpl
- PassivationManagerStub - Class in org.infinispan.eviction.impl
- PassivationManagerStub() - Constructor for class org.infinispan.eviction.impl.PassivationManagerStub
- passivator - Variable in class org.infinispan.container.impl.AbstractInternalDataContainer
- passivator - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
- PassthroughMapResponseCollector - Class in org.infinispan.remoting.transport.impl
-
Receive responses from multiple nodes, without checking that the responses are valid.
- PassthroughMapResponseCollector(int) - Constructor for class org.infinispan.remoting.transport.impl.PassthroughMapResponseCollector
- PassthroughSingleResponseCollector - Class in org.infinispan.remoting.transport.impl
-
RPC to a single node, without any validity checks.
- password() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractUnmanagedConnectionFactoryConfiguration
- password() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
- password() - Method in class org.infinispan.persistence.remote.configuration.MechanismConfiguration
- password(char[]) - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
-
Specifies the password to be used for authentication.
- password(char[]) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
-
Specifies the password to be used for authentication.
- password(char[]) - Method in class org.infinispan.persistence.remote.configuration.MechanismConfigurationBuilder
- password(String) - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
-
Specifies the password to be used for authentication.
- password(String) - Method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfigurationBuilder
- password(String) - Method in class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfigurationBuilder
- password(String) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
-
Specifies the password to be used for authentication.
- password(String) - Method in class org.infinispan.persistence.remote.configuration.MechanismConfigurationBuilder
- PASSWORD - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
- PASSWORD - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- PASSWORD - Static variable in class org.infinispan.persistence.jdbc.common.configuration.AbstractUnmanagedConnectionFactoryConfiguration
- pastEndTag - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- path() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
- path() - Method in class org.infinispan.configuration.global.GlobalStatePathConfiguration
- path() - Method in class org.infinispan.configuration.global.StackFileConfiguration
- path() - Method in class org.infinispan.configuration.global.TemporaryGlobalStatePathConfiguration
- path() - Method in interface org.infinispan.rest.framework.RestRequest
- path() - Method in class org.infinispan.rest.NettyRestRequest
- path(String) - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
- path(String) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
- path(String) - Method in interface org.infinispan.configuration.cache.IndexingConfigurationChildBuilder
- path(String) - Method in class org.infinispan.configuration.global.StackFileConfigurationBuilder
- path(String) - Method in class org.infinispan.rest.framework.impl.InvocationImpl.Builder
- PATH - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- PATH - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.Attribute
- PATH - Static variable in class org.infinispan.commons.util.ClassFinder
- PATH - Static variable in class org.infinispan.configuration.cache.IndexingConfiguration
- PATH - Static variable in class org.infinispan.configuration.global.GlobalStatePathConfiguration
- PATH - Static variable in class org.infinispan.configuration.global.TemporaryGlobalStatePathConfiguration
- paths() - Method in class org.infinispan.rest.framework.impl.InvocationImpl
- paths() - Method in interface org.infinispan.rest.framework.Invocation
-
Returns one or more paths associated with the invocation.
- pause() - Method in class org.infinispan.persistence.sifs.LogAppender
- pc - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- pcEnd - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- pcStart - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- peek() - Method in class org.infinispan.container.versioning.irac.DefaultIracVersionGenerator
- peek() - Method in interface org.infinispan.functional.EntryView.ReadEntryView
-
The same as
EntryView.ReadEntryView.find()
but does not update any hit/miss statistics. - peek(int, Object) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- peek(int, Object) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
- peek(int, Object) - Method in interface org.infinispan.container.impl.InternalDataContainer
-
Same as
DataContainer.peek(Object)
except that the segment of the key can provided to lookup entries without calculating the segment for the given key - peek(int, Object) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- peek(Object) - Method in interface org.infinispan.commons.util.PeekableMap
-
Deprecated.Peaks at a value for the given key.
- peek(Object) - Method in interface org.infinispan.container.DataContainer
-
Retrieves a cache entry in the same way as
DataContainer.get(Object)
} except that it does not update or reorder any of the internal constructs. - peek(Object) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- peek(Object) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
- peek(Object) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
- peek(Object) - Method in class org.infinispan.container.impl.PeekableTouchableCaffeineMap
- peek(Object) - Method in class org.infinispan.container.impl.PeekableTouchableContainerMap
- peek(Object) - Method in interface org.infinispan.container.impl.PeekableTouchableMap
-
Peaks at a value for the given key.
- peek(Object) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- peek(Object) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- peek(Consumer<? super R>) - Method in interface org.infinispan.CacheStream
- peek(Consumer<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
- peek(Consumer<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- peek(Consumer<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- peek(DoubleConsumer) - Method in interface org.infinispan.DoubleCacheStream
- peek(DoubleConsumer) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- peek(DoubleConsumer) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- peek(IntConsumer) - Method in interface org.infinispan.IntCacheStream
- peek(IntConsumer) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- peek(IntConsumer) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- peek(LongConsumer) - Method in interface org.infinispan.LongCacheStream
- peek(LongConsumer) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- peek(LongConsumer) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- peek(SerializableConsumer<? super R>) - Method in interface org.infinispan.CacheStream
-
Same as
CacheStream.peek(Consumer)
except that the Consumer must also implementSerializable
- peek(SerializableDoubleConsumer) - Method in interface org.infinispan.DoubleCacheStream
-
Same as
DoubleCacheStream.flatMap(DoubleFunction)
except that the DoubleFunction must also implementSerializable
- peek(SerializableDoubleConsumer) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- peek(SerializableIntConsumer) - Method in interface org.infinispan.IntCacheStream
-
Same as
IntCacheStream.flatMap(IntFunction)
except that the IntFunction must also implementSerializable
- peek(SerializableIntConsumer) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- peek(SerializableLongConsumer) - Method in interface org.infinispan.LongCacheStream
-
Same as
LongCacheStream.flatMap(LongFunction)
except that the LongFunction must also implement Serializable. - peek(SerializableLongConsumer) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- PeekableMap<K,
V> - Interface in org.infinispan.commons.util -
Deprecated, for removal: This API element is subject to removal in a future version.since 11.0 with no replacement - no longer used
- PeekableTouchableCaffeineMap<K,
V> - Class in org.infinispan.container.impl - PeekableTouchableCaffeineMap(Cache<K, InternalCacheEntry<K, V>>) - Constructor for class org.infinispan.container.impl.PeekableTouchableCaffeineMap
- PeekableTouchableContainerMap<K,
V> - Class in org.infinispan.container.impl - PeekableTouchableContainerMap() - Constructor for class org.infinispan.container.impl.PeekableTouchableContainerMap
- PeekableTouchableContainerMap(ConcurrentMap<K, InternalCacheEntry<K, V>>) - Constructor for class org.infinispan.container.impl.PeekableTouchableContainerMap
- PeekableTouchableMap<K,
V> - Interface in org.infinispan.container.impl - PENDING - Enum constant in enum org.infinispan.topology.RebalancingStatus
- PendingLockListener - Interface in org.infinispan.util.concurrent.locks
-
A listener that is invoked when
PendingLockPromise
is ready. - PendingLockManager - Interface in org.infinispan.util.concurrent.locks
-
A manager that checks and waits for older topology transaction with conflicting keys.
- PendingLockPromise - Interface in org.infinispan.util.concurrent.locks
-
A promise returned by
PendingLockManager
. - pendingOperations() - Method in class org.infinispan.util.concurrent.DataOperationOrderer
-
Returns how many keys have pending operations waiting for their completion
- PerCacheTxTable - Class in org.infinispan.server.hotrod.tx.table
-
A Transaction Table for client transaction.
- PerCacheTxTable(Address) - Constructor for class org.infinispan.server.hotrod.tx.table.PerCacheTxTable
- PercentileStatistic - Enum in org.infinispan.extendedstats.percentiles
-
Percentile statistic for the transaction execution time.
- performBatch(TxInvocationContext<AbstractCacheTransaction>, TriPredicate<? super WriteCommand, Object, MVCCEntry<?, ?>>) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- performCheckOnSegment(int) - Method in interface org.infinispan.transaction.impl.WriteSkewHelper.KeySpecificLogic
- performOperation() - Method in interface org.infinispan.stream.impl.TerminalOperation
-
Actually runs the terminal operation returning the result from the operation
- performSequentially(Iterator<I>, Function<? super I, CompletionStage<Void>>) - Static method in class org.infinispan.util.concurrent.CompletionStages
- performSequentially(Iterator<I>, Function<? super I, CompletionStage<T>>, Collector<T, A, R>) - Static method in class org.infinispan.util.concurrent.CompletionStages
- performWriteSkewCheck(EntryLoader<K, V>, int, TxInvocationContext<?>, EntryVersion, VersionGenerator, boolean) - Method in class org.infinispan.container.entries.VersionedRepeatableReadEntry
- performWriteSkewCheckAndReturnNewVersions(VersionedPrepareCommand, EntryLoader<?, ?>, VersionGenerator, TxInvocationContext<?>, WriteSkewHelper.KeySpecificLogic, KeyPartitioner) - Static method in class org.infinispan.transaction.impl.WriteSkewHelper
- PerKeyLockContainer - Class in org.infinispan.util.concurrent.locks.impl
-
A lock container that creates and maintains a new lock per entry.
- PerKeyLockContainer() - Constructor for class org.infinispan.util.concurrent.locks.impl.PerKeyLockContainer
- PERMANENT - Enum constant in enum org.infinispan.commons.api.CacheContainerAdmin.AdminFlag
-
Deprecated, for removal: This API element is subject to removal in a future version.configurations are now always permanent by default. Use the
CacheContainerAdmin.AdminFlag.VOLATILE
flag to obtain the opposite behaviour. - permission() - Method in class org.infinispan.rest.framework.impl.InvocationImpl
- permission() - Method in interface org.infinispan.rest.framework.Invocation
- permission(String) - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
-
Adds a permission to a role
- permission(String...) - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
-
Adds multiple permissions to a role
- permission(AuthorizationPermission) - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
-
Adds a permission to a role
- permission(AuthorizationPermission) - Method in class org.infinispan.rest.framework.impl.InvocationImpl.Builder
- permission(AuthorizationPermission...) - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
-
Adds multiple permissions to a role
- permissionMapper() - Method in class org.infinispan.configuration.global.RolePermissionMapperConfiguration
- permissionMapperConfiguration() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
- PERMISSIONS - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- PermissiveAuthorizationManager - Class in org.infinispan.security.impl
-
A permissive
AuthorizationManager
. - PermissiveAuthorizationManager() - Constructor for class org.infinispan.security.impl.PermissiveAuthorizationManager
- persistence() - Method in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
- persistence() - Method in class org.infinispan.configuration.cache.Configuration
- persistence() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- persistence() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- persistence() - Method in interface org.infinispan.configuration.cache.PersistenceConfigurationChildBuilder
- PERSISTENCE - Enum constant in enum org.infinispan.configuration.parsing.Element
- PERSISTENCE - Static variable in interface org.infinispan.persistence.jdbc.common.logging.Log
- PERSISTENCE_AVAILABILITY_CHANGED - Enum constant in enum org.infinispan.notifications.cachelistener.event.Event.Type
- PERSISTENCE_EXECUTOR - Enum constant in enum org.infinispan.configuration.parsing.Attribute
-
Deprecated, for removal: This API element is subject to removal in a future version.
- PERSISTENCE_MARSHALLER - Static variable in class org.infinispan.factories.KnownComponentNames
- PERSISTENCE_MODE_ID - Static variable in class org.infinispan.functional.ParamIds
- PersistenceAvailabilityChanged - Annotation Type in org.infinispan.notifications.cachelistener.annotation
-
Use this annotation on methods that require notification when the availability of the PersistenceManager changes.
- PersistenceAvailabilityChangedEvent<K,
V> - Interface in org.infinispan.notifications.cachelistener.event - persistenceConfiguration() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
- PersistenceConfiguration - Class in org.infinispan.configuration.cache
-
Configuration for stores.
- PersistenceConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Configuration for cache stores.
- PersistenceConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
- PersistenceConfigurationChildBuilder - Interface in org.infinispan.configuration.cache
- PersistenceContextInitializer - Interface in org.infinispan.commons.marshall
-
Interface used to initialise a
SerializationContext
using the specified Pojos, Marshaller implementations and provided .proto schemas. - PersistenceContextInitializer - Interface in org.infinispan.persistence.jdbc.impl
-
Interface used to initialise a
SerializationContext
using the specified Pojos, Marshaller implementations and provided .proto schemas. - PersistenceContextInitializer - Interface in org.infinispan.spring.common.session
-
Interface used to initialise a
SerializationContext
using the specified Pojos, Marshaller implementations and provided .proto schemas. - PersistenceContextInitializerImpl - Class in org.infinispan.commons.marshall
-
WARNING: Generated code! Do not edit!
- PersistenceContextInitializerImpl - Class in org.infinispan.multimap.impl
-
WARNING: Generated code! Do not edit!
- PersistenceContextInitializerImpl - Class in org.infinispan.persistence.jdbc.impl
-
WARNING: Generated code! Do not edit!
- PersistenceContextInitializerImpl - Class in org.infinispan.persistence.rocksdb
-
WARNING: Generated code! Do not edit!
- PersistenceContextInitializerImpl - Class in org.infinispan.query.impl
-
WARNING: Generated code! Do not edit!
- PersistenceContextInitializerImpl - Class in org.infinispan.server.core
-
WARNING: Generated code! Do not edit!
- PersistenceContextInitializerImpl - Class in org.infinispan.server.memcached
-
WARNING: Generated code! Do not edit!
- PersistenceContextInitializerImpl - Class in org.infinispan.spring.common.session
-
WARNING: Generated code! Do not edit!
- PersistenceContextInitializerImpl() - Constructor for class org.infinispan.commons.marshall.PersistenceContextInitializerImpl
- PersistenceContextInitializerImpl() - Constructor for class org.infinispan.multimap.impl.PersistenceContextInitializerImpl
- PersistenceContextInitializerImpl() - Constructor for class org.infinispan.persistence.jdbc.impl.PersistenceContextInitializerImpl
- PersistenceContextInitializerImpl() - Constructor for class org.infinispan.persistence.rocksdb.PersistenceContextInitializerImpl
- PersistenceContextInitializerImpl() - Constructor for class org.infinispan.query.impl.PersistenceContextInitializerImpl
- PersistenceContextInitializerImpl() - Constructor for class org.infinispan.server.core.PersistenceContextInitializerImpl
- PersistenceContextInitializerImpl() - Constructor for class org.infinispan.server.memcached.PersistenceContextInitializerImpl
- PersistenceContextInitializerImpl() - Constructor for class org.infinispan.spring.common.session.PersistenceContextInitializerImpl
- PersistenceException - Exception in org.infinispan.persistence.spi
-
An exception thrown by a
CacheLoader
or aCacheWriter
implementation if there are problems reading from a loader. - PersistenceException() - Constructor for exception org.infinispan.persistence.spi.PersistenceException
- PersistenceException(String) - Constructor for exception org.infinispan.persistence.spi.PersistenceException
- PersistenceException(String, Throwable) - Constructor for exception org.infinispan.persistence.spi.PersistenceException
- PersistenceException(Throwable) - Constructor for exception org.infinispan.persistence.spi.PersistenceException
- persistenceExecutor(String) - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
- persistenceManager - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
- persistenceManager - Variable in class org.infinispan.persistence.support.DelegatingPersistenceManager
- PersistenceMarshaller - Interface in org.infinispan.marshall.persistence
-
The marshaller that is responsible serializing/deserializing objects which are to be persisted.
- persistenceThreadPool() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
- persistenceThreadPool() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
- persistenceThreadPool() - 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.
- persistenceThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- persistenceThreadPool() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Configuration for the persistence thread pool
- persistenceThreadPool() - Method in class org.infinispan.configuration.global.ThreadsConfiguration
- persistenceThreadPool() - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
- persistenceThreadPoolName() - 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.
- persistenceThreadPoolName(String) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- PersistenceUtil - Class in org.infinispan.persistence.internal
-
Persistence Utility that is useful for internal classes.
- PersistenceUtil - Class in org.infinispan.persistence
- PersistenceUtil() - Constructor for class org.infinispan.persistence.internal.PersistenceUtil
- PersistenceUtil() - Constructor for class org.infinispan.persistence.PersistenceUtil
- PERSISTENT - Enum constant in enum org.infinispan.counter.api.Storage
-
The counter value is stored persistently and survives a cluster restart/stop.
- PERSISTENT_LOCATION - Enum constant in enum org.infinispan.configuration.parsing.Element
- PERSISTENT_UUID - Static variable in interface org.infinispan.commons.marshall.Ids
- persistentLocation() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
-
Returns the filesystem path where persistent state data which needs to survive container restarts should be stored.
- persistentLocation(String) - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
-
Defines the filesystem path where node-specific persistent data which needs to survive container restarts should be stored.
- persistentLocation(String, String) - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
- PersistentUUID - Class in org.infinispan.topology
-
PersistentUUID.
- PersistentUUID(long, long) - Constructor for class org.infinispan.topology.PersistentUUID
- PersistentUUID.Externalizer - Class in org.infinispan.topology
- PersistentUUIDManager - Interface in org.infinispan.topology
-
PersistentUUIDManager maintains a mapping of
PersistentUUID
s present in the cluster - PersistentUUIDManagerImpl - Class in org.infinispan.topology
-
Implementation of the
PersistentUUIDManager
interface - PersistentUUIDManagerImpl() - Constructor for class org.infinispan.topology.PersistentUUIDManagerImpl
- persistentUUIDToAddress() - Method in interface org.infinispan.topology.PersistentUUIDManager
-
Provides a remapping operator which translates persistentuuids to addresses
- persistentUUIDToAddress() - Method in class org.infinispan.topology.PersistentUUIDManagerImpl
- PESSIMISTIC - Enum constant in enum org.infinispan.transaction.LockingMode
- physicalAddress - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- ping() - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- ping() - Method in interface org.infinispan.client.hotrod.impl.InternalRemoteCache
- ping() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- PING - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- PING_ON_STARTUP - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- PING_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- pingResponse(HotRodHeader, HotRodServer, Channel, OperationStatus) - Method in class org.infinispan.server.hotrod.Encoder4x
- pingResponse(HotRodHeader, HotRodServer, Channel, OperationStatus) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- PlatformMBeanServerLookup - Class in org.infinispan.commons.jmx
-
Default implementation for
MBeanServerLookup
, will return the platform MBean server. - PlatformMBeanServerLookup - Class in org.infinispan.jmx
-
Deprecated, for removal: This API element is subject to removal in a future version.Use
PlatformMBeanServerLookup
instead - PlatformMBeanServerLookup() - Constructor for class org.infinispan.commons.jmx.PlatformMBeanServerLookup
- PlatformMBeanServerLookup() - Constructor for class org.infinispan.jmx.PlatformMBeanServerLookup
-
Deprecated.
- pmemChannelFor(File, int, boolean, boolean) - Static method in class org.infinispan.persistence.sifs.pmem.PmemUtilWrapper
-
Same as
PmemUtil.pmemChannelFor(File, int, boolean, boolean)
. - PmemUtilWrapper - Class in org.infinispan.persistence.sifs.pmem
-
This class is here solely for the purpose of encapsulating the
PmemUtil
class so we do not load it unless necessary, allowing this to be an optional dependency. - PmemUtilWrapper() - Constructor for class org.infinispan.persistence.sifs.pmem.PmemUtilWrapper
- POINTER_SIZE - Static variable in class org.infinispan.commons.util.AbstractEntrySizeCalculatorHelper
- Policy - Enum in org.infinispan.server.hotrod.configuration
- POLICY - Enum constant in enum org.infinispan.server.hotrod.configuration.Attribute
- POLICY - Enum constant in enum org.infinispan.server.hotrod.configuration.Element
- POLICY - Static variable in class org.infinispan.server.hotrod.configuration.SaslConfiguration
- poll() - Method in class org.infinispan.executors.ExecutorAllCompletionService
- poll() - Method in class org.infinispan.executors.SemaphoreCompletionService
- poll(long, TimeUnit) - Method in class org.infinispan.executors.ExecutorAllCompletionService
- poll(long, TimeUnit) - Method in class org.infinispan.executors.SemaphoreCompletionService
- PooledConnectionFactoryConfiguration - Class in org.infinispan.persistence.jdbc.common.configuration
- PooledConnectionFactoryConfiguration(AttributeSet) - Constructor for class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfiguration
- PooledConnectionFactoryConfigurationBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,
S>> - Class in org.infinispan.persistence.jdbc.common.configuration -
PooledConnectionFactoryConfigurationBuilder.
- PooledConnectionFactoryConfigurationBuilder(AbstractJdbcStoreConfigurationBuilder<?, S>) - Constructor for class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfigurationBuilder
- popNDC(boolean) - Static method in class org.infinispan.util.logging.LogFactory
- popScope() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
- port() - Method in class org.infinispan.client.hotrod.configuration.ServerConfiguration
- port() - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfiguration
- port() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- port() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- port(int) - Method in class org.infinispan.client.hotrod.configuration.ServerConfigurationBuilder
- port(int) - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfigurationBuilder
- port(int) - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
- port(int) - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- port(int) - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
-
Specifies the port on which this server will listen
- PORT - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- PORT - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- pos - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- posEnd - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- position() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
- position() - Method in class org.infinispan.io.ReadableGridFileChannel
-
Deprecated.
- position(long) - Method in class org.infinispan.io.ReadableGridFileChannel
-
Deprecated.
- position(InterceptorConfiguration.Position) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
-
Deprecated.Specifies a position, denoted by the
InterceptorConfiguration.Position
enumeration, where to place the new interceptor. - POSITION - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- POSITION - Static variable in class org.infinispan.configuration.cache.InterceptorConfiguration
- possiblyPresent(E) - Method in class org.infinispan.commons.util.BloomFilter
-
Returns
true
if the element might be present,false
if the value was for sure not present. - posStart - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- POST - Enum constant in enum org.infinispan.notifications.Listener.Observation
-
Observation level used to only be notified of an operation after it has completed
- POST - Enum constant in enum org.infinispan.rest.framework.Method
- PostCacheEventFilter<K,
V> - Class in org.infinispan.notifications.cachelistener.filter -
A Filter that only allows post events to be accepted.
- PostCacheEventFilter() - Constructor for class org.infinispan.notifications.cachelistener.filter.PostCacheEventFilter
- postDeregister() - Method in class org.infinispan.jmx.ResourceDMBean
- POSTGRES - Enum constant in enum org.infinispan.persistence.jdbc.common.DatabaseType
- postRegister(Boolean) - Method in class org.infinispan.jmx.ResourceDMBean
- postStart() - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- postStart() - Method in class org.infinispan.factories.ComponentRegistry
- postStart() - Method in class org.infinispan.factories.GlobalComponentRegistry
- postStart() - Method in interface org.infinispan.globalstate.GlobalConfigurationManager
- postStop() - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- postStop() - Method in class org.infinispan.factories.ComponentRegistry
- postStop() - Method in class org.infinispan.factories.GlobalComponentRegistry
- postTxCommandCheck(InvocationContext, VisitableCommand, Object) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
- PRE - Enum constant in enum org.infinispan.notifications.Listener.Observation
-
Observation level used to only be notified of an operation before it completes
- preDefinedOrdinals() - Method in class org.infinispan.search.mapper.model.impl.InfinispanSimpleStringSetPojoPathFilterFactory
- preDeregister() - Method in class org.infinispan.jmx.ResourceDMBean
- predicate() - Method in class org.infinispan.search.mapper.scope.impl.SearchScopeImpl
- predicate() - Method in interface org.infinispan.search.mapper.scope.SearchScope
-
Initiate the building of a search predicate.
- predicate(KeyValueFilter<? super K, ? super V>) - Static method in class org.infinispan.filter.CacheFilters
-
Creates a new
Predicate
using the provided key value filter as a basis for the operation. - PREFER_NON_NULL - Enum constant in enum org.infinispan.xsite.spi.XSiteMergePolicy
-
Chooses the
non-null
value if available (write/remove conflict, write wins), otherwise uses theXSiteMergePolicy.DEFAULT
. - PREFER_NULL - Enum constant in enum org.infinispan.xsite.spi.XSiteMergePolicy
-
Chooses the
null
value if available (write/remove conflict, remove wins), otherwise uses theXSiteMergePolicy.DEFAULT
. - PreferAvailabilityStrategy - Class in org.infinispan.partitionhandling.impl
- PreferAvailabilityStrategy(EventLogManager, PersistentUUIDManager, LostDataCheck) - Constructor for class org.infinispan.partitionhandling.impl.PreferAvailabilityStrategy
- PreferConsistencyStrategy - Class in org.infinispan.partitionhandling.impl
- PreferConsistencyStrategy(EventLogManager, PersistentUUIDManager, LostDataCheck) - Constructor for class org.infinispan.partitionhandling.impl.PreferConsistencyStrategy
- PreferNonNullXSiteEntryMergePolicy<K,
V> - Class in org.infinispan.xsite.spi -
A
XSiteEntryMergePolicy
implementation that chooses a non-null entry. - PreferNullXSiteEntryMergePolicy<K,
V> - Class in org.infinispan.xsite.spi -
A
XSiteEntryMergePolicy
implementation that chooses a null entry. - PREFERRED_ALWAYS - Enum constant in enum org.infinispan.conflict.MergePolicy
- PREFERRED_NON_NULL - Enum constant in enum org.infinispan.conflict.MergePolicy
- prefix() - Method in class org.infinispan.configuration.global.GlobalMetricsConfiguration
-
The global prefix to add to all metric names.
- prefix() - Method in class org.infinispan.configuration.global.GlobalMetricsConfigurationBuilder
-
The global prefix to add to all metric names.
- prefix(String) - Method in class org.infinispan.configuration.global.GlobalMetricsConfigurationBuilder
-
The global prefix to add to all metric names.
- PREFIX - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- PREFIX - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
- PREFIX - Static variable in class org.infinispan.configuration.global.GlobalMetricsConfiguration
- PREFIX_10_1 - Static variable in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
- PREFIX_11_0 - Static variable in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
- PREFIX_12_0 - Static variable in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
- PREFIX_LATEST - Static variable in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
- preIndexingReloading() - Method in interface org.infinispan.query.logging.Log
- preload() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- preload() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
-
Loops through all individual cache loader configs and checks if preload is set on any of them
- preload() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
- preload(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
-
If true, when the cache starts, data stored in the cache store will be pre-loaded into memory.
- preload(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
- preload(boolean) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
-
If true, when the cache starts, data stored in the cache store will be pre-loaded into memory.
- PRELOAD - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- PRELOAD - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- preloadPublisher() - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- preLog(FullHttpRequest) - Method in class org.infinispan.rest.logging.RestAccessLoggingHandler
- prepare(boolean) - Method in class org.infinispan.server.hotrod.tx.PrepareCoordinator
-
Prepares the transaction.
- prepare(Xid) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
-
This can be call for any transaction object.
- prepare(XidImpl) - Method in class org.infinispan.transaction.xa.XaTransactionTable
- prepare(LocalTransaction) - Method in class org.infinispan.transaction.impl.TransactionCoordinator
- prepare(LocalTransaction, boolean) - Method in class org.infinispan.transaction.impl.TransactionCoordinator
- PREPARE_COMMAND_SIZE - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- PREPARE_EXECUTION_TIME - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- PREPARE_RESPONSE - Static variable in interface org.infinispan.commons.marshall.Ids
- PREPARE_TX - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- PREPARE_TX - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- PREPARE_TX_2 - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- PREPARE_TX_2 - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- prepareAllTxStores(TxInvocationContext<AbstractCacheTransaction>, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- prepareAndValidateBackup() - Method in interface org.infinispan.server.core.backup.ContainerResource
-
A method to ensure that the resources requested in the
BackupManager.Resources
are valid and can be included in a backup. - prepareAndValidateBackup() - Method in class org.infinispan.server.core.backup.resources.CacheResource
- prepareAndValidateBackup() - Method in class org.infinispan.server.core.backup.resources.CounterResource
- prepareAndValidateRestore(Properties) - Method in interface org.infinispan.server.core.backup.ContainerResource
-
A method to ensure that the resources requested in the
BackupManager.Resources
are contained in the backup to be restored. - prepareAndValidateRestore(Properties) - Method in class org.infinispan.server.core.backup.resources.CounterResource
- prepareBuild(PojoMappingDelegate) - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapperDelegate
- PrepareCoordinator - Class in org.infinispan.server.hotrod.tx
-
A class that handles the prepare request from the Hot Rod clients.
- PrepareCoordinator(AdvancedCache<byte[], byte[]>, XidImpl, boolean, long) - Constructor for class org.infinispan.server.hotrod.tx.PrepareCoordinator
- PREPARED - Enum constant in enum org.infinispan.server.hotrod.tx.table.Status
-
The transaction is successful prepared and it waits for the client
TransactionManager
decision to commit or rollback - PREPARED_FUNCTION - Static variable in class org.infinispan.server.core.ExternalizerIds
- PreparedTxIterator - Class in org.infinispan.transaction.xa.recovery
-
Default implementation for RecoveryIterator.
- PreparedTxIterator() - Constructor for class org.infinispan.transaction.xa.recovery.PreparedTxIterator
- prepareForPersist(ScopedPersistentState) - Method in interface org.infinispan.globalstate.GlobalStateProvider
-
This method is invoked by the
GlobalStateManager
just before persisting the global state - prepareForPersist(ScopedPersistentState) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- prepareForPersist(ScopedPersistentState) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- prepareForRestore(ScopedPersistentState) - Method in interface org.infinispan.globalstate.GlobalStateProvider
-
This method is invoked by the
GlobalStateManager
after starting up to notify that global state has been restored. - prepareForRestore(ScopedPersistentState) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- prepareForRestore(ScopedPersistentState) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- prepareKeyStatement(PreparedStatement, Object) - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
- prepareKeyStatement(PreparedStatement, Object) - Method in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.SchemaTableOperations
- prepareOnUnexistingTransaction(String) - Method in interface org.infinispan.extendedstats.logging.Log
- preparePublishStatement(PreparedStatement, IntSet) - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
- PrepareResponse - Class in org.infinispan.remoting.responses
-
A
ValidResponse
used by Optimistic Transactions. - PrepareResponse() - Constructor for class org.infinispan.remoting.responses.PrepareResponse
- prepareSizeStatement(PreparedStatement) - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
- prepareTxFailure(Throwable) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- prepareValueStatement(PreparedStatement, int, MarshallableEntry<? extends K, ? extends V>) - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
- prepareValueStatement(PreparedStatement, int, MarshallableEntry<? extends K, ? extends V>) - Method in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.SchemaTableOperations
- prepareWithModifications(Transaction, int, Publisher<NonBlockingStore.SegmentedPublisher<Object>>, Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>>) - Method in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
- prepareWithModifications(Transaction, int, Publisher<NonBlockingStore.SegmentedPublisher<Object>>, Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>>) - Method in interface org.infinispan.persistence.spi.NonBlockingStore
-
Write remove and put modifications to the store in the prepare phase, which should not yet persisted until the same transaction is committed via
NonBlockingStore.commit(Transaction)
or they are discarded if the transaction is rolled back viaNonBlockingStore.rollback(Transaction)
. - prepareWithModifications(Transaction, int, Publisher<NonBlockingStore.SegmentedPublisher<Object>>, Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>>) - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
- prepareWithModifications(Transaction, int, Publisher<NonBlockingStore.SegmentedPublisher<Object>>, Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>>) - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
- prepareWithModifications(Transaction, BatchModification) - Method in interface org.infinispan.persistence.spi.TransactionalCacheWriter
-
Deprecated.Write modifications to the store in the prepare phase, as this is the only way we know the FINAL values of the entries.
- PREPARING - Enum constant in enum org.infinispan.server.hotrod.tx.table.Status
-
The client transaction was replayed successful (versions read are validated) and the transactions is preparing.
- PREPARING_FUNCTION - Static variable in class org.infinispan.server.core.ExternalizerIds
- PreparingDecisionFunction - Class in org.infinispan.server.hotrod.tx.table.functions
-
It changes the
TxState
status toStatus.PREPARING
and stores the transaction modifications. - PreparingDecisionFunction(List<WriteCommand>) - Constructor for class org.infinispan.server.hotrod.tx.table.functions.PreparingDecisionFunction
- PrependRequest - Enum constant in enum org.infinispan.server.memcached.MemcachedOperation
- preRegister(MBeanServer, ObjectName) - Method in class org.infinispan.jmx.ResourceDMBean
- preStart() - Method in class org.infinispan.cache.impl.CacheImpl
- preStart() - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- preStart() - Method in class org.infinispan.factories.ComponentRegistry
- preStart() - Method in class org.infinispan.factories.GlobalComponentRegistry
- preStart() - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- preStart() - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- preStop() - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- preStop() - Method in class org.infinispan.factories.ComponentRegistry
- preStop() - Method in class org.infinispan.factories.GlobalComponentRegistry
- pretendBlock() - Static method in class org.infinispan.commons.internal.BlockHoundUtil
-
Signal to BlockHound that a method must not be called from a non-blocking thread.
- prettyPrint - Variable in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- prettyPrint(boolean) - Method in class org.infinispan.commons.configuration.io.ConfigurationWriter.Builder
- prettyPrint(byte) - Static method in enum org.infinispan.server.hotrod.tx.ControlByte
- prettyPrintBitSet(long, Class<E>) - Static method in class org.infinispan.commons.util.EnumUtil
- prettyPrintOwnership() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
- prettyPrintSubject(Subject) - Static method in class org.infinispan.commons.util.Util
-
Prints
Subject
's principals as a one-liner (as opposed to default Subject'stoString()
method, which prints every principal on separate line). - prettyPrintTime(long) - Static method in class org.infinispan.commons.util.Util
-
Prints a time for display
- prettyPrintTime(long, TimeUnit) - Static method in class org.infinispan.commons.util.Util
- preventBufferCompaction - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- previousValue - Variable in class org.infinispan.commons.util.RemovableIterator
- primary() - Method in class org.infinispan.distribution.DistributionInfo
- PRIMARY - Enum constant in enum org.infinispan.commands.VisitableCommand.LoadType
-
In non-transactional cache, load previous value only on the primary owner.
- PRIMARY - Enum constant in enum org.infinispan.distribution.Ownership
-
This node is the primary owner.
- PRIMARY_OWNER - Enum constant in enum org.infinispan.configuration.cache.Index
-
Deprecated, for removal: This API element is subject to removal in a future version.This mode is no longer supported since version 11.0. A configuration error will be raised if encountered.
- primaryKeyMultipleColumnWithoutSchema() - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- primaryKeyPresentButNotEmbedded(String, String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- primaryOnly() - Element in annotation type org.infinispan.notifications.Listener
-
Specifies whether the event should be fired on the primary data owner of the affected key, or all nodes that see the update.
- PrimitiveEntrySizeCalculator - Class in org.infinispan.container.entries
-
Entry Size calculator that returns an approximation of how much various primitives, primitive wrappers, Strings, and arrays
- PrimitiveEntrySizeCalculator() - Constructor for class org.infinispan.container.entries.PrimitiveEntrySizeCalculator
- principalName - Variable in class org.infinispan.server.hotrod.AccessLoggingHeader
- PrincipalNameResolver - Class in org.infinispan.spring.common.session
-
Extracts Principal Name from Session.
- PrincipalNameResolver() - Constructor for class org.infinispan.spring.common.session.PrincipalNameResolver
- principalRoleMapper() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
- principalRoleMapper(PrincipalRoleMapper) - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
- PrincipalRoleMapper - Interface in org.infinispan.security
-
PrincipalRoleMapper.
- PrincipalRoleMapperConfiguration - Class in org.infinispan.configuration.global
- PrincipalRoleMapperConfigurationBuilder - Class in org.infinispan.configuration.global
- PrincipalRoleMapperContext - Interface in org.infinispan.security
-
Deprecated, for removal: This API element is subject to removal in a future version.since 14.0. To be removed in 17.0. Use
AuthorizationMapperContext
instead - principalRoleMapperNotMutable() - Method in interface org.infinispan.rest.logging.Log
- principals - Variable in class org.infinispan.server.core.security.SubjectSaslServer
- principalToRoles(Principal) - Method in class org.infinispan.security.mappers.ClusterRoleMapper
- principalToRoles(Principal) - Method in class org.infinispan.security.mappers.CommonNameRoleMapper
- principalToRoles(Principal) - Method in class org.infinispan.security.mappers.IdentityRoleMapper
- principalToRoles(Principal) - Method in interface org.infinispan.security.PrincipalRoleMapper
-
Maps a principal name to a set of role names.
- printable(char) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- printable(String) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- printArray(byte[]) - Static method in class org.infinispan.commons.util.Util
- printArray(byte[], boolean) - Static method in class org.infinispan.commons.util.Util
- printDebugStats() - Method in class org.infinispan.commons.util.FastCopyHashMap
- printFlags() - Method in class org.infinispan.commands.AbstractFlagAffectedCommand
- printFullVersionInformation() - Static method in class org.infinispan.commons.util.Version
-
Prints full version information to the standard output.
- printFullVersionInformation() - Static method in class org.infinispan.Version
-
Deprecated.Prints full version information to the standard output.
- printLockInfo() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticLockManager
- printLockInfo() - Method in class org.infinispan.extendedstats.wrappers.TopKeyLockManager
- printLockInfo() - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
- printLockInfo() - Method in interface org.infinispan.util.concurrent.locks.LockManager
-
Prints lock information for all locks.
- printStackTrace() - Method in exception org.infinispan.commons.configuration.io.xml.XmlPullParserException
- printVersion() - Static method in class org.infinispan.commons.util.Version
-
Returns version information as a string.
- printVersion() - Static method in class org.infinispan.Version
-
Deprecated.Returns version information as a string.
- printXid(int, byte[], byte[]) - Static method in class org.infinispan.commons.tx.XidImpl
- priority() - Method in class org.infinispan.configuration.global.ThreadFactoryConfigurationBuilder
- priority() - Element in annotation type org.infinispan.factories.annotations.Start
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 10.0, will be removed in a future version.
- priority() - Element in annotation type org.infinispan.factories.annotations.Stop
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 10.0, will be removed in a future version.
- priority(Integer) - Method in class org.infinispan.configuration.global.ThreadFactoryConfigurationBuilder
- PRIORITY - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- PRIVATE_METADATA - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- PRIVATE_NETWORKS - Static variable in class org.infinispan.server.hotrod.MultiHomedServerAddress.InetAddressWithNetMask
- PrivateMetadata - Class in org.infinispan.metadata.impl
-
A class to store internal metadata.
- PrivateMetadata.Builder - Class in org.infinispan.metadata.impl
- PrivateMetadata$___Marshaller_2707b1b527c228e45215e24669c8ab752e6a1689fb6e3510d925b1e899b8ee06 - Class in org.infinispan.metadata.impl
-
WARNING: Generated code! Do not edit!
- PrivateMetadata$___Marshaller_2707b1b527c228e45215e24669c8ab752e6a1689fb6e3510d925b1e899b8ee06() - Constructor for class org.infinispan.metadata.impl.PrivateMetadata$___Marshaller_2707b1b527c228e45215e24669c8ab752e6a1689fb6e3510d925b1e899b8ee06
- processCacheEntryCreated(ClientCacheEntryCustomEvent<byte[]>) - Method in class org.infinispan.spring.remote.session.RemoteApplicationPublishedBridge
- processCacheEntryCreated(CacheEntryCreatedEvent) - Method in class org.infinispan.spring.embedded.session.EmbeddedApplicationPublishedBridge
- processCacheEntryDestroyed(ClientCacheEntryCustomEvent<byte[]>) - Method in class org.infinispan.spring.remote.session.RemoteApplicationPublishedBridge
- processCacheEntryDestroyed(CacheEntryRemovedEvent) - Method in class org.infinispan.spring.embedded.session.EmbeddedApplicationPublishedBridge
- processCacheEntryExpired(ClientCacheEntryCustomEvent<byte[]>) - Method in class org.infinispan.spring.remote.session.RemoteApplicationPublishedBridge
- processCacheEntryExpired(CacheEntryExpiredEvent) - Method in class org.infinispan.spring.embedded.session.EmbeddedApplicationPublishedBridge
- processExpiration() - Method in interface org.infinispan.expiration.ExpirationManager
-
Processes the expiration event queue.
- processExpiration() - Method in class org.infinispan.expiration.impl.ClusterExpirationManager
- processExpiration() - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
- ProcessInfo - Class in org.infinispan.commons.jdkspecific
- PROCESSING_INSTRUCTION - Static variable in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
-
An XML processing instruction declaration was just read.
- processNamespaces - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- ProcessorInfo - Class in org.infinispan.commons.jdkspecific
-
JDK 10+ implementation
- ProcessorInfo - Class in org.infinispan.commons.util
-
Provides general information about the processors on this host.
- programmaticMapping() - Method in interface org.infinispan.search.mapper.mapping.MappingConfigurationContext
-
Start the definition of a programmatic mapping.
- programmaticMapping() - Method in class org.infinispan.search.mapper.mapping.SearchMappingBuilder
- ProgrammaticSearchMappingProvider - Interface in org.infinispan.search.mapper.mapping
-
An object responsible for configuring the Hibernate Search mapping.
- ProjectedJsonResult - Class in org.infinispan.query.remote.json
- ProjectedJsonResult(long, List<JsonProjection>) - Constructor for class org.infinispan.query.remote.json.ProjectedJsonResult
- projection() - Method in class org.infinispan.search.mapper.scope.impl.SearchScopeImpl
- projection() - Method in interface org.infinispan.search.mapper.scope.SearchScope
-
Initiate the building of a search projection that will be valid for the indexes in this scope.
- properties() - Method in class org.infinispan.client.hotrod.configuration.Configuration
- properties() - Method in class org.infinispan.commons.configuration.AbstractTypedPropertiesConfiguration
- properties() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- properties() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 12.0, indexing behaviour is defined by
IndexingConfiguration.writer()
andIndexingConfiguration.reader()
. - properties() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
- properties() - Method in class org.infinispan.configuration.global.GlobalJmxConfiguration
- properties() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
-
Deprecated.
- properties() - Method in class org.infinispan.configuration.global.TransportConfiguration
- properties(Properties) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
- PROPERTIES - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- PROPERTIES - Enum constant in enum org.infinispan.configuration.parsing.Element
- PROPERTIES - Enum constant in enum org.infinispan.persistence.remote.configuration.Element
- PROPERTIES - Enum constant in enum org.infinispan.server.hotrod.configuration.Element
- PROPERTIES - Static variable in class org.infinispan.commons.configuration.AbstractTypedPropertiesConfiguration
- PROPERTIES - Static variable in class org.infinispan.commons.configuration.attributes.PropertiesAttributeSerializer
- PROPERTIES - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- PROPERTIES - Static variable in class org.infinispan.configuration.global.GlobalJmxConfiguration
- PROPERTIES_FILE - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
- PropertiesAttributeSerializer - Class in org.infinispan.commons.configuration.attributes
- PropertiesAttributeSerializer(Enum<?>, Enum<?>, Enum<?>) - Constructor for class org.infinispan.commons.configuration.attributes.PropertiesAttributeSerializer
- PropertiesAttributeSerializer(String, String, String) - Constructor for class org.infinispan.commons.configuration.attributes.PropertiesAttributeSerializer
- property(String) - Static method in interface org.infinispan.query.dsl.Expression
-
Deprecated.
- PROPERTY - Enum constant in enum org.infinispan.configuration.parsing.Element
- PROPERTY - Enum constant in enum org.infinispan.server.hotrod.configuration.Element
- PROPERTY_FILE - Static variable in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfiguration
- PROPERTY_LOCATION - Static variable in class org.infinispan.commons.configuration.io.xml.MXParser
- PROPERTY_XMLDECL_CONTENT - Static variable in class org.infinispan.commons.configuration.io.xml.MXParser
- PROPERTY_XMLDECL_STANDALONE - Static variable in class org.infinispan.commons.configuration.io.xml.MXParser
- PROPERTY_XMLDECL_VERSION - Static variable in class org.infinispan.commons.configuration.io.xml.MXParser
- propertyFile() - Method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfiguration
- propertyFile(String) - Method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfigurationBuilder
- PropertyFormatter - Class in org.infinispan.configuration.format
-
Extracts the configuration into flat key-value property structure by reflection.
- PropertyFormatter - Class in org.infinispan.counter.api
-
A property style format for
CounterConfiguration
. - PropertyFormatter() - Constructor for class org.infinispan.configuration.format.PropertyFormatter
-
Create a new PropertyFormatter instance.
- PropertyFormatter() - Constructor for class org.infinispan.counter.api.PropertyFormatter
- PropertyFormatter(String, String) - Constructor for class org.infinispan.configuration.format.PropertyFormatter
-
Create a new PropertyFormatter instance.
- PropertyReplacer - Interface in org.infinispan.commons.configuration.io
- PropertyReplacer.Default - Class in org.infinispan.commons.configuration.io
- props - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- protect() - Method in class org.infinispan.commons.configuration.attributes.Attribute
- protect() - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Returns a new ValueSet where immutable
Attribute
s are write-protected - PROTO_KEY_SUFFIX - Static variable in interface org.infinispan.query.remote.client.ProtobufMetadataManagerConstants
-
All protobuf definition source files must end with this suffix.
- PROTO_SCHEMAS - Enum constant in enum org.infinispan.server.core.BackupManager.Resources.Type
- PROTOBUF_METADATA_CACHE_NAME - Static variable in interface org.infinispan.query.remote.client.ProtobufMetadataManagerConstants
-
The name of the Protobuf definitions cache.
- PROTOBUF_VALUE_WRAPPER - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- PROTOBUF_WRAPPER - Static variable in interface org.infinispan.commons.dataconversion.WrapperIds
- protobufMetadataManager() - Method in class org.infinispan.rest.InvocationHelper
- ProtobufMetadataManager - Interface in org.infinispan.query.remote
-
A clustered persistent and replicated repository of protobuf definition files.
- ProtobufMetadataManagerConstants - Interface in org.infinispan.query.remote.client
-
Useful constants used by the Protobuf metadata cache.
- ProtobufMetadataManagerMBean - Interface in org.infinispan.query.remote.client
-
MBean interface for ProtobufMetadataManager, suitable for building invocation proxies with one of the
JMX.newMBeanProxy(javax.management.MBeanServerConnection, javax.management.ObjectName, java.lang.Class<T>)
methods. - ProtobufResource - Class in org.infinispan.rest.resources
-
Protobuf schema manipulation Resource
- ProtobufResource(InvocationHelper, RestTelemetryService) - Constructor for class org.infinispan.rest.resources.ProtobufResource
- protocol() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
- protocol() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
- protocol() - Method in class org.infinispan.persistence.remote.configuration.SslConfiguration
- protocol() - Method in class org.infinispan.server.core.configuration.SslEngineConfiguration
- protocol(String) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
-
Configures the secure socket protocol.
- protocol(String) - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
-
Configures the secure socket protocol.
- protocol(String) - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
-
Configures the secure socket protocol.
- protocol(String) - Method in class org.infinispan.server.core.configuration.SslEngineConfigurationBuilder
-
Configures the secure socket protocol.
- PROTOCOL - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- PROTOCOL_METADATA - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsMetricsMetadata
- PROTOCOL_VERSION - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- PROTOCOL_VERSION - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- PROTOCOL_VERSION_20 - Enum constant in enum org.infinispan.client.hotrod.ProtocolVersion
- PROTOCOL_VERSION_21 - Enum constant in enum org.infinispan.client.hotrod.ProtocolVersion
- PROTOCOL_VERSION_22 - Enum constant in enum org.infinispan.client.hotrod.ProtocolVersion
- PROTOCOL_VERSION_23 - Enum constant in enum org.infinispan.client.hotrod.ProtocolVersion
- PROTOCOL_VERSION_24 - Enum constant in enum org.infinispan.client.hotrod.ProtocolVersion
- PROTOCOL_VERSION_25 - Enum constant in enum org.infinispan.client.hotrod.ProtocolVersion
- PROTOCOL_VERSION_26 - Enum constant in enum org.infinispan.client.hotrod.ProtocolVersion
- PROTOCOL_VERSION_27 - Enum constant in enum org.infinispan.client.hotrod.ProtocolVersion
- PROTOCOL_VERSION_28 - Enum constant in enum org.infinispan.client.hotrod.ProtocolVersion
- PROTOCOL_VERSION_29 - Enum constant in enum org.infinispan.client.hotrod.ProtocolVersion
- PROTOCOL_VERSION_30 - Enum constant in enum org.infinispan.client.hotrod.ProtocolVersion
- PROTOCOL_VERSION_31 - Enum constant in enum org.infinispan.client.hotrod.ProtocolVersion
- PROTOCOL_VERSION_40 - Enum constant in enum org.infinispan.client.hotrod.ProtocolVersion
- PROTOCOL_VERSION_AUTO - Enum constant in enum org.infinispan.client.hotrod.ProtocolVersion
- ProtocolFlag - Enum in org.infinispan.server.hotrod
- protocols() - Method in class org.infinispan.server.core.configuration.SslEngineConfiguration
- ProtocolServer<C extends ProtocolServerConfiguration> - Interface in org.infinispan.server.core
-
Represents a protocol compliant server.
- ProtocolServerConfiguration<T extends ProtocolServerConfiguration> - Class in org.infinispan.server.core.configuration
-
ServerConfiguration.
- ProtocolServerConfiguration(Enum<?>, AttributeSet, SslConfiguration, IpFilterConfiguration) - Constructor for class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- ProtocolServerConfiguration(String, AttributeSet, SslConfiguration, IpFilterConfiguration) - Constructor for class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- ProtocolServerConfigurationBuilder<T extends ProtocolServerConfiguration,
S extends ProtocolServerConfigurationChildBuilder<T, S>> - Class in org.infinispan.server.core.configuration - ProtocolServerConfigurationBuilder(int) - Constructor for class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- ProtocolServerConfigurationBuilder(int, AttributeSet) - Constructor for class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- ProtocolServerConfigurationChildBuilder<T extends ProtocolServerConfiguration,
S extends ProtocolServerConfigurationChildBuilder<T, S>> - Interface in org.infinispan.server.core.configuration -
ProtocolServerConfigurationChildBuilder.
- protocolVersion(String) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.
- protocolVersion(String) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.Use
ConfigurationBuilder.version(ProtocolVersion)
instead. - protocolVersion(String) - 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. Use
ConfigurationChildBuilder.version(ProtocolVersion)
instead. - protocolVersion(ProtocolVersion) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- protocolVersion(ProtocolVersion) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- protocolVersion(ProtocolVersion) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
-
This property defines the protocol version that this client should use.
- ProtocolVersion - Enum in org.infinispan.client.hotrod
-
Enumeration of supported Hot Rod client protocol VERSIONS.
- ProtoSchemaOptions(C, AbstractSchemaJdbcStore.Parameter[], String, AbstractSchemaJdbcStore.Parameter[], String, DataConversion, DataConversion, MarshallableEntryFactory<K, V>) - Constructor for class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.ProtoSchemaOptions
- PROTOSTREAM_WRAPPER - Static variable in interface org.infinispan.commons.dataconversion.WrapperIds
-
Deprecated, for removal: This API element is subject to removal in a future version.Replaced by PROTOBUF_WRAPPER. Will be removed in next minor version.
- ProtoStreamMarshaller - Class in org.infinispan.client.hotrod.marshall
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.0, will be removed in the future. org.infinispan.commons.marshall.ProtoStreamMarshaller should be used instead.
- ProtoStreamMarshaller - Class in org.infinispan.commons.marshall
-
Provides the starting point for implementing a
Marshaller
that uses Protobuf encoding. - ProtoStreamMarshaller() - Constructor for class org.infinispan.client.hotrod.marshall.ProtoStreamMarshaller
-
Deprecated.
- ProtoStreamMarshaller() - Constructor for class org.infinispan.commons.marshall.ProtoStreamMarshaller
- ProtoStreamMarshaller(SerializationContext) - Constructor for class org.infinispan.commons.marshall.ProtoStreamMarshaller
- ProtostreamTranscoder - Class in org.infinispan.encoding
-
Performs conversions between application/x-protostream and commons formats.
- ProtostreamTranscoder(SerializationContextRegistry, ClassLoader) - Constructor for class org.infinispan.encoding.ProtostreamTranscoder
- ProtoStreamTypeIds - Interface in org.infinispan.commons.marshall
-
TypeIds used by protostream in place of FQN message/enum names to reduce payload size.
- providedId - Variable in class org.infinispan.search.mapper.work.impl.IndexingOperation
- provider() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
- provider(String) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
-
Configures the SSL provider.
- provider(String) - Method in class org.infinispan.commons.util.SslContextFactory
- Proxies - Class in org.infinispan.commons.util
-
Proxies is a collection of useful dynamic profixes.
- Proxies() - Constructor for class org.infinispan.commons.util.Proxies
- PROXY_HOST - Static variable in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
- PROXY_PORT - Static variable in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
- proxyHost() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
- proxyHost(String) - Method in class org.infinispan.server.hotrod.configuration.AbstractHotRodServerChildConfigurationBuilder
- proxyHost(String) - Method in interface org.infinispan.server.hotrod.configuration.HotRodServerChildConfigurationBuilder
-
Sets the external address of this node, i.e.
- proxyHost(String) - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
-
Sets the external address of this node, i.e.
- proxyPort() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
- proxyPort(int) - Method in class org.infinispan.server.hotrod.configuration.AbstractHotRodServerChildConfigurationBuilder
- proxyPort(int) - Method in interface org.infinispan.server.hotrod.configuration.HotRodServerChildConfigurationBuilder
-
Sets the external port of this node, i.e.
- proxyPort(int) - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
-
Sets the external port of this node, i.e.
- publicHost() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
- publicPort() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
- publishEntries(boolean, boolean) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- publishEntries(String, Object[], Set<Integer>, int) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- publishEntries(String, Object[], Set<Integer>, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- publishEntries(String, Object[], Set<Integer>, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
Publishes the entries from the server in a non blocking fashion.
- publishEntries(Predicate<? super K>, boolean, boolean, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- publishEntries(Supplier<Connection>, Consumer<Connection>, IntSet, Predicate<? super K>, boolean) - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
- publishEntries(Supplier<Connection>, Consumer<Connection>, IntSet, Predicate<? super K>, boolean) - Method in interface org.infinispan.persistence.jdbc.common.TableOperations
- publishEntries(IntSet, Predicate<? super K>, boolean) - Method in class org.infinispan.persistence.async.AsyncNonBlockingStore
- publishEntries(IntSet, Predicate<? super K>, boolean) - Method in class org.infinispan.persistence.file.SingleFileStore
- publishEntries(IntSet, Predicate<? super K>, boolean) - Method in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
- publishEntries(IntSet, Predicate<? super K>, boolean) - Method in class org.infinispan.persistence.remote.RemoteStore
- publishEntries(IntSet, Predicate<? super K>, boolean) - Method in class org.infinispan.persistence.rocksdb.RocksDBStore
- publishEntries(IntSet, Predicate<? super K>, boolean) - Method in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
- publishEntries(IntSet, Predicate<? super K>, boolean) - Method in interface org.infinispan.persistence.spi.NonBlockingStore
-
Publishes entries from this store that are in one of the provided segments and also pass the provided filter.
- publishEntries(IntSet, Predicate<? super K>, boolean) - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
- publishEntries(IntSet, Predicate<? super K>, boolean) - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
- publishEntries(IntSet, Predicate<? super K>, boolean, boolean, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- publishEntriesByQuery(Query<?>, Set<Integer>, int) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- publishEntriesByQuery(Query<?>, Set<Integer>, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- publishEntriesByQuery(Query<?>, Set<Integer>, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
Publish entries from the server matching a query.
- publishEntriesWithMetadata(Set<Integer>, int) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- publishEntriesWithMetadata(Set<Integer>, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- publishEntriesWithMetadata(Set<Integer>, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
Publish entries with metadata information
- publisher - Variable in class org.infinispan.rest.stream.CacheChunkedStream
- publisher() - Method in interface org.infinispan.context.EntryLookup
-
Returns a Publisher that when subscribed to provide all values that have a value in the given context.
- publisher() - Method in class org.infinispan.context.impl.AbstractInvocationContext
- publisher() - Method in class org.infinispan.context.impl.ImmutableContext
- publisher() - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
- publisher(int) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
- publisher(int) - Method in interface org.infinispan.container.impl.InternalDataContainer
- publisher(IntSet) - Method in class org.infinispan.container.impl.DefaultDataContainer
- publisher(IntSet) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
- publisher(IntSet) - Method in interface org.infinispan.container.impl.InternalDataContainer
- PUBLISHER_REDUCERS - Static variable in interface org.infinispan.commons.marshall.Ids
- PUBLISHER_RESPONSE - Static variable in interface org.infinispan.commons.marshall.Ids
- PUBLISHER_TRANSFORMERS - Static variable in interface org.infinispan.commons.marshall.Ids
- PublisherHandler - Class in org.infinispan.reactive.publisher.impl
-
Handler for holding publisher results between requests of data
- PublisherHandler() - Constructor for class org.infinispan.reactive.publisher.impl.PublisherHandler
- PublisherHandler.SegmentResult - Class in org.infinispan.reactive.publisher.impl
- PublisherManagerFactory - Class in org.infinispan.factories
-
Factory that allows creation of a
LocalPublisherManager
orClusterPublisherManager
based on the provided configuration. - PublisherManagerFactory() - Constructor for class org.infinispan.factories.PublisherManagerFactory
- PublisherReducers - Class in org.infinispan.reactive.publisher
-
Static factory method class to provide various reducers and finalizers for use with distributed Publisher.
- PublisherReducers.PublisherReducersExternalizer - Class in org.infinispan.reactive.publisher
- PublisherReducersExternalizer() - Constructor for class org.infinispan.reactive.publisher.PublisherReducers.PublisherReducersExternalizer
- PublisherTransformers - Class in org.infinispan.reactive.publisher
-
Static factory method class to provide various transformers for use with distributed Publisher.
- PublisherTransformers.PublisherTransformersExternalizer - Class in org.infinispan.reactive.publisher
- PublisherTransformersExternalizer() - Constructor for class org.infinispan.reactive.publisher.PublisherTransformers.PublisherTransformersExternalizer
- publisherWithLostSegments() - Method in interface org.infinispan.reactive.publisher.impl.SegmentAwarePublisherSupplier
-
Same as
SegmentPublisherSupplier.publisherWithSegments()
, except that we also can notify a listener when a segment has been lost before publishing all its entries. - publisherWithLostSegments(boolean) - Method in interface org.infinispan.reactive.publisher.impl.SegmentAwarePublisherSupplier
-
Same as
SegmentPublisherSupplier.publisherWithSegments()
, except that we also can notify a listener when a segment has been lost before publishing all its entries - publisherWithoutSegments() - Method in interface org.infinispan.reactive.publisher.impl.SegmentAwarePublisherSupplier
-
When this method is used the
DeliveryGuarantee
is ignored as the user isn't listening to completion or lost segments - publisherWithoutSegments() - Method in interface org.infinispan.reactive.publisher.impl.SegmentPublisherSupplier
- publisherWithSegments() - Method in interface org.infinispan.reactive.publisher.impl.SegmentPublisherSupplier
- publishKeys(Predicate<? super K>) - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader
-
Deprecated.Publishes all the keys from this store.
- publishKeys(Predicate<? super K>) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- publishKeys(Predicate<? super K>, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- publishKeys(Supplier<Connection>, Consumer<Connection>, IntSet, Predicate<? super K>) - Method in interface org.infinispan.persistence.jdbc.common.TableOperations
- publishKeys(IntSet, Predicate<? super K>) - Method in class org.infinispan.persistence.async.AsyncNonBlockingStore
- publishKeys(IntSet, Predicate<? super K>) - Method in class org.infinispan.persistence.file.SingleFileStore
- publishKeys(IntSet, Predicate<? super K>) - Method in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
- publishKeys(IntSet, Predicate<? super K>) - Method in class org.infinispan.persistence.remote.RemoteStore
- publishKeys(IntSet, Predicate<? super K>) - Method in class org.infinispan.persistence.rocksdb.RocksDBStore
- publishKeys(IntSet, Predicate<? super K>) - Method in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
- publishKeys(IntSet, Predicate<? super K>) - Method in interface org.infinispan.persistence.spi.NonBlockingStore
-
Publishes keys from this store that are in one of the provided segments and also pass the provided filter.
- publishKeys(IntSet, Predicate<? super K>) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
-
Deprecated.Publishes all the keys that map to the given segments from this store.
- publishKeys(IntSet, Predicate<? super K>) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- publishKeys(IntSet, Predicate<? super K>) - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
- publishKeys(IntSet, Predicate<? super K>) - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
- publishKeys(IntSet, Predicate<? super K>, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- pullElementName() - Method in class org.infinispan.server.core.dataconversion.xml.MXParserReader
- pullNextEvent() - Method in class org.infinispan.server.core.dataconversion.xml.MXParserReader
- pullText() - Method in class org.infinispan.server.core.dataconversion.xml.MXParserReader
- purge() - Method in interface org.infinispan.search.mapper.scope.SearchWorkspace
-
Delete all documents from indexes targeted by this workspace.
- purge(Object, String) - Method in class org.infinispan.search.mapper.work.impl.SearchIndexerImpl
- purge(Object, String) - Method in interface org.infinispan.search.mapper.work.SearchIndexer
- purge(Executor, AdvancedCacheExpirationWriter.ExpirationPurgeListener<K, V>) - Method in interface org.infinispan.persistence.spi.AdvancedCacheExpirationWriter
-
Deprecated.Using the thread in the pool, removed all the expired data from the persistence storage.
- purge(Executor, AdvancedCacheExpirationWriter.ExpirationPurgeListener<K, V>) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
-
Deprecated.Using the thread in the pool, removed all the expired data from the persistence storage.
- purge(Executor, AdvancedCacheExpirationWriter.ExpirationPurgeListener<K, V>) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- purge(Executor, AdvancedCacheWriter.PurgeListener<? super K>) - Method in interface org.infinispan.persistence.spi.AdvancedCacheExpirationWriter
-
Deprecated.This method is never called.
- purge(Executor, AdvancedCacheWriter.PurgeListener<? super K>) - Method in interface org.infinispan.persistence.spi.AdvancedCacheWriter
-
Deprecated.Using the thread in the pool, removed all the expired data from the persistence storage.
- purge(Set<String>) - Method in interface org.infinispan.search.mapper.scope.SearchWorkspace
-
Delete documents from indexes targeted by this workspace that were indexed with any of the given routing keys.
- PURGE - Enum constant in enum org.infinispan.configuration.cache.IndexStartupMode
-
Purge will be triggered at cache startup time.
- PURGE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- PURGE_ON_STARTUP - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- purgeExpired() - Method in class org.infinispan.persistence.async.AsyncNonBlockingStore
- purgeExpired() - Method in class org.infinispan.persistence.file.SingleFileStore
- purgeExpired() - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- purgeExpired() - Method in class org.infinispan.persistence.remote.RemoteStore
- purgeExpired() - Method in class org.infinispan.persistence.rocksdb.RocksDBStore
- purgeExpired() - Method in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
- purgeExpired() - Method in interface org.infinispan.persistence.spi.NonBlockingStore
-
Returns a Publisher that, after it is subscribed to, removes any expired entries from the store and publishes them to the returned Publisher.
- purgeExpired() - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
- purgeExpired() - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- purgeExpired() - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
- PurgeIndexingOperation - Class in org.infinispan.search.mapper.work.impl
- purgeOnStartup() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
-
If true, purges this cache store when it starts up.
- purgeOnStartup() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
-
If true, purges this cache store when it starts up.
- purgeOnStartup(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
-
If true, purges this cache store when it starts up.
- purgeOnStartup(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
- purgeOnStartup(boolean) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
-
If true, purges this cache store when it starts up.
- purgingIndex(String) - Method in interface org.infinispan.query.logging.Log
- pushNDC(String, boolean) - Static method in class org.infinispan.util.logging.LogFactory
- pushNDC(ByteString, boolean) - Static method in class org.infinispan.util.logging.LogFactory
- pushScope(String) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
- put(int, K, V, Metadata, PrivateMetadata, long, long) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- put(int, K, V, Metadata, PrivateMetadata, long, long) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
- put(int, K, V, Metadata, PrivateMetadata, long, long) - Method in interface org.infinispan.container.impl.InternalDataContainer
-
Same as
DataContainer.put(Object, Object, Metadata)
except that the segment of the key can provided to write/lookup entries without calculating the segment for the given key. - put(int, WrappedBytes, WrappedBytes, Metadata, PrivateMetadata, long, long) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- put(int, WrappedBytes, WrappedBytes, Metadata, PrivateMetadata, long, long) - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
- put(Object, Object) - Method in class org.infinispan.spring.common.provider.SpringCache
- put(Object, Object, long, TimeUnit) - Method in class org.infinispan.spring.common.provider.SpringCache
- put(K) - Method in class org.infinispan.client.hotrod.impl.StreamingRemoteCacheImpl
- put(K) - Method in interface org.infinispan.client.hotrod.StreamingRemoteCache
-
Initiates a streaming put operation.
- put(K, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.StreamingRemoteCacheImpl
- put(K, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.StreamingRemoteCache
-
An overloaded form of
StreamingRemoteCache.put(Object)
, which takes in lifespan parameters. - put(K, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.StreamingRemoteCacheImpl
- put(K, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.StreamingRemoteCache
-
An overloaded form of
StreamingRemoteCache.put(Object)
, which takes in lifespan and maxIdle parameters. - put(K, V) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- put(K, V) - Method in class org.infinispan.cache.impl.CacheImpl
- put(K, V) - Method in class org.infinispan.cache.impl.DecoratedCache
- put(K, V) - Method in class org.infinispan.cache.impl.EncoderCache
- put(K, V) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- put(K, V) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- put(K, V) - Method in interface org.infinispan.commons.api.BasicCache
-
If the return value of this operation will be ignored by the application, the user is strongly encouraged to use the
Flag.IGNORE_RETURN_VALUES
flag when invoking this method in order to make it behave as efficiently as possible (i.e. - put(K, V) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
- put(K, V) - Method in class org.infinispan.commons.util.ArrayMap
- put(K, V) - Method in class org.infinispan.commons.util.FastCopyHashMap
- put(K, V) - Method in class org.infinispan.commons.util.HopscotchHashMap
- put(K, V) - Method in class org.infinispan.commons.util.WeakValueHashMap
- put(K, V) - Method in interface org.infinispan.multimap.api.BasicMultimapCache
-
Puts a key-value pair in this multimap cache.
- put(K, V) - Method in class org.infinispan.multimap.impl.EmbeddedMultimapCache
- put(K, V) - Method in class org.infinispan.security.impl.SecureCacheImpl
- put(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- put(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- put(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
- put(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- put(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- put(K, V, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- put(K, V, long, TimeUnit) - Method in interface org.infinispan.commons.api.BasicCache
-
An overloaded form of
BasicCache.put(Object, Object)
, which takes in lifespan parameters. - put(K, V, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
- put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- put(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.BasicCache
-
An overloaded form of
BasicCache.put(Object, Object)
, which takes in lifespan parameters. - put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- put(K, V, Metadata) - Method in interface org.infinispan.AdvancedCache
-
An overloaded form of
#put(K, V)
, which takes in an instance ofMetadata
which can be used to provide metadata information for the entry being stored, such as lifespan, version of value...etc. - put(K, V, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- put(K, V, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
- put(K, V, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
- put(K, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
- put(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- put(K, V, Metadata) - Method in interface org.infinispan.container.DataContainer
-
Puts an entry in the cache along with metadata adding information such lifespan of entry, max idle time, version information...etc.
- put(K, V, Metadata) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- put(K, V, Metadata) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
- put(K, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
- put(WrappedBytes, WrappedBytes, Metadata) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- put(WrappedBytes, WrappedBytes, Metadata) - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
- put(WrappedBytes, InternalCacheEntry<WrappedBytes, WrappedBytes>) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- PUT - Enum constant in enum org.infinispan.rest.framework.Method
- PUT - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- PUT_ALL - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- PUT_ALL_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- PUT_FOR_EXTERNAL_READ - Enum constant in enum org.infinispan.context.Flag
-
Flags the invocation as a
Cache.putForExternalRead(Object, Object)
call, as opposed to a regularBasicCache.put(Object, Object)
. - PUT_FOR_EXTERNAL_READ - Static variable in class org.infinispan.context.impl.FlagBitSets
- PUT_FOR_STATE_TRANSFER - Enum constant in enum org.infinispan.context.Flag
-
Flags the invocation as a put operation done internally by the state transfer.
- PUT_FOR_STATE_TRANSFER - Static variable in class org.infinispan.context.impl.FlagBitSets
- PUT_FOR_X_SITE_STATE_TRANSFER - Enum constant in enum org.infinispan.context.Flag
-
Flags the invocation as a put operation done internally by the cross-site state transfer.
- PUT_FOR_X_SITE_STATE_TRANSFER - Static variable in class org.infinispan.context.impl.FlagBitSets
- PUT_IF_ABSENT - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- PUT_IF_ABSENT_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- PUT_KEY_VALUE_FUNCTION - Static variable in interface org.infinispan.multimap.impl.ExternalizerIds
- PUT_MULTIMAP - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- PUT_MULTIMAP_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- PUT_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- PUT_STREAM - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- PUT_STREAM_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.CacheImpl
- putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.DecoratedCache
- putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.EncoderCache
- putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- putAll(Map<? extends K, ? extends V>) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
Adds or overrides each specified entry in the remote cache.
- putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
- putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.commons.util.FastCopyHashMap
- putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
- putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
Adds or overrides each specified entry in the remote cache.
- putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.commons.api.BasicCache
-
An overloaded form of
Map.putAll(Map)
, which takes in lifespan parameters. - putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
- putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
Adds or overrides each specified entry in the remote cache.
- putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.BasicCache
-
An overloaded form of
Map.putAll(Map)
, which takes in lifespan parameters. - putAll(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putAll(Map<? extends K, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
-
An overloaded form of
Map.putAll(Map)
, which takes in an instance ofMetadata
which can be used to provide metadata information for the entries being stored, such as lifespan, version of value...etc. - putAll(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- putAll(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
- putAll(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
- putAll(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
- putAll(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putAll(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putAll(Map<? extends WrappedBytes, ? extends InternalCacheEntry<WrappedBytes, WrappedBytes>>) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.CacheImpl
- putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.DecoratedCache
- putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.EncoderCache
- putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- putAllAsync(Map<? extends K, ? extends V>) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
Adds or overrides each specified entry in the remote cache.
- putAllAsync(Map<? extends K, ? extends V>) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
Map.putAll(Map)
. - putAllAsync(Map<? extends K, ? extends V>) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
- putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
Adds or overrides each specified entry in the remote cache.
- putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
BasicCache.putAll(Map, long, TimeUnit)
. - putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
- putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.InvalidatedNearRemoteCache
- putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
Adds or overrides each specified entry in the remote cache.
- putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
BasicCache.putAll(Map, long, TimeUnit, long, TimeUnit)
. - putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putAllAsync(Map<? extends K, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
- putAllAsync(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- putAllAsync(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
- putAllAsync(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
- putAllAsync(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
- putAllAsync(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putAllAsync(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putAllInternal(Map<? extends K, ? extends V>, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putAsync(K, V) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- putAsync(K, V) - Method in class org.infinispan.cache.impl.CacheImpl
- putAsync(K, V) - Method in class org.infinispan.cache.impl.DecoratedCache
- putAsync(K, V) - Method in class org.infinispan.cache.impl.EncoderCache
- putAsync(K, V) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putAsync(K, V) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- putAsync(K, V) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
BasicCache.put(Object, Object)
. - putAsync(K, V) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
- putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- putAsync(K, V, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
BasicCache.put(Object, Object, long, TimeUnit)
. - putAsync(K, V, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
- putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.InvalidatedNearRemoteCache
- putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
BasicCache.put(Object, Object, long, TimeUnit, long, TimeUnit)
. - putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putAsync(K, V, Metadata) - Method in interface org.infinispan.AdvancedCache
-
Asynchronous version of
AdvancedCache.put(Object, Object, Metadata)
which stores metadata alongside the value. - putAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- putAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
- putAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
- putAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
- putAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putAsync(K, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putAsyncEntry(K, V, Metadata) - Method in interface org.infinispan.AdvancedCache
-
Extension of
AdvancedCache.putAsync(K, V, Metadata)
which returns aCacheEntry
instead of only the previous value. - putAsyncEntry(K, V, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- putAsyncEntry(K, V, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
- putAsyncEntry(K, V, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
- putAsyncEntry(K, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
- putAsyncEntry(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putAsyncEntry(K, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putAsyncReturnEntry(K, V, Metadata) - Method in interface org.infinispan.AdvancedCache
- putAsyncReturnEntry(K, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
- putAsyncReturnEntry(K, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putConfiguration(String, Configuration) - Method in class org.infinispan.configuration.ConfigurationManager
- putConfiguration(String, ConfigurationBuilder) - Method in class org.infinispan.configuration.ConfigurationManager
- putEntryInMap(PeekableTouchableMap<K, V>, int, K, InternalCacheEntry<K, V>) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
- putEntryInMap(PeekableTouchableMap<K, V>, int, K, InternalCacheEntry<K, V>) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
- putForExternalRead(K, V) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- putForExternalRead(K, V) - Method in class org.infinispan.cache.impl.CacheImpl
- putForExternalRead(K, V) - Method in class org.infinispan.cache.impl.DecoratedCache
- putForExternalRead(K, V) - Method in class org.infinispan.cache.impl.EncoderCache
- putForExternalRead(K, V) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putForExternalRead(K, V) - Method in interface org.infinispan.Cache
-
Under special operating behavior, associates the value with the specified key.
- putForExternalRead(K, V) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putForExternalRead(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- putForExternalRead(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- putForExternalRead(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
- putForExternalRead(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- putForExternalRead(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putForExternalRead(K, V, long, TimeUnit) - Method in interface org.infinispan.Cache
-
An overloaded form of
Cache.putForExternalRead(K, V)
, which takes in lifespan parameters. - putForExternalRead(K, V, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putForExternalRead(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- putForExternalRead(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- putForExternalRead(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
- putForExternalRead(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- putForExternalRead(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putForExternalRead(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
-
An overloaded form of
Cache.putForExternalRead(K, V)
, which takes in lifespan parameters. - putForExternalRead(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putForExternalRead(K, V, Metadata) - Method in interface org.infinispan.AdvancedCache
-
An overloaded form of
#putForExternalRead(K, V)
, which takes in an instance ofMetadata
which can be used to provide metadata information for the entry being stored, such as lifespan, version of value...etc. - putForExternalRead(K, V, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- putForExternalRead(K, V, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
- putForExternalRead(K, V, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
- putForExternalRead(K, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
- putForExternalRead(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putForExternalRead(K, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putForExternalReadInternal(K, V, Metadata, ByRef.Boolean) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putForExternalReadInternal(K, V, Metadata, ByRef.Boolean) - Method in class org.infinispan.cache.impl.StatsCollectingCache
- putIfAbsent(Object, Object) - Method in class org.infinispan.spring.common.provider.SpringCache
- putIfAbsent(String, String) - Method in class org.infinispan.commons.util.TypedProperties
-
Put a value if the associated key is not present
- putIfAbsent(K) - Method in class org.infinispan.client.hotrod.impl.StreamingRemoteCacheImpl
- putIfAbsent(K) - Method in interface org.infinispan.client.hotrod.StreamingRemoteCache
-
A conditional form of put which inserts an entry into the cache only if no mapping for the key is already present.
- putIfAbsent(K, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.StreamingRemoteCacheImpl
- putIfAbsent(K, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.StreamingRemoteCache
-
An overloaded form of
StreamingRemoteCache.putIfAbsent(Object)
which takes in lifespan parameters. - putIfAbsent(K, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.StreamingRemoteCacheImpl
- putIfAbsent(K, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.StreamingRemoteCache
-
An overloaded form of
StreamingRemoteCache.putIfAbsent(Object)
which takes in lifespan and maxIdle parameters. - putIfAbsent(K, MetadataValue<V>) - Method in interface org.infinispan.client.hotrod.near.NearCache
- putIfAbsent(K, MetadataValue<V>) - Method in class org.infinispan.client.hotrod.near.NearCacheService
- putIfAbsent(K, V) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- putIfAbsent(K, V) - Method in class org.infinispan.cache.impl.CacheImpl
- putIfAbsent(K, V) - Method in class org.infinispan.cache.impl.DecoratedCache
- putIfAbsent(K, V) - Method in class org.infinispan.cache.impl.EncoderCache
- putIfAbsent(K, V) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putIfAbsent(K, V) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- putIfAbsent(K, V) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
- putIfAbsent(K, V) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
- putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- putIfAbsent(K, V, long, TimeUnit) - Method in interface org.infinispan.commons.api.BasicCache
-
An overloaded form of
ConcurrentMap.putIfAbsent(Object, Object)
, which takes in lifespan parameters. - putIfAbsent(K, V, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
- putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.BasicCache
-
An overloaded form of
ConcurrentMap.putIfAbsent(Object, Object)
, which takes in lifespan parameters. - putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putIfAbsent(K, V, Metadata) - Method in interface org.infinispan.AdvancedCache
-
An overloaded form of
#putIfAbsent(K, V)
, which takes in an instance ofMetadata
which can be used to provide metadata information for the entry being stored, such as lifespan, version of value...etc. - putIfAbsent(K, V, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- putIfAbsent(K, V, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
- putIfAbsent(K, V, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
- putIfAbsent(K, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
- putIfAbsent(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putIfAbsent(K, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putIfAbsent(WrappedBytes, InternalCacheEntry<WrappedBytes, WrappedBytes>) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- putIfAbsentAsync(K, V) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- putIfAbsentAsync(K, V) - Method in class org.infinispan.cache.impl.CacheImpl
- putIfAbsentAsync(K, V) - Method in class org.infinispan.cache.impl.DecoratedCache
- putIfAbsentAsync(K, V) - Method in class org.infinispan.cache.impl.EncoderCache
- putIfAbsentAsync(K, V) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putIfAbsentAsync(K, V) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- putIfAbsentAsync(K, V) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
ConcurrentMap.putIfAbsent(Object, Object)
. - putIfAbsentAsync(K, V) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
- putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- putIfAbsentAsync(K, V, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
BasicCache.putIfAbsent(Object, Object, long, TimeUnit)
. - putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
- putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
BasicCache.putIfAbsent(Object, Object, long, TimeUnit, long, TimeUnit)
. - putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putIfAbsentAsync(K, V, Metadata) - Method in interface org.infinispan.AdvancedCache
-
An overloaded form of
#putIfAbsentAsync(K, V)
, which takes in an instance ofMetadata
which can be used to provide metadata information for the entry being stored, such as lifespan, version of value...etc. - putIfAbsentAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- putIfAbsentAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
- putIfAbsentAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
- putIfAbsentAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
- putIfAbsentAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putIfAbsentAsync(K, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putIfAbsentAsyncEntry(K, V, Metadata) - Method in interface org.infinispan.AdvancedCache
-
An extension form of
AdvancedCache.putIfAbsentAsync(K, V, Metadata)
, which returns aCacheEntry
instead of only the value. - putIfAbsentAsyncEntry(K, V, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- putIfAbsentAsyncEntry(K, V, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
- putIfAbsentAsyncEntry(K, V, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
- putIfAbsentAsyncEntry(K, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
- putIfAbsentAsyncEntry(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putIfAbsentAsyncEntry(K, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putIfAbsentAsyncReturnEntry(K, V, Metadata) - Method in interface org.infinispan.AdvancedCache
- putIfAbsentAsyncReturnEntry(K, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
- putIfAbsentAsyncReturnEntry(K, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
- putIfAbsentInternal(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- putIfAbsentInternal(K, V, Metadata) - Method in class org.infinispan.cache.impl.StatsCollectingCache
- PutIfAbsentRequest - Enum constant in enum org.infinispan.server.memcached.MemcachedOperation
- putLookedUpEntries(Map<Object, CacheEntry>) - Method in class org.infinispan.transaction.impl.LocalTransaction
- putLookedUpEntries(Map<Object, CacheEntry>) - Method in class org.infinispan.transaction.impl.RemoteTransaction
- putLookedUpEntries(Map<Object, CacheEntry>) - Method in interface org.infinispan.transaction.xa.CacheTransaction
- putLookedUpEntry(Object, CacheEntry) - Method in interface org.infinispan.context.EntryLookup
-
Puts an entry in the registry of looked up entries in the current scope.
- putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
- putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.context.impl.ClearInvocationContext
- putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.context.impl.ImmutableContext
- putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.context.impl.NonTxInvocationContext
- putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
- putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.transaction.impl.LocalTransaction
- putLookedUpEntry(Object, CacheEntry) - Method in class org.infinispan.transaction.impl.RemoteTransaction
- putLookedUpEntry(Object, CacheEntry) - Method in interface org.infinispan.transaction.xa.CacheTransaction
- putMemoryAddressOffset(int, long) - Method in class org.infinispan.container.offheap.MemoryAddressHash
- putNoReturn(K, InternalCacheEntry<K, V>) - Method in interface org.infinispan.container.impl.PeekableTouchableMap
-
Same as
Map.put(Object, Object)
except that the map is not required to return a value. - putNoReturn(WrappedBytes, InternalCacheEntry<WrappedBytes, WrappedBytes>) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- PutRequest - Enum constant in enum org.infinispan.server.memcached.MemcachedOperation
Q
- QName(String, String) - Constructor for class org.infinispan.configuration.parsing.ParserRegistry.QName
- qop() - Method in class org.infinispan.server.hotrod.configuration.SaslConfiguration
- QOP - Enum in org.infinispan.server.hotrod.configuration
- QOP - Enum constant in enum org.infinispan.server.hotrod.configuration.Attribute
- QOP - Static variable in class org.infinispan.server.hotrod.configuration.SaslConfiguration
- queries() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfigurationBuilder
- QUERIES - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
- QueriesJdbcConfiguration - Class in org.infinispan.persistence.sql.configuration
- queriesJdbcConfigurationBuilder() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.use
QueriesJdbcStoreConfigurationBuilder.queries()
instead - QueriesJdbcConfigurationBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,
S>> - Class in org.infinispan.persistence.sql.configuration -
QueriesJdbcConfigurationBuilder.
- QueriesJdbcConfigurationBuilder(AbstractJdbcStoreConfigurationBuilder<?, S>) - Constructor for class org.infinispan.persistence.sql.configuration.QueriesJdbcConfigurationBuilder
- QueriesJdbcStore<K,
V> - Class in org.infinispan.persistence.sql - QueriesJdbcStore() - Constructor for class org.infinispan.persistence.sql.QueriesJdbcStore
- QueriesJdbcStore.QueryTableOperations - Class in org.infinispan.persistence.sql
- QueriesJdbcStoreConfiguration - Class in org.infinispan.persistence.sql.configuration
- QueriesJdbcStoreConfiguration(AttributeSet, AsyncStoreConfiguration, ConnectionFactoryConfiguration, SchemaJdbcConfiguration, QueriesJdbcConfiguration) - Constructor for class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfiguration
- QueriesJdbcStoreConfigurationBuilder - Class in org.infinispan.persistence.sql.configuration
-
QueriesJdbcStoreConfigurationBuilder.
- QueriesJdbcStoreConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfigurationBuilder
- QueriesJdbcStoreConfigurationSerializer - Class in org.infinispan.persistence.sql.configuration
-
QueriesJdbcStoreConfigurationSerializer.
- QueriesJdbcStoreConfigurationSerializer() - Constructor for class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfigurationSerializer
- query() - Method in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
- query() - Method in class org.infinispan.configuration.cache.Configuration
- query() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- query() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- query(AdvancedCache<?, ?>, byte[]) - Method in interface org.infinispan.server.core.QueryFacade
-
Execute a query against a cache.
- Query<T> - Interface in org.infinispan.query.dsl
-
An immutable object representing both the query and the result.
- QUERY - Enum constant in enum org.infinispan.configuration.parsing.Element
- QUERY - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- QUERY_DSL_FILTER_FACTORY_NAME - Static variable in class org.infinispan.client.hotrod.filter.Filters
-
The name of the factory used for query DSL based filters and converters.
- QUERY_ITERATION_FILTER - Static variable in class org.infinispan.server.core.ExternalizerIds
- QUERY_JDBC_STORE - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
- QUERY_LOWER_BOUND - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- QUERY_METRICS - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- QUERY_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- QUERY_STRING - Static variable in interface org.infinispan.query.remote.json.JSONConstants
- QueryBlockHoundIntegration - Class in org.infinispan.query.internal
- QueryBlockHoundIntegration() - Constructor for class org.infinispan.query.internal.QueryBlockHoundIntegration
- QueryBuilder - Interface in org.infinispan.query.dsl
-
Deprecated.since 10.1. The Ickle query language is now preferred over the
QueryBuilder
. SeeQueryFactory.create(java.lang.String)
. TheQueryBuilder
and associated context interfaces will be removed in version 11.0. - QueryConfiguration - Class in org.infinispan.configuration.cache
-
Configures query options and defaults
- QueryConfiguration(AttributeSet) - Constructor for class org.infinispan.configuration.cache.QueryConfiguration
- QueryConfigurationBuilder - Class in org.infinispan.configuration.cache
- QueryConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.QueryConfigurationBuilder
- queryDefinition - Variable in class org.infinispan.query.impl.IndexedQueryImpl
- QueryDefinition - Class in org.infinispan.query.impl
-
Wraps the query to be executed in a cache represented either as an Ickle query String or as a
SearchQuery
together with parameters and pagination and sort information. - QueryDefinition(String, IckleParsingResult.StatementType, SearchQueryBuilder, int) - Constructor for class org.infinispan.query.impl.QueryDefinition
- QueryDefinition(String, IckleParsingResult.StatementType, SerializableFunction<AdvancedCache<?, ?>, QueryEngine<?>>, int) - Constructor for class org.infinispan.query.impl.QueryDefinition
- QueryDefinition.Externalizer - Class in org.infinispan.query.impl
- QueryFacade - Interface in org.infinispan.server.core
-
Query facade SPI.
- QueryFactory - Interface in org.infinispan.query.dsl
-
Factory for query DSL objects.
- QueryModuleCommandExtensions - Class in org.infinispan.query.impl
- QueryModuleCommandExtensions() - Constructor for class org.infinispan.query.impl.QueryModuleCommandExtensions
- QueryNamedParameterParser - Class in org.infinispan.persistence.sql
- QueryNamedParameterParser() - Constructor for class org.infinispan.persistence.sql.QueryNamedParameterParser
- QueryNamedParameterParser.ParserResults - Class in org.infinispan.persistence.sql
- QueryResult<E> - Interface in org.infinispan.query.dsl
-
Represents the result of a
Query
. - queryStatistics - Variable in class org.infinispan.query.impl.IndexedQueryImpl
- QueryTableOperations(AbstractSchemaJdbcStore.ProtoSchemaOptions<K, V, QueriesJdbcStoreConfiguration>, AbstractSchemaJdbcStore.Parameter[], QueriesJdbcConfiguration) - Constructor for class org.infinispan.persistence.sql.QueriesJdbcStore.QueryTableOperations
- queue() - Method in class org.infinispan.extendedstats.container.ConcurrentGlobalContainer
- QUEUE - Static variable in interface org.infinispan.commons.marshall.Ids
- QUEUE_COUNT - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- QUEUE_FLUSH_INTERVAL - Enum constant in enum org.infinispan.configuration.parsing.Attribute
-
Deprecated, for removal: This API element is subject to removal in a future version.
- QUEUE_LENGTH - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- QUEUE_SIZE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- QUEUE_SIZE - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.Attribute
- queueConflictResolution(CacheTopology, Set<Address>) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
-
Initiates conflict resolution using the conflictTopology, which should have already been broadcast via {@link this#updateTopologiesAfterMerge(CacheTopology, CacheTopology, AvailabilityMode)}
- queueConflictResolution(CacheTopology, Set<Address>) - Method in class org.infinispan.topology.ClusterCacheStatus
- queueCount(int) - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
- QueueingSegmentListener<K,
V, E extends Event<K, V>> - Interface in org.infinispan.notifications.cachelistener -
This interface describes methods needed for a segment listener that is used when iterating over the current events and be able to queue them properly
- queueLength - Variable in class org.infinispan.factories.threads.AbstractThreadPoolExecutorFactory
- queueLength() - Method in class org.infinispan.commons.executors.BlockingThreadPoolExecutorFactory
-
Deprecated.
- queueLength() - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
- queueLength() - Method in class org.infinispan.factories.threads.AbstractThreadPoolExecutorFactory
- queueLength(Integer) - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
- queueRebalance(List<Address>) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
-
Queue (or start) a rebalance.
- queueRebalance(List<Address>) - Method in class org.infinispan.topology.ClusterCacheStatus
- queueSize(int) - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
- QuitRequest - Enum constant in enum org.infinispan.server.memcached.MemcachedOperation
R
- RACK - Enum constant in enum org.infinispan.distribution.topologyaware.TopologyLevel
- RACK_ID - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- RACK_ID - Static variable in class org.infinispan.configuration.global.TransportConfiguration
- rackId() - Method in class org.infinispan.configuration.global.TransportConfiguration
- rackId(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
-
The id of the rack where this node runs.
- RAFT_MEMBERS - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- RAFT_MEMBERS - Static variable in class org.infinispan.configuration.global.TransportConfiguration
- raftId() - Method in enum org.infinispan.remoting.transport.impl.EmptyRaftManager
- raftManager() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- raftManager() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- raftManager() - Method in interface org.infinispan.remoting.transport.Transport
- raftMember(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
-
Adds a single member to the
raft-members
. - raftMembers() - Method in class org.infinispan.configuration.global.TransportConfiguration
- raftMembers(String...) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
-
Adds multiple members to the
raft-members
. - raftMembers(Collection<String>) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
-
Adds multiple members to the
raft-members
. - RaftUtil - Enum in org.infinispan.remoting.transport.jgroups
-
Utility methods for jgroups-raft
- RAM_BUFFER_SIZE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- ramBufferSize(int) - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
- randomUUID() - Static method in class org.infinispan.topology.PersistentUUID
- randomUUID(String, String, String, String) - Static method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
- RangeConditionContext - Interface in org.infinispan.query.dsl
-
Deprecated.since 10.1. See deprecation note on
QueryBuilder
. - RangeConditionContextQueryBuilder - Interface in org.infinispan.query.dsl
-
Deprecated.since 10.1. See deprecation note on
QueryBuilder
. - RangeSet - Class in org.infinispan.commons.util
-
Deprecated, for removal: This API element is subject to removal in a future version.since 9.3 This class will no longer be public. Please use
IntSets.immutableRangeSet(int)
instead. - RangeSet(int) - Constructor for class org.infinispan.commons.util.RangeSet
-
Deprecated.
- RankCalculator - Class in org.infinispan.container.versioning
-
Compute the version prefix to be used by
NumericVersionGenerator
in clustered caches. - RankCalculator() - Constructor for class org.infinispan.container.versioning.RankCalculator
- raw(String) - Method in class org.infinispan.commons.dataconversion.internal.Json.DefaultFactory
- raw(String) - Method in interface org.infinispan.commons.dataconversion.internal.Json.Factory
- RAW_VALUES - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- rawContent() - Method in class org.infinispan.rest.ByteBufContentSource
- rawContent() - Method in interface org.infinispan.rest.framework.ContentSource
- rawData() - Method in class org.infinispan.commons.tx.XidImpl
- rawValue - Variable in class org.infinispan.server.memcached.MemcachedDecoder
- rawValues() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.since 12.0 - This option can still be needed when retrieving from a preexisting remote cache
- rawValues(boolean) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- rawValues(boolean) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.
- rawValues(boolean) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
-
Normally the
RemoteStore
stores values wrapped inInternalCacheEntry
. - reachedEnd - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- read() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- read() - Method in class org.infinispan.commons.time.TimeServiceTicker
- read() - Method in class org.infinispan.io.GridInputStream
-
Deprecated.
- read() - Method in class org.infinispan.io.UnclosableObjectInputStream
-
Deprecated.
- read() - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
- read(byte[]) - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- read(byte[]) - Method in class org.infinispan.io.GridInputStream
-
Deprecated.
- read(byte[]) - Method in class org.infinispan.io.UnclosableObjectInputStream
-
Deprecated.
- read(byte[]) - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
- read(byte[], int, int) - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- read(byte[], int, int) - Method in class org.infinispan.io.GridInputStream
-
Deprecated.
- read(byte[], int, int) - Method in class org.infinispan.io.UnclosableObjectInputStream
-
Deprecated.
- read(byte[], int, int) - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
- read(ByteBuf) - Static method in class org.infinispan.server.core.transport.VInt
- read(ByteBuf) - Static method in class org.infinispan.server.core.transport.VLong
- read(ChannelHandlerContext) - Method in class org.infinispan.server.core.transport.SaslQopHandler
- read(InputStream) - Static method in class org.infinispan.commons.util.Util
-
Reads the given InputStream fully, closes the stream and returns the result as a String.
- read(String) - Static method in class org.infinispan.commons.dataconversion.internal.Json
-
Parse a JSON entity from its string representation.
- read(URL) - Static method in class org.infinispan.commons.dataconversion.internal.Json
-
Parse a JSON entity from a
URL
. - read(ByteBuffer) - Method in class org.infinispan.io.ReadableGridFileChannel
-
Deprecated.
- read(ByteBuffer, long) - Method in class org.infinispan.persistence.sifs.FileProvider.Handle
- read(CharacterIterator) - Static method in class org.infinispan.commons.dataconversion.internal.Json
-
Parse a JSON entity from a
CharacterIterator
. - read(AuthenticationConfiguration, Combine) - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
- read(ClusterConfiguration, Combine) - Method in class org.infinispan.client.hotrod.configuration.ClusterConfigurationBuilder
- read(Configuration) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- read(Configuration, Combine) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- read(ConnectionPoolConfiguration, Combine) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
- read(ExecutorFactoryConfiguration, Combine) - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfigurationBuilder
- read(NearCacheConfiguration, Combine) - Method in class org.infinispan.client.hotrod.configuration.NearCacheConfigurationBuilder
- read(RemoteCacheConfiguration, Combine) - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfigurationBuilder
- read(SecurityConfiguration, Combine) - Method in class org.infinispan.client.hotrod.configuration.SecurityConfigurationBuilder
- read(ServerConfiguration, Combine) - Method in class org.infinispan.client.hotrod.configuration.ServerConfigurationBuilder
- read(SslConfiguration, Combine) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
- read(StatisticsConfiguration, Combine) - Method in class org.infinispan.client.hotrod.configuration.StatisticsConfigurationBuilder
- read(TransactionConfiguration, Combine) - Method in class org.infinispan.client.hotrod.configuration.TransactionConfigurationBuilder
-
Deprecated.
- read(Attribute<T>) - Method in class org.infinispan.commons.configuration.attributes.Attribute
- read(AttributeSet, Combine) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Copies all attribute from another AttributeSet using the supplied
Combine.Attributes
strategy. - read(ClassAllowList) - Method in class org.infinispan.commons.configuration.ClassAllowList
- read(AsyncStoreConfiguration, Combine) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
- read(AuthorizationConfiguration, Combine) - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
- read(BackupConfiguration, Combine) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
- read(BackupForConfiguration, Combine) - Method in class org.infinispan.configuration.cache.BackupForBuilder
- read(ClusteringConfiguration, Combine) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
- read(ClusterLoaderConfiguration, Combine) - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
-
Deprecated.
- read(Configuration) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- read(Configuration, Combine) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- read(ContentTypeConfiguration, Combine) - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
- read(CustomInterceptorsConfiguration, Combine) - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
-
Deprecated.
- read(CustomStoreConfiguration, Combine) - Method in class org.infinispan.configuration.cache.CustomStoreConfigurationBuilder
- read(EncodingConfiguration, Combine) - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
- read(ExpirationConfiguration, Combine) - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
- read(GroupsConfiguration, Combine) - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
- read(HashConfiguration, Combine) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
- read(IndexingConfiguration, Combine) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
- read(IndexMergeConfiguration, Combine) - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
- read(IndexReaderConfiguration, Combine) - Method in class org.infinispan.configuration.cache.IndexReaderConfigurationBuilder
- read(IndexWriterConfiguration, Combine) - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
- read(InterceptorConfiguration, Combine) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
-
Deprecated.
- read(InvocationBatchingConfiguration, Combine) - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
- read(L1Configuration, Combine) - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
- read(LockingConfiguration, Combine) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
- read(MemoryConfiguration, Combine) - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
- read(MemoryStorageConfiguration, Combine) - Method in class org.infinispan.configuration.cache.MemoryStorageConfigurationBuilder
-
Deprecated.
- read(PartitionHandlingConfiguration, Combine) - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
- read(PersistenceConfiguration, Combine) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
- read(QueryConfiguration, Combine) - Method in class org.infinispan.configuration.cache.QueryConfigurationBuilder
- read(RecoveryConfiguration, Combine) - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
- read(SecurityConfiguration, Combine) - Method in class org.infinispan.configuration.cache.SecurityConfigurationBuilder
- read(SingleFileStoreConfiguration, Combine) - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
- read(SitesConfiguration, Combine) - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
- read(StateTransferConfiguration, Combine) - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
- read(StatisticsConfiguration, Combine) - Method in class org.infinispan.configuration.cache.StatisticsConfigurationBuilder
- read(TakeOfflineConfiguration, Combine) - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
- read(TransactionConfiguration, Combine) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
- read(UnsafeConfiguration, Combine) - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
- read(XSiteStateTransferConfiguration, Combine) - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
- read(AllowListConfiguration, Combine) - Method in class org.infinispan.configuration.global.AllowListConfigurationBuilder
- read(BoundedThreadPoolConfiguration, Combine) - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
- read(CacheContainerConfiguration, Combine) - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
- read(CachedThreadPoolConfiguration, Combine) - Method in class org.infinispan.configuration.global.CachedThreadPoolConfigurationBuilder
- read(ExecutorFactoryConfiguration, Combine) - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
- read(GlobalAuthorizationConfiguration, Combine) - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
- read(GlobalConfiguration) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- read(GlobalJmxConfiguration, Combine) - Method in class org.infinispan.configuration.global.GlobalJmxConfigurationBuilder
- read(GlobalMetricsConfiguration, Combine) - Method in class org.infinispan.configuration.global.GlobalMetricsConfigurationBuilder
- read(GlobalSecurityConfiguration, Combine) - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
- read(GlobalStateConfiguration, Combine) - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
- read(GlobalStatePathConfiguration, Combine) - Method in class org.infinispan.configuration.global.GlobalStatePathConfigurationBuilder
- read(GlobalStorageConfiguration, Combine) - Method in class org.infinispan.configuration.global.GlobalStorageConfigurationBuilder
- read(JGroupsConfiguration, Combine) - Method in class org.infinispan.configuration.global.JGroupsConfigurationBuilder
- read(PrincipalRoleMapperConfiguration, Combine) - Method in class org.infinispan.configuration.global.PrincipalRoleMapperConfigurationBuilder
- read(RolePermissionMapperConfiguration, Combine) - Method in class org.infinispan.configuration.global.RolePermissionMapperConfigurationBuilder
- read(ScheduledExecutorFactoryConfiguration, Combine) - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
- read(ScheduledThreadPoolConfiguration, Combine) - Method in class org.infinispan.configuration.global.ScheduledThreadPoolConfigurationBuilder
- read(SerializationConfiguration, Combine) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
- read(ShutdownConfiguration, Combine) - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
- read(SiteConfiguration, Combine) - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
-
Deprecated.
- read(StackConfiguration, Combine) - Method in class org.infinispan.configuration.global.StackConfigurationBuilder
- read(StackFileConfiguration, Combine) - Method in class org.infinispan.configuration.global.StackFileConfigurationBuilder
- read(TemporaryGlobalStatePathConfiguration, Combine) - Method in class org.infinispan.configuration.global.TemporaryGlobalStatePathConfigurationBuilder
- read(ThreadFactoryConfiguration, Combine) - Method in class org.infinispan.configuration.global.ThreadFactoryConfigurationBuilder
- read(ThreadPoolConfiguration, Combine) - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
- read(ThreadsConfiguration, Combine) - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
- read(TransportConfiguration, Combine) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
- read(WhiteListConfiguration, Combine) - Method in class org.infinispan.configuration.global.WhiteListConfigurationBuilder
-
Deprecated.
- read(CounterManagerConfiguration, Combine) - Method in class org.infinispan.counter.configuration.CounterManagerConfigurationBuilder
- read(StrongCounterConfiguration, Combine) - Method in class org.infinispan.counter.configuration.StrongCounterConfigurationBuilder
- read(WeakCounterConfiguration, Combine) - Method in class org.infinispan.counter.configuration.WeakCounterConfigurationBuilder
- read(ClusteredLockConfiguration, Combine) - Method in class org.infinispan.lock.configuration.ClusteredLockConfigurationBuilder
- read(ClusteredLockManagerConfiguration, Combine) - Method in class org.infinispan.lock.configuration.ClusteredLockManagerConfigurationBuilder
- read(MicrometerMeterRegistryConfiguration, Combine) - Method in class org.infinispan.metrics.config.MicrometerMeterRegisterConfigurationBuilder
- read(ManagedConnectionFactoryConfiguration, Combine) - Method in class org.infinispan.persistence.jdbc.common.configuration.ManagedConnectionFactoryConfigurationBuilder
- read(PooledConnectionFactoryConfiguration, Combine) - Method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfigurationBuilder
- read(SimpleConnectionFactoryConfiguration, Combine) - Method in class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfigurationBuilder
- read(DataColumnConfiguration, Combine) - Method in class org.infinispan.persistence.jdbc.configuration.DataColumnConfigurationBuilder
- read(IdColumnConfiguration, Combine) - Method in class org.infinispan.persistence.jdbc.configuration.IdColumnConfigurationBuilder
- read(JdbcStringBasedStoreConfiguration, Combine) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
- read(SegmentColumnConfiguration, Combine) - Method in class org.infinispan.persistence.jdbc.configuration.SegmentColumnConfigurationBuilder
- read(TableManipulationConfiguration, Combine) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
- read(TimestampColumnConfiguration, Combine) - Method in class org.infinispan.persistence.jdbc.configuration.TimestampColumnConfigurationBuilder
- read(AuthenticationConfiguration, Combine) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
- read(ConnectionPoolConfiguration, Combine) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
- read(ExecutorFactoryConfiguration, Combine) - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
- read(KeyStoreConfiguration, Combine) - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfigurationBuilder
- read(MechanismConfiguration, Combine) - Method in class org.infinispan.persistence.remote.configuration.MechanismConfigurationBuilder
- read(RemoteServerConfiguration, Combine) - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfigurationBuilder
- read(RemoteStoreConfiguration, Combine) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- read(SecurityConfiguration, Combine) - Method in class org.infinispan.persistence.remote.configuration.SecurityConfigurationBuilder
- read(SslConfiguration, Combine) - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
- read(TrustStoreConfiguration, Combine) - Method in class org.infinispan.persistence.remote.configuration.TrustStoreConfigurationBuilder
- read(RocksDBExpirationConfiguration, Combine) - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBExpirationConfigurationBuilder
- read(RocksDBStoreConfiguration, Combine) - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
- read(DataConfiguration, Combine) - Method in class org.infinispan.persistence.sifs.configuration.DataConfigurationBuilder
- read(IndexConfiguration, Combine) - Method in class org.infinispan.persistence.sifs.configuration.IndexConfigurationBuilder
- read(SoftIndexFileStoreConfiguration, Combine) - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
- read(QueriesJdbcConfiguration, Combine) - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfigurationBuilder
- read(QueriesJdbcStoreConfiguration, Combine) - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfigurationBuilder
- read(SchemaJdbcConfiguration, Combine) - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfigurationBuilder
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.commons.dataconversion.MediaType$___Marshaller_f2fc301543ca54d0326b5d8ce3b7199226a678253252e7ac46f1fad54bd90568
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.commons.marshall.WrappedByteArray$___Marshaller_dd5f1f82b70f419159a02b94c2ffa39a035efa36bc3f94e3bec8f1fb78d5e078
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.commons.util.KeyValueWithPrevious$___Marshaller_9145896a24b67e12a03ab245b027743214e8f0a00cff4e94594e6701c8f07ff1
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.commons.util.NullValue$___Marshaller_a83283d4dbbe8b8520f457699d99f19344b973d04786829de1e22c08915e6e56
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.container.entries.RemoteMetadata$___Marshaller_4cb4a1b59ce257eb4994240cafc1894764116cb17c3875df246d2943dcbdce0d
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.container.versioning.irac.IracEntryVersion$___Marshaller_1d33e9a17b1520460201f2d05b09e88a3eb2df8efbb49f8a10103069f8b573d5
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.container.versioning.irac.MapEntry$___Marshaller_37a121f54771729f5bc90dae7b319161c44a1e9491f8af866c7aba312bf9651e
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.container.versioning.irac.TopologyIracVersion$___Marshaller_14f804c9dae1c80820c4a124ae0decae2266c24993f77973d0fee34d7db215d2
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.container.versioning.NumericVersion$___Marshaller_54e14f07f0b2d32fc02dc14b15442c6b41ee1d50304f1e61ddb56d9feb6975b1
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.container.versioning.SimpleClusteredVersion$___Marshaller_f7402494821fa8e2ee025bf7d4a4b60322db5a0eb2018b6aa5836c002c8e07b7
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.counter.api.CounterConfiguration$___Marshaller_200ccbe7f9bd55cd3d0f90bae5ea29adc0a29590c936038020329c50ede7e29f
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata$___Marshaller_d639102389197d7d9d67594c1f4f7cd51d35bdb2ed77d89d90c58b8d63ad3ab0
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.metadata.EmbeddedExpirableMetadata$___Marshaller_57542ccf09e811f3460251c589ca05aed449dbbc1765661fa3851dddaac8dd71
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.metadata.EmbeddedLifespanExpirableMetadata$___Marshaller_8da6d90d1f279b201c958e38c4b73ab7f2712dc1dc20b32c21334eacdfc6fd4b
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.metadata.EmbeddedMaxIdleExpirableMetadata$___Marshaller_6887b83200c53e83a8233e38450ed44c3191b4968b578e16a63c12add76959ed
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.metadata.EmbeddedMetadata$___Marshaller_d44c815cc3de96e45a01e06b569541e480035dc14f5499e3f3edc3fa7c6fe67
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.metadata.impl.IracMetadata$___Marshaller_cf0a6ded5e9e5b145ea5821d40d9659677d03a5df3e405762cc053e3bbb15e64
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.metadata.impl.PrivateMetadata$___Marshaller_2707b1b527c228e45215e24669c8ab752e6a1689fb6e3510d925b1e899b8ee06
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.multimap.impl.Bucket$___Marshaller_686dc55729a31972fef7d4722c2e90e0421789a20c8a9d4176be1714ac94d28c
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.persistence.rocksdb.ExpiryBucket$___Marshaller_c1bbd47a4aa119c6b21703d5030cb689b65205a24de2638d9c9f2ce1f3a222f6
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.persistence.rocksdb.MetadataImpl$___Marshaller_b44737a8b6b24b0cd6de162703366becf9e68a2ce287544774acbaaa7268814
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.query.impl.KnownClassKey$___Marshaller_b1b9e11dd7f2c702e88c180bbc686b798fa5794bc27ae13347aacd2e4a465e3d
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress$___Marshaller_fff84712bca7d00f611bdc3fd76a067b0a3a1f4981a7d3aad1c9257d9a5d7324
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.rest.distribution.CacheDistributionInfo$___Marshaller_d29d2c8791a59bb0952e36da57e31d3d06e79a149845ac44d334bd095efcb62c
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.rest.distribution.CacheDistributionRunnable$___Marshaller_45f1040aff503b6010c6b926057475925f0a64804eab6e8f0d6f4ba5ddce3a36
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.rest.distribution.NodeDistributionInfo$___Marshaller_50bcddd047df75d5979a51292e9db600cc21f4e1e18d6fe36b39e9a26196ea0e
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.security.impl.CacheRoleImpl$___Marshaller_8ebe2292503551beeebd9f0cc1e432a19521b4115fff99f8859a58acb74d6d74
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.security.impl.SubjectAdapter$___Marshaller_75e0224333a6eeeafc364cef114fe68e65410956aa87814e98e0722f4d8a588d
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.security.mappers.RoleSet$___Marshaller_2fda1a742ac008d38f1c852650748615da7cca98a60afaa87bb162ebc6157665
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.server.core.backup.resources.CacheBackupEntry$___Marshaller_b2d0dee2aac68dcec862a9e304f7e24daf8a89e2925ed0f1902a4f7e597df134
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.server.core.backup.resources.CounterBackupEntry$___Marshaller_2af248d5cc134577501d751e859e0021aca6b7f47edf43acc378580b56297af6
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.server.memcached.MemcachedMetadata$___Marshaller_582bc1c0173638c6bfeeee0149c471f14236f1b1d719f55da181f90c415f8bf1
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.spring.common.session.MapSessionProtoAdapter.SessionAttributeRawMarshaller
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.spring.common.session.MapSessionProtoAdapter$___Marshaller_71442e7b0d28786c1f10a1743da12fcd08d64dc0b8a798e5658e855284c87eee
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.spring.common.session.SessionAttribute$___Marshaller_5dcef48338013ff033aa3ebdfe72b959048a23f1ab1b4e671508996ffee0358b
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.spring.common.session.SessionUpdateRemappingFunctionProtoAdapter$___Marshaller_9c0544bb624c0af23e5a5e11e8120017e963b2cee452968f8524051818abdb2b
- read(ProtobufTagMarshaller.ReadContext) - Method in class org.infinispan.util.ByteString$___Marshaller_8e599c0fc1e9a512b7cdb7c05fb5529744ecac265708e69fd30c5e989237252a
- read(AuthenticationConfiguration, Combine) - Method in class org.infinispan.rest.configuration.AuthenticationConfigurationBuilder
- read(CorsConfiguration, Combine) - Method in class org.infinispan.rest.configuration.CorsConfigurationBuilder
- read(CorsRuleConfiguration, Combine) - Method in class org.infinispan.rest.configuration.CorsRuleConfigurationBuilder
- read(RestServerConfiguration, Combine) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- read(CreatePermissionConfiguration, Combine) - Method in class org.infinispan.security.impl.CreatePermissionConfigurationBuilder
- read(Role, Combine) - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
- read(EncryptionConfiguration, Combine) - Method in class org.infinispan.server.core.configuration.EncryptionConfigurationBuilder
- read(IpFilterConfiguration, Combine) - Method in class org.infinispan.server.core.configuration.IpFilterConfigurationBuilder
- read(SniConfiguration, Combine) - Method in class org.infinispan.server.core.configuration.SniConfigurationBuilder
- read(SslConfiguration, Combine) - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
- read(SslEngineConfiguration, Combine) - Method in class org.infinispan.server.core.configuration.SslEngineConfigurationBuilder
- read(AuthenticationConfiguration, Combine) - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
- read(HotRodServerConfiguration, Combine) - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
- read(SaslConfiguration, Combine) - Method in class org.infinispan.server.hotrod.configuration.SaslConfigurationBuilder
- read(TopologyCacheConfiguration, Combine) - Method in class org.infinispan.server.hotrod.configuration.TopologyCacheConfigurationBuilder
- read(T) - Method in interface org.infinispan.commons.configuration.Builder
- read(T, Combine) - Method in interface org.infinispan.commons.configuration.Builder
-
Reads the configuration from an already created configuration bean into this builder.
- read(T, Combine) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
- read(T, Combine) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
- read(T, Combine) - Method in class org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfigurationBuilder
- read(T, Combine) - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- READ - Enum constant in enum org.infinispan.container.entries.ReadCommittedEntry.Flags
- READ - Enum constant in enum org.infinispan.security.AuthorizationPermission
-
Allows reading data from a cache
- READ - Enum constant in enum org.infinispan.util.concurrent.DataOperationOrderer.Operation
- READ_ALL_WRITE_ALL - Enum constant in enum org.infinispan.topology.CacheTopology.Phase
-
Used after state transfer completes: readCH == writeCH = unionCH
- READ_CHUNK_SIZE - Static variable in class org.infinispan.commons.configuration.io.xml.MXParser
- READ_COMMITTED - Enum constant in enum org.infinispan.util.concurrent.IsolationLevel
- READ_NEW_WRITE_ALL - Enum constant in enum org.infinispan.topology.CacheTopology.Phase
-
Intermediate state that prevents ISPN-5021: readCH == pendingCH, writeCH = unionCH
- READ_OLD_WRITE_ALL - Enum constant in enum org.infinispan.topology.CacheTopology.Phase
-
Used during state transfer: readCH == currentCH, writeCH = unionCH
- READ_ONLY - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- READ_ONLY - Enum constant in enum org.infinispan.persistence.spi.NonBlockingStore.Characteristic
-
If this store supports only being read from.
- READ_ONLY - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- READ_ONLY_SNAPSHOT_VIEW - Static variable in interface org.infinispan.commons.marshall.Ids
- READ_QUERY_TIMEOUT - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
- READ_UNCOMMITTED - Enum constant in enum org.infinispan.util.concurrent.IsolationLevel
- READ_WRITE_SNAPSHOT_VIEW - Static variable in interface org.infinispan.commons.marshall.Ids
- read10_1EntryHeader(FileProvider.Handle, long) - Static method in class org.infinispan.persistence.sifs.EntryRecord
- readable(ByteBuf, int) - Static method in class org.infinispan.server.hotrod.Intrinsics
- ReadableGridFileChannel - Class in org.infinispan.io
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.0
- readArray(Enum<?>, Enum<?>) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationReader
- readArray(Enum<?>, Enum<?>) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
- readArray(String, String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
- readArray(String, String) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationReader
- readArray(String, String) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationReader
- readArray(String, String) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader
- readAttribute(ConfigurationReader, String, int, ConfigurationBuilderHolder) - Method in interface org.infinispan.configuration.parsing.ConfigurationParser
- readBoolean() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readBoolean() - Method in class org.infinispan.io.UnclosableObjectInputStream
-
Deprecated.
- readBoolean() - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
- readBooleanAttributeElement(ConfigurationReader, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Read an element which contains only a single boolean attribute.
- readByte() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readByte() - Method in class org.infinispan.io.UnclosableObjectInputStream
-
Deprecated.
- readByte() - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
- readChar() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readChar() - Method in class org.infinispan.io.UnclosableObjectInputStream
-
Deprecated.
- readChar() - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
- ReadCommittedEntry<K,
V> - Class in org.infinispan.container.entries -
A wrapper around a cached entry that encapsulates read committed semantics when writes are initiated, committed or rolled back.
- ReadCommittedEntry(K, V, Metadata) - Constructor for class org.infinispan.container.entries.ReadCommittedEntry
- ReadCommittedEntry.Flags - Enum in org.infinispan.container.entries
- readContentAsBytes(Object) - Static method in class org.infinispan.rest.stream.CacheChunkedStream
- readContext(int) - Method in class org.infinispan.cache.impl.DecoratedCache
- readDouble() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readDouble() - Method in class org.infinispan.io.UnclosableObjectInputStream
-
Deprecated.
- readDouble() - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
- readElement(ConfigurationReader, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.CacheParser
- readElement(ConfigurationReader, ConfigurationBuilderHolder) - Method in interface org.infinispan.configuration.parsing.ConfigurationParser
-
The entry point of a configuration parser which gets passed a
ConfigurationReader
positioned at a root element associated with the parser itself according to the registered mapping. - readElement(ConfigurationReader, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.Parser
- readElement(ConfigurationReader, ConfigurationBuilderHolder) - Method in class org.infinispan.counter.configuration.CounterConfigurationParser
- readElement(ConfigurationReader, ConfigurationBuilderHolder) - Method in class org.infinispan.counter.configuration.CounterParser
- readElement(ConfigurationReader, ConfigurationBuilderHolder) - Method in class org.infinispan.lock.configuration.ClusteredLockConfigurationParser
- readElement(ConfigurationReader, ConfigurationBuilderHolder) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStoreConfigurationParser
- readElement(ConfigurationReader, ConfigurationBuilderHolder) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationParser
- readElement(ConfigurationReader, ConfigurationBuilderHolder) - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationParser
- readElement(ConfigurationReader, ConfigurationBuilderHolder) - Method in class org.infinispan.persistence.sql.configuration.SqlStoreConfigurationParser
- readElement(ConfigurationReader, CounterManagerConfigurationBuilder, Element, String) - Method in class org.infinispan.counter.configuration.CounterParser
- readEntryHeader(FileProvider.Handle, long) - Static method in class org.infinispan.persistence.sifs.EntryRecord
- reader - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- reader() - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
- reader() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
- reader() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
- reader() - Method in interface org.infinispan.configuration.cache.IndexingConfigurationChildBuilder
- readEvent(ClientCacheEntryCustomEvent<byte[]>) - Method in class org.infinispan.spring.remote.session.RemoteApplicationPublishedBridge
- readExternal(ObjectInput) - Method in class org.infinispan.io.GridFile.Metadata
-
Deprecated.
- readFloat() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readFloat() - Method in class org.infinispan.io.UnclosableObjectInputStream
-
Deprecated.
- readFloat() - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
- readFrom(ObjectInput) - Static method in class org.infinispan.commands.CommandInvocationId
- readFrom(ObjectInput) - Method in interface org.infinispan.commands.ReplicableCommand
-
Reads this instance from the stream written by
ReplicableCommand.writeTo(ObjectOutput)
. - readFrom(ObjectInput) - Method in interface org.infinispan.commons.marshall.MarshallUtil.ElementReader
- readFrom(ObjectInput) - Static method in class org.infinispan.commons.tx.XidImpl
- readFrom(ObjectInput) - Static method in class org.infinispan.commons.util.IntSetsExternalization
- readFrom(ObjectInput) - Static method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- readFrom(ObjectInput) - Static method in class org.infinispan.container.versioning.irac.IracTombstoneInfo
- readFrom(ObjectInput) - Static method in class org.infinispan.encoding.DataConversion
- readFrom(ObjectInput) - Method in class org.infinispan.expiration.impl.TouchCommand
- readFrom(ObjectInput) - Static method in class org.infinispan.functional.impl.MetaParams
- readFrom(ObjectInput) - Method in class org.infinispan.manager.impl.ReplicableManagerFunctionCommand
- readFrom(ObjectInput) - Method in class org.infinispan.manager.impl.ReplicableRunnableCommand
- readFrom(ObjectInput) - Static method in class org.infinispan.metadata.impl.IracMetadata
- readFrom(ObjectInput) - Method in class org.infinispan.notifications.cachelistener.cluster.MultiClusterEventCommand
- readFrom(ObjectInput) - Static method in class org.infinispan.remoting.responses.PrepareResponse
- readFrom(ObjectInput) - Method in class org.infinispan.server.hotrod.command.tx.ForwardCommitCommand
- readFrom(ObjectInput) - Static method in class org.infinispan.server.hotrod.tx.table.CacheXid
- readFrom(ObjectInput) - Static method in enum org.infinispan.server.hotrod.tx.table.Status
- readFrom(ObjectInput) - Method in class org.infinispan.topology.HeartBeatCommand
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.commands.remote.IracPutManyRequest
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.commands.remote.IracTombstoneCheckRequest
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.commands.remote.IracTouchKeyRequest
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.commands.remote.XSiteCacheRequest
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.commands.remote.XSiteRemoteEventCommand
- readFrom(ObjectInput) - Method in interface org.infinispan.xsite.commands.remote.XSiteRequest
-
Reads this instance from the stream written by
XSiteRequest.writeTo(ObjectOutput)
. - readFrom(ObjectInput) - Method in class org.infinispan.xsite.commands.remote.XSiteStatePushRequest
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.commands.remote.XSiteStateTransferControlRequest
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.commands.XSiteAmendOfflineStatusCommand
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.commands.XSiteAutoTransferStatusCommand
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.commands.XSiteBringOnlineCommand
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.commands.XSiteLocalEventCommand
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.commands.XSiteOfflineStatusCommand
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.commands.XSiteSetStateTransferModeCommand
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.commands.XSiteStateTransferCancelSendCommand
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.commands.XSiteStateTransferFinishReceiveCommand
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.commands.XSiteStateTransferFinishSendCommand
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.commands.XSiteStateTransferRestartSendingCommand
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.commands.XSiteStateTransferStartReceiveCommand
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.commands.XSiteStateTransferStartSendCommand
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.commands.XSiteTakeOfflineCommand
- readFrom(ObjectInput) - Static method in class org.infinispan.xsite.events.XSiteEvent
- readFrom(ObjectInput) - Static method in class org.infinispan.xsite.irac.IracManagerKeyInfoImpl
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
- readFully(byte[]) - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readFully(byte[]) - Method in class org.infinispan.io.UnclosableObjectInputStream
-
Deprecated.
- readFully(byte[]) - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
- readFully(byte[], int, int) - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readFully(byte[], int, int) - Method in class org.infinispan.io.UnclosableObjectInputStream
-
Deprecated.
- readFully(byte[], int, int) - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
- readInt() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readInt() - Method in class org.infinispan.io.UnclosableObjectInputStream
-
Deprecated.
- readInt() - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
- readInternalMetadata(FileProvider.Handle, EntryHeader, long) - Static method in class org.infinispan.persistence.sifs.EntryRecord
- readKey(FileProvider.Handle, EntryHeader, long) - Static method in class org.infinispan.persistence.sifs.EntryRecord
- readLine() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readLine() - Method in class org.infinispan.io.UnclosableObjectInputStream
-
Deprecated.
- readLine() - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
- readLong() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readLong() - Method in class org.infinispan.io.UnclosableObjectInputStream
-
Deprecated.
- readLong() - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
- readMaybeByte(ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
-
Reads a byte if possible.
- readMaybeLong(ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
- readMaybeOptRangedBytes(ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
-
Read a range of bytes prefixed by its length (encoded as a signed VInt).
- readMaybeOptString(ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
- readMaybeRangedBytes(ByteBuf) - Static method in class org.infinispan.server.core.transport.ExtendedByteBufJava
- readMaybeRangedBytes(ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
-
Reads a range of bytes if possible.
- readMaybeRangedBytes(ByteBuf, int) - Static method in class org.infinispan.server.core.transport.ExtendedByteBufJava
- readMaybeRangedBytes(ByteBuf, int) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
- readMaybeSignedInt(ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
- readMaybeString(ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
-
Reads a string if possible.
- readMaybeVInt(ByteBuf) - Static method in class org.infinispan.server.core.transport.ExtendedByteBufJava
- readMaybeVInt(ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
-
Reads a variable size int if possible.
- readMaybeVLong(ByteBuf) - Static method in class org.infinispan.server.core.transport.ExtendedByteBufJava
- readMaybeVLong(ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
-
Reads a variable long if possible.
- readMessageStream(ImmutableSerializationContext, Class<T>, DataInputStream) - Static method in class org.infinispan.server.core.backup.resources.CounterResource
- readMetadata(FileProvider.Handle, EntryHeader, long) - Static method in class org.infinispan.persistence.sifs.EntryRecord
- readObject() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readObject() - Method in class org.infinispan.io.UnclosableObjectInputStream
-
Deprecated.
- readObject(InputStream) - Method in interface org.infinispan.commons.marshall.StreamAwareMarshaller
-
Unmarshall an object from the
InputStream
- readObject(ObjectInput) - Method in class org.infinispan.cache.impl.BiFunctionMapper.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.cache.impl.EncoderEntryMapper.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.cache.impl.EncoderKeyMapper.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.cache.impl.EncoderValueMapper.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.cache.impl.FunctionMapper.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.commons.dataconversion.MediaType.MediaTypeExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.commons.hash.MurmurHash3.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.commons.io.ByteBufferImpl.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.commons.marshall.AdminFlagExternalizer
- readObject(ObjectInput) - Method in interface org.infinispan.commons.marshall.Externalizer
-
Deprecated.Read an instance from the stream.
- readObject(ObjectInput) - Method in class org.infinispan.commons.marshall.InstanceReusingAdvancedExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.commons.marshall.SingletonExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.commons.marshall.SuppliedExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.commons.marshall.WrappedByteArray.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.commons.util.ImmutableListCopy.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.commons.util.Immutables.ImmutableMapWrapperExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.commons.util.Immutables.ImmutableSetWrapperExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.container.entries.ImmortalCacheEntry.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.container.entries.ImmortalCacheValue.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheEntry.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.container.entries.MortalCacheEntry.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.container.entries.MortalCacheValue.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.container.entries.RemoteMetadata.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.container.entries.TransientCacheEntry.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.container.entries.TransientCacheValue.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.container.entries.TransientMortalCacheValue.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.container.versioning.NumericVersion.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.container.versioning.SimpleClusteredVersion.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.context.Flag.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.distribution.ch.impl.TopologyAwareConsistentHashFactory.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.encoding.DataConversion.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.filter.AcceptAllKeyValueFilter.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.filter.CacheFilters.CacheFiltersExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.filter.CompositeKeyValueFilter.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.functional.impl.EntryViews.NoValueReadOnlyViewExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.functional.impl.EntryViews.ReadOnlySnapshotViewExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.functional.impl.EntryViews.ReadWriteSnapshotViewExternalizer
- readObject(ObjectInput) - Static method in class org.infinispan.functional.impl.Params
- readObject(ObjectInput) - Method in class org.infinispan.functional.impl.StatsEnvelope.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.globalstate.impl.CacheState.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.globalstate.ScopedState.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.globalstate.ScopeFilter.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.ConstantLambdaExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.LambdaWithMetasExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.SetValueIfEqualsReturnBooleanExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.ClassExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.CollectionExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.DoubleSummaryStatisticsExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.EnumExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.EnumSetExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.IntSummaryStatisticsExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.LongSummaryStatisticsExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.MapExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.EntryVersionParamExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.LifespanExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.MaxIdleExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.OptionalExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.ThrowableExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.TriangleAckExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.UuidExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.metadata.EmbeddedMetadata.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.metadata.impl.InternalMetadataImpl.Externalizer
-
Deprecated.
- readObject(ObjectInput) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerRemoveCallable.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerReplicateCallable.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventConverterAsConverter.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterAsKeyValueFilter.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverterAsKeyValueFilterConverter.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterAsCacheEventFilter.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.partitionhandling.AvailabilityMode.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.persistence.remote.upgrade.AddSourceRemoteStoreTask.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.persistence.remote.upgrade.CheckRemoteStoreTask.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.persistence.remote.upgrade.DisconnectRemoteStoreTask.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.persistence.remote.upgrade.MigrationTask.EntryWriterExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.persistence.remote.upgrade.MigrationTask.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.persistence.remote.upgrade.RemovedFilter.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.query.impl.QueryDefinition.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.reactive.publisher.PublisherReducers.PublisherReducersExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.reactive.publisher.PublisherTransformers.PublisherTransformersExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.remoting.responses.BiasRevocationResponse.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.remoting.responses.CacheNotFoundResponse.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.remoting.responses.ExceptionResponse.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.remoting.responses.SuccessfulResponse.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.remoting.responses.UnsuccessfulResponse.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.remoting.responses.UnsureResponse.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.server.core.security.simple.SimpleGroupPrincipal.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.server.core.security.simple.SimpleSubjectUserInfo.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.server.hotrod.event.KeyValueWithPreviousEventConverterExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.server.hotrod.iteration.IterationFilter.IterationFilterExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl.DistributedCacheStatsCallableExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.stream.impl.CacheBiConsumers.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.stream.impl.CacheIntermediatePublisher.ReducerExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.stream.impl.CacheStreamIntermediateReducer.ReducerExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.stream.StreamMarshalling.StreamMarshallingExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.topology.CacheJoinInfo.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.topology.CacheStatusResponse.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.topology.PersistentUUID.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.transaction.xa.GlobalTransaction.Externalizer
- readObject(ObjectInput) - Static method in class org.infinispan.util.ByteString
- readObject(ObjectInput) - Method in class org.infinispan.util.IntSetExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.util.KeyValuePair.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.xsite.commands.remote.XSiteRequestExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.xsite.statetransfer.XSiteState.XSiteStateExternalizer
- readObjectFromObjectInput(GlobalMarshaller, ObjectInput) - Static method in class org.infinispan.marshall.core.GlobalMarshaller
- readOnly(K, V, Metadata) - Static method in class org.infinispan.functional.impl.EntryViews
- readOnly(CacheEntry) - Static method in class org.infinispan.functional.impl.EntryViews
- readOnly(CacheEntry<K, V>, DataConversion, DataConversion) - Static method in class org.infinispan.functional.impl.EntryViews
- ReadOnlyMapImpl<K,
V> - Class in org.infinispan.functional.impl -
Read-only map implementation.
- ReadOnlySegmentAwareCollection<E> - Class in org.infinispan.distribution.util
-
Set implementation that shows a read only view of the provided set by only allowing entries that map to a given segment using the provided consistent hash.
- ReadOnlySegmentAwareCollection(Collection<E>, LocalizedCacheTopology, IntSet) - Constructor for class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
- ReadOnlySegmentAwareEntryCollection<K,
V> - Class in org.infinispan.distribution.util -
Iterator implementation that shows a read only view of the provided iterator by only allowing values that map to a given segment using the provided consistent hash.
- ReadOnlySegmentAwareEntryCollection(Set<Map.Entry<K, V>>, LocalizedCacheTopology, IntSet) - Constructor for class org.infinispan.distribution.util.ReadOnlySegmentAwareEntryCollection
- ReadOnlySegmentAwareEntryIterator<K,
V> - Class in org.infinispan.distribution.util -
Iterator implementation that shows a read only view of the provided iterator by only allowing values that map to a given segment using the provided consistent hash.
- ReadOnlySegmentAwareEntryIterator(Iterator<Map.Entry<K, V>>, LocalizedCacheTopology, IntSet) - Constructor for class org.infinispan.distribution.util.ReadOnlySegmentAwareEntryIterator
- ReadOnlySegmentAwareIterator<E> - Class in org.infinispan.distribution.util
-
Iterator implementation that shows a read only view of the provided iterator by only allowing values that map to a given segment using the provided consistent hash.
- ReadOnlySegmentAwareIterator(Iterator<E>, LocalizedCacheTopology, IntSet) - Constructor for class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator
- ReadOnlySegmentAwareMap<K,
V> - Class in org.infinispan.distribution.util -
Map implementation that shows a read only view of the provided entry by only allowing entries whose key maps to a given segment using the provided consistent hash.
- ReadOnlySegmentAwareMap(Map<K, V>, LocalizedCacheTopology, IntSet) - Constructor for class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
- ReadOnlySnapshotViewExternalizer() - Constructor for class org.infinispan.functional.impl.EntryViews.ReadOnlySnapshotViewExternalizer
- readOptRangedBytes(ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
-
Reads optional range of bytes.
- readOptString(ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
-
Reads an optional String.
- readOwners() - Method in class org.infinispan.distribution.DistributionInfo
- readOwnership() - Method in class org.infinispan.distribution.DistributionInfo
- readQueryTimeout - Variable in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
- readQueryTimeout() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfiguration
- readQueryTimeout(Integer) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
- readRangedBytes(ByteBuf) - Static method in class org.infinispan.server.core.transport.ExtendedByteBuf
- readRangedBytes(ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
- readRangedBytes(ByteBuf, int) - Static method in class org.infinispan.server.core.transport.ExtendedByteBuf
- readRangedBytes(ByteBuf, int) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
- readResolve() - Method in class org.infinispan.rest.logging.Messages_$bundle
- readResolve() - Method in class org.infinispan.scripting.logging.Messages_$bundle
- readResolve() - Method in class org.infinispan.search.mapper.log.impl.InfinispanEventContextMessages_$bundle
- readScopedState(String) - Method in interface org.infinispan.globalstate.GlobalStateManager
-
Reads the persistent state for the specified scope.
- readScopedState(String) - Method in class org.infinispan.globalstate.impl.GlobalStateManagerImpl
- readShort() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readShort() - Method in class org.infinispan.io.UnclosableObjectInputStream
-
Deprecated.
- readShort() - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
- readSignedInt(InputStream) - Static method in class org.infinispan.commons.io.SignedNumeric
- readSignedInt(ObjectInput) - Static method in class org.infinispan.commons.io.SignedNumeric
- readString() - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
- readString(ByteBuf) - Static method in class org.infinispan.server.core.transport.ExtendedByteBuf
-
Reads length of String and then returns an UTF-8 formatted String of such length.
- readString(ByteBuf) - Static method in class org.infinispan.server.core.transport.ExtendedByteBufJava
- readString(ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
-
Reads length of String and then returns an UTF-8 formatted String of such length.
- readStringAttributeElement(ConfigurationReader, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Read an element which contains only a single string attribute.
- readUnsignedByte() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readUnsignedByte() - Method in class org.infinispan.io.UnclosableObjectInputStream
-
Deprecated.
- readUnsignedByte() - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
- readUnsignedInt(byte[], int) - Static method in class org.infinispan.commons.io.UnsignedNumeric
-
Reads an int stored in variable-length format.
- readUnsignedInt(ByteBuf) - Static method in class org.infinispan.server.core.transport.ExtendedByteBuf
- readUnsignedInt(ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
- readUnsignedInt(DataInput) - Static method in class org.infinispan.commons.io.UnsignedNumeric
-
Reads an int stored in variable-length format.
- readUnsignedInt(InputStream) - Static method in class org.infinispan.commons.io.UnsignedNumeric
- readUnsignedInt(ByteBuffer) - Static method in class org.infinispan.commons.io.UnsignedNumeric
- readUnsignedLong(byte[], int) - Static method in class org.infinispan.commons.io.UnsignedNumeric
-
Reads an int stored in variable-length format.
- readUnsignedLong(ByteBuf) - Static method in class org.infinispan.server.core.transport.ExtendedByteBuf
- readUnsignedLong(ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
- readUnsignedLong(DataInput) - Static method in class org.infinispan.commons.io.UnsignedNumeric
-
Reads a long stored in variable-length format.
- readUnsignedLong(InputStream) - Static method in class org.infinispan.commons.io.UnsignedNumeric
- readUnsignedLong(ByteBuffer) - Static method in class org.infinispan.commons.io.UnsignedNumeric
- readUnsignedMaybeLong(ByteBuf) - Static method in class org.infinispan.server.core.transport.ExtendedByteBufJava
- readUnsignedShort() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readUnsignedShort() - Method in class org.infinispan.io.UnclosableObjectInputStream
-
Deprecated.
- readUnsignedShort() - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
- readUnsignedShort(ByteBuf) - Static method in class org.infinispan.server.core.transport.ExtendedByteBuf
- readUnsignedShort(ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
- readUTF() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readUTF() - Method in class org.infinispan.io.UnclosableObjectInputStream
-
Deprecated.
- readUTF() - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
- readValue(FileProvider.Handle, EntryHeader, long) - Static method in class org.infinispan.persistence.sifs.EntryRecord
- readWrite(MVCCEntry, Object, Metadata, DataConversion, DataConversion) - Static method in class org.infinispan.functional.impl.EntryViews
- readWrite(MVCCEntry, DataConversion, DataConversion) - Static method in class org.infinispan.functional.impl.EntryViews
- ReadWriteMapImpl<K,
V> - Class in org.infinispan.functional.impl -
Read-write map implementation.
- ReadWriteSnapshotViewExternalizer() - Constructor for class org.infinispan.functional.impl.EntryViews.ReadWriteSnapshotViewExternalizer
- READY - Enum constant in enum org.infinispan.remoting.inboundhandler.action.ActionStatus
-
The action is completed successfully.
- ReadyAction - Interface in org.infinispan.remoting.inboundhandler.action
-
An interface that allows the
PerCacheInboundInvocationHandler
to check when this action is ready. - realCacheCollection - Variable in class org.infinispan.util.WriteableCacheCollectionMapper
- realCollection - Variable in class org.infinispan.util.CollectionMapper
- realIterator - Variable in class org.infinispan.commons.util.RemovableCloseableIterator
- realIterator - Variable in class org.infinispan.commons.util.RemovableIterator
- realm() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
- realm() - Method in class org.infinispan.persistence.remote.configuration.MechanismConfiguration
- realm() - Method in class org.infinispan.server.core.configuration.EncryptionConfiguration
- realm() - Method in class org.infinispan.server.core.configuration.SniConfiguration
- realm(String) - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
-
Specifies the realm to be used for authentication.
- realm(String) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
-
Specifies the realm to be used for authentication.
- realm(String) - Method in class org.infinispan.persistence.remote.configuration.MechanismConfigurationBuilder
- realm(String) - Method in class org.infinispan.server.core.configuration.EncryptionConfigurationBuilder
- realm(String) - Method in class org.infinispan.server.core.configuration.SniConfigurationBuilder
- REALM - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- realSet - Variable in class org.infinispan.util.CacheSetMapper
- REAPER_ENABLED - Static variable in class org.infinispan.configuration.cache.ExpirationConfiguration
- REAPER_WAKE_UP_INTERVAL - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- REAPER_WAKE_UP_INTERVAL - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
- reaperEnabled() - Method in class org.infinispan.configuration.cache.ExpirationConfiguration
-
Determines whether the background reaper thread is enabled to test entries for expiration.
- reaperEnabled() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
- reaperEnabled(boolean) - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
-
Enable the background reaper to test entries for expiration.
- reaperWakeUpInterval() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
- reaperWakeUpInterval(long) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
-
The time interval (millis) at which the thread that cleans up transaction completion information kicks in.
- rebalance(CH) - Method in interface org.infinispan.distribution.ch.ConsistentHashFactory
-
Deprecated.Create a new consistent hash instance, based on an existing instance, but balanced according to the implementation's rules.
- rebalance(DefaultConsistentHash) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
- rebalance(DefaultConsistentHash) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory
- rebalance(ReplicatedConsistentHash) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory
- rebalance(ReplicatedConsistentHash) - Method in class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory
- rebalance(ScatteredConsistentHash) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory
- rebalance(CacheTopology) - Method in interface org.infinispan.topology.CacheTopologyHandler
-
Invoked when state transfer has to be started.
- rebalanceBuilder(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
- rebalanceBuilder(ScatteredConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory
- RebalancingStatus - Enum in org.infinispan.topology
-
RebalancingStatus.
- recalculateMinTopologyIdIfNeeded(CacheTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
- receiveClusterView(View, boolean) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- receiveState(int, Object, Object, IracMetadata) - Method in class org.infinispan.xsite.irac.DefaultIracManager
- receiveState(int, Object, Object, IracMetadata) - Method in interface org.infinispan.xsite.irac.IracManager
-
Receives the state related to the
key
. - receiveState(int, Object, Object, IracMetadata) - Method in enum org.infinispan.xsite.irac.NoOpIracManager
- ReclosableLatch - Class in org.infinispan.util.concurrent
-
A thread gate, that uses an
AbstractQueuedSynchronizer
. - ReclosableLatch() - Constructor for class org.infinispan.util.concurrent.ReclosableLatch
- ReclosableLatch(boolean) - Constructor for class org.infinispan.util.concurrent.ReclosableLatch
- RECONNECT_PERIOD - Static variable in class org.infinispan.client.hotrod.event.impl.ClientListenerNotifier
- ReconnectTask - Class in org.infinispan.client.hotrod.event.impl
- ReconnectTask(EventDispatcher<?>) - Constructor for class org.infinispan.client.hotrod.event.impl.ReconnectTask
- record(double) - Method in interface org.infinispan.commons.stat.DistributionSummaryTracker
-
Updates the statistics kept by the summary with the specified amount.
- record(long) - Method in class org.infinispan.commons.stat.DefaultSimpleStat
- record(long) - Method in interface org.infinispan.commons.stat.SimpleStat
- record(long) - Method in class org.infinispan.commons.stat.SimpleStateWithTimer
- recordEviction() - Method in class org.infinispan.stats.impl.StatsCollector
- recordEvictions(int) - Method in class org.infinispan.stats.impl.StatsCollector
- recordException(Exception) - Method in class org.infinispan.remoting.transport.impl.MapResponseCollector
- recordException(Object, Throwable) - Method in class org.infinispan.rest.tracing.RestTelemetryService
- recordException(Object, Throwable) - Method in class org.infinispan.server.core.telemetry.impl.OpenTelemetryService
- recordException(Object, Throwable) - Method in class org.infinispan.server.core.telemetry.TelemetryService.NoTelemetry
- recordException(Object, Throwable) - Method in interface org.infinispan.server.core.telemetry.TelemetryService
- recordException(Object, Throwable) - Method in class org.infinispan.server.hotrod.tracing.HotRodTelemetryService
- recordHits(int, long) - Method in class org.infinispan.stats.impl.StatsCollector
- recordMessageSent(Address, int, boolean) - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsMetricsManager
-
Records a message sent to a
destination
. - recordMessageSent(Address, int, boolean) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsMetricsManagerImpl
- recordMessageSent(Address, int, boolean) - Method in class org.infinispan.remoting.transport.jgroups.NoOpJGroupsMetricManager
- recordMisses(int, long) - Method in class org.infinispan.stats.impl.StatsCollector
- recordRemoveHits(int, long) - Method in class org.infinispan.stats.impl.StatsCollector
- recordRemoveMisses(int) - Method in class org.infinispan.stats.impl.StatsCollector
- recordRequestSent(String, long, TimeUnit) - Method in class org.infinispan.xsite.metrics.DefaultXSiteMetricsCollector
- recordRequestSent(String, long, TimeUnit) - Method in class org.infinispan.xsite.metrics.NoOpXSiteMetricsCollector
- recordRequestSent(String, long, TimeUnit) - Method in interface org.infinispan.xsite.metrics.XSiteMetricsCollector
- recordRequestsReceived(String) - Method in class org.infinispan.xsite.metrics.DefaultXSiteMetricsCollector
- recordRequestsReceived(String) - Method in class org.infinispan.xsite.metrics.NoOpXSiteMetricsCollector
- recordRequestsReceived(String) - Method in interface org.infinispan.xsite.metrics.XSiteMetricsCollector
- recordSize(int) - Method in class org.infinispan.commons.marshall.AdaptiveBufferSizePredictor
- recordSize(int) - Method in interface org.infinispan.commons.marshall.BufferSizePredictor
-
Record the size of the of data in the last buffer used.
- recordStores(int, long) - Method in class org.infinispan.stats.impl.StatsCollector
- recover(int) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
- RECOVERING_CLUSTER - Enum constant in enum org.infinispan.topology.ClusterTopologyManager.ClusterManagerStatus
- recovery() - Method in class org.infinispan.configuration.cache.AbstractTransportConfigurationChildBuilder
- recovery() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
-
This method allows configuration of the transaction recovery cache.
- recovery() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
-
This method allows configuration of the transaction recovery cache.
- recovery() - Method in interface org.infinispan.configuration.cache.TransactionConfigurationChildBuilder
- RECOVERY - Enum constant in enum org.infinispan.configuration.parsing.Element
- RECOVERY_INFO_CACHE_NAME - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- RECOVERY_INFO_CACHE_NAME - Static variable in class org.infinispan.configuration.cache.RecoveryConfiguration
- RecoveryAdminOperations - Class in org.infinispan.transaction.xa.recovery
-
Admin utility class for allowing management of in-doubt transactions (e.g.
- RecoveryAdminOperations() - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
- RecoveryAwareLocalTransaction - Class in org.infinispan.transaction.xa.recovery
-
Extends
LocalXaTransaction
and adds recovery related information. - RecoveryAwareLocalTransaction(Transaction, GlobalTransaction, boolean, int, long) - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareLocalTransaction
- RecoveryAwareRemoteTransaction - Class in org.infinispan.transaction.xa.recovery
-
Extends
RemoteTransaction
and adds recovery related information and functionality. - RecoveryAwareRemoteTransaction(List<WriteCommand>, GlobalTransaction, int, long) - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
- RecoveryAwareTransaction - Interface in org.infinispan.transaction.xa.recovery
-
Base interface for transactions that are holders of recovery information.
- RecoveryAwareTransactionTable - Class in org.infinispan.transaction.xa.recovery
-
Transaction table that delegates prepared transaction's management to the
RecoveryManager
. - RecoveryAwareTransactionTable() - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
- RecoveryConfiguration - Class in org.infinispan.configuration.cache
-
Defines recovery configuration for the cache.
- RecoveryConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Defines recovery configuration for the cache.
- recoveryInfoCacheName() - Method in class org.infinispan.configuration.cache.RecoveryConfiguration
-
Sets the name of the cache where recovery related information is held.
- recoveryInfoCacheName(String) - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
-
Sets the name of the cache where recovery related information is held.
- RecoveryInfoKey - Class in org.infinispan.transaction.xa.recovery
-
This makes sure that only xids pertaining to a certain cache are being returned when needed.
- RecoveryInfoKey(XidImpl, String) - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryInfoKey
- recoveryManager - Variable in class org.infinispan.transaction.xa.XaTransactionTable
- RecoveryManager - Interface in org.infinispan.transaction.xa.recovery
-
RecoveryManager is the component responsible with managing recovery related information and the functionality associated with it.
- RecoveryManager.RecoveryIterator - Interface in org.infinispan.transaction.xa.recovery
-
Stateful structure allowing prepared-tx retrieval in a batch-oriented manner, as required by
XAResource.recover(int)
. - RecoveryManagerFactory - Class in org.infinispan.factories
-
Factory for RecoveryManager.
- RecoveryManagerFactory() - Constructor for class org.infinispan.factories.RecoveryManagerFactory
- RecoveryManagerImpl - Class in org.infinispan.transaction.xa.recovery
-
Default implementation for
RecoveryManager
- RecoveryManagerImpl(ConcurrentMap<RecoveryInfoKey, RecoveryAwareRemoteTransaction>, String) - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
- recoveryResponse(HotRodHeader, HotRodServer, Channel, Collection<XidImpl>) - Method in class org.infinispan.server.hotrod.Encoder4x
- recoveryResponse(HotRodHeader, HotRodServer, Channel, Collection<XidImpl>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- recursiveDirectoryCopy(Path, Path) - Static method in class org.infinispan.commons.util.Util
- recursiveFileRemove(File) - Static method in class org.infinispan.commons.util.Util
-
Deletes directory recursively.
- recursiveFileRemove(String) - Static method in class org.infinispan.commons.util.Util
-
Deletes directory recursively.
- recursiveFileRemove(Path) - Static method in class org.infinispan.commons.util.Util
- RECV_BUF_SIZE - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- recvBufSize() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- recvBufSize(int) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- recvBufSize(int) - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
- recvBufSize(int) - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- recvBufSize(int) - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
-
Sets the size of the receive buffer
- RedirectResource - Class in org.infinispan.rest.resources
-
REST resource to serve redirects
- RedirectResource(InvocationHelper, String, String, boolean) - Constructor for class org.infinispan.rest.resources.RedirectResource
- reduce(double, DoubleBinaryOperator) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- reduce(double, DoubleBinaryOperator) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- reduce(double, SerializableDoubleBinaryOperator) - Method in interface org.infinispan.DoubleCacheStream
-
Same as
DoubleStream.reduce(double, DoubleBinaryOperator)
except that the DoubleBinaryOperator must also implementSerializable
- reduce(int, IntBinaryOperator) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- reduce(int, IntBinaryOperator) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- reduce(int, SerializableIntBinaryOperator) - Method in interface org.infinispan.IntCacheStream
-
Same as
IntStream.reduce(int, IntBinaryOperator)
except that the IntBinaryOperator must also implementSerializable
- reduce(long, LongBinaryOperator) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- reduce(long, LongBinaryOperator) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- reduce(long, SerializableLongBinaryOperator) - Method in interface org.infinispan.LongCacheStream
-
Same as
LongStream.reduce(long, LongBinaryOperator)
except that the LongBinaryOperator must also implement Serializable. - reduce(E, BiFunction<E, ? super I, E>) - Static method in class org.infinispan.reactive.publisher.PublisherReducers
-
Provides a reduction where the initial value must be the identity value that is not modified via the provided biFunction.
- reduce(BinaryOperator<E>) - Static method in class org.infinispan.reactive.publisher.PublisherReducers
- reduce(BinaryOperator<R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
- reduce(BinaryOperator<R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- reduce(BinaryOperator<R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- reduce(BinaryOperator<T>) - Method in interface org.infinispan.functional.Traversable
-
A terminal operation that applies a binary folding operation to all elements of this traversable, and wraps the result in an optional.
- reduce(DoubleBinaryOperator) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- reduce(DoubleBinaryOperator) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- reduce(IntBinaryOperator) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- reduce(IntBinaryOperator) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- reduce(LongBinaryOperator) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- reduce(LongBinaryOperator) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- reduce(SerializableBinaryOperator<R>) - Method in interface org.infinispan.CacheStream
-
Same as
Stream.reduce(BinaryOperator)
except that the BinaryOperator must also implementSerializable
- reduce(SerializableDoubleBinaryOperator) - Method in interface org.infinispan.DoubleCacheStream
-
Same as
DoubleStream.reduce(DoubleBinaryOperator)
except that the DoubleBinaryOperator must also implementSerializable
- reduce(SerializableIntBinaryOperator) - Method in interface org.infinispan.IntCacheStream
-
Same as
IntStream.reduce(IntBinaryOperator)
except that the IntBinaryOperator must also implementSerializable
- reduce(SerializableLongBinaryOperator) - Method in interface org.infinispan.LongCacheStream
-
Same as
LongStream.reduce(LongBinaryOperator)
except that the LongBinaryOperator must also implement Serializable. - reduce(R, BinaryOperator<R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
- reduce(R, BinaryOperator<R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- reduce(R, BinaryOperator<R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- reduce(R, SerializableBinaryOperator<R>) - Method in interface org.infinispan.CacheStream
-
Same as
Stream.reduce(Object, BinaryOperator)
except that the BinaryOperator must also implementSerializable
- reduce(T, BinaryOperator<T>) - Method in interface org.infinispan.functional.Traversable
-
A terminal operation that applies a binary folding operation to a start value and all elements of this traversable.
- reduce(U, BiFunction<U, ? super R, U>, BinaryOperator<U>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
- reduce(U, BiFunction<U, ? super R, U>, BinaryOperator<U>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- reduce(U, BiFunction<U, ? super R, U>, BinaryOperator<U>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- reduce(U, BiFunction<U, ? super T, U>, BinaryOperator<U>) - Method in interface org.infinispan.functional.Traversable
-
A terminal operation that applies a binary folding operation to a start value and the result of each element having a mapping function applied.
- reduce(U, SerializableBiFunction<U, ? super R, U>, SerializableBinaryOperator<U>) - Method in interface org.infinispan.CacheStream
-
Same as
Stream.reduce(Object, BiFunction, BinaryOperator)
except that the BinaryOperator must also implementSerializable
- ReducerExternalizer() - Constructor for class org.infinispan.stream.impl.CacheIntermediatePublisher.ReducerExternalizer
- ReducerExternalizer() - Constructor for class org.infinispan.stream.impl.CacheStreamIntermediateReducer.ReducerExternalizer
- reduceWith(Callable<? extends E>, BiFunction<E, ? super I, E>) - Static method in class org.infinispan.reactive.publisher.PublisherReducers
- REF - Enum constant in enum org.infinispan.stream.impl.IntermediateType
- refCnt() - Method in class org.infinispan.rest.ServerSentEvent
- ReflectionUtil - Class in org.infinispan.commons.util
-
Basic reflection utilities to enhance what the JDK provides.
- ReflectionUtil() - Constructor for class org.infinispan.commons.util.ReflectionUtil
- refresh() - Method in interface org.infinispan.search.mapper.scope.SearchWorkspace
-
Refresh the indexes so that all changes executed so far will be visible in search queries.
- REFRESH_INTERVAL - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- REFRESH_INTERVAL - Static variable in class org.infinispan.configuration.cache.IndexReaderConfiguration
- refreshInterval(long) - Method in class org.infinispan.configuration.cache.IndexReaderConfigurationBuilder
- REGEX - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- REGEX - Enum constant in enum org.infinispan.configuration.parsing.Element
- register() - Static method in class org.infinispan.commons.util.ClasspathURLStreamHandler
-
Registers this URL handler as the JVM-wide URL stream handler.
- register(Channel) - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- register(ChannelPromise) - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- register(Channel, ChannelPromise) - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- register(SerializationContextInitializer) - Method in class org.infinispan.commons.marshall.ProtoStreamMarshaller
- register(SerializationContextInitializer) - Method in interface org.infinispan.marshall.persistence.PersistenceMarshaller
-
Registers the schemas and marshallers defined by the provided
SerializationContextInitializer
with thePersistenceMarshaller
'sSerializationContext
. - register(InitialPublisherCommand<?, I, R>) - Method in class org.infinispan.reactive.publisher.impl.PublisherHandler
-
Registers a publisher given the initial command arguments.
- REGISTER - Enum constant in enum org.infinispan.configuration.global.ShutdownHookBehavior
-
Forces the cache to register a shutdown hook even if an MBean server is detected.
- registerAlias(String, String, Class<?>) - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
-
Register an alias to another component.
- registerAlias(String, String, Class<?>) - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
- registerChannel(Channel) - Method in class org.infinispan.server.hotrod.iteration.IterationReaper
- registerComponent(Class<?>, T, boolean) - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
-
Register a component named
componentType.getName()
. - registerComponent(Object, Class<?>) - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.Registers a component in the registry under the given type, and injects any dependencies needed.
- registerComponent(Object, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- registerComponent(Object, String, boolean) - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- registerComponent(String, T, boolean) - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
-
Register a component named
componentName
. - registerComponent(String, T, boolean) - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
- registerComponentAccessor(String, List<String>, ComponentAccessor<?>) - Method in interface org.infinispan.factories.impl.ModuleMetadataBuilder.ModuleBuilder
- registerComponentInternal(Object, String, boolean) - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- registerDefaultClassLoader(ClassLoader) - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.Since 9.4, not used
- registerDynamicMetadata(ModuleMetadataBuilder.ModuleBuilder, GlobalConfiguration) - Method in interface org.infinispan.factories.impl.DynamicModuleMetadataProvider
-
Use the provided builder to add additional component metadata.
- registerEncoder(Encoder) - Method in interface org.infinispan.marshall.core.EncoderRegistry
-
Deprecated, for removal: This API element is subject to removal in a future version.
- registerEncoder(Encoder) - Method in class org.infinispan.marshall.core.EncoderRegistryImpl
- registerExternalMBean(Object, String) - Method in class org.infinispan.jmx.CacheJmxRegistration
-
Registers a MBean, but does not track it to perform automatic unregistration on stop.
- registerFilter(String, Map<String, Object>, FilterCallback, boolean, Object...) - Method in interface org.infinispan.objectfilter.Matcher
- registerFilter(String, Map<String, Object>, FilterCallback, Object...) - Method in interface org.infinispan.objectfilter.Matcher
- registerFilter(String, FilterCallback, boolean, Object...) - Method in interface org.infinispan.objectfilter.Matcher
- registerFilter(String, FilterCallback, Object...) - Method in interface org.infinispan.objectfilter.Matcher
- registerFilter(Query<?>, FilterCallback, boolean, Object...) - Method in interface org.infinispan.objectfilter.Matcher
- registerFilter(Query<?>, FilterCallback, Object...) - Method in interface org.infinispan.objectfilter.Matcher
- registerInDoubtTransaction(RecoveryAwareRemoteTransaction) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
- registerInDoubtTransaction(RecoveryAwareRemoteTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
- registeringQueryInterceptor(String) - Method in interface org.infinispan.query.logging.Log
- registerInternalCache(String, Configuration) - Method in class org.infinispan.registry.impl.InternalCacheRegistryImpl
- registerInternalCache(String, Configuration, EnumSet<InternalCacheRegistry.Flag>) - Method in class org.infinispan.registry.impl.InternalCacheRegistryImpl
- registerL1WriteSynchronizer(Object, L1WriteSynchronizer) - Method in class org.infinispan.distribution.impl.L1ManagerImpl
- registerL1WriteSynchronizer(Object, L1WriteSynchronizer) - Method in interface org.infinispan.distribution.L1Manager
-
Registers the given write synchronizer to be notified whenever a remote value is looked up for the given key.
- registerListener() - Method in class org.infinispan.remoting.inboundhandler.action.DefaultReadyAction
- registerListener() - Method in class org.infinispan.spring.common.session.AbstractApplicationPublisherBridge
- registerListener() - Method in class org.infinispan.spring.embedded.session.EmbeddedApplicationPublishedBridge
- registerListener() - Method in class org.infinispan.spring.remote.session.RemoteApplicationPublishedBridge
- registerListenerInvocations(boolean, boolean, boolean, IndexedFilter<?, ?, ?>, Map<Class<? extends Annotation>, List<DelegatingCacheEntryListenerInvocation<K, V>>>, DataConversion, DataConversion) - Method in interface org.infinispan.notifications.cachelistener.filter.FilterIndexingServiceProvider
- registerLockedKey(Object) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
- registerMarshaller(Marshaller) - Method in class org.infinispan.client.hotrod.impl.MarshallerRegistry
- registerMarshaller(BaseMarshaller<?>) - Method in interface org.infinispan.query.remote.ProtobufMetadataManager
- registerMarshallers(SerializationContext) - Method in class org.infinispan.commons.GlobalContextInitializerImpl
- registerMarshallers(SerializationContext) - Method in class org.infinispan.commons.marshall.PersistenceContextInitializerImpl
- registerMarshallers(SerializationContext) - Method in class org.infinispan.commons.marshall.UserContextInitializerImpl
- registerMarshallers(SerializationContext) - Method in class org.infinispan.multimap.impl.PersistenceContextInitializerImpl
- registerMarshallers(SerializationContext) - Method in class org.infinispan.persistence.jdbc.impl.PersistenceContextInitializerImpl
- registerMarshallers(SerializationContext) - Method in class org.infinispan.persistence.rocksdb.PersistenceContextInitializerImpl
- registerMarshallers(SerializationContext) - Method in class org.infinispan.query.impl.PersistenceContextInitializerImpl
- registerMarshallers(SerializationContext) - Method in class org.infinispan.rest.distribution.DataDistributionContextInitializerImpl
- registerMarshallers(SerializationContext) - Method in class org.infinispan.server.core.PersistenceContextInitializerImpl
- registerMarshallers(SerializationContext) - Method in class org.infinispan.server.memcached.PersistenceContextInitializerImpl
- registerMarshallers(SerializationContext) - Method in class org.infinispan.spring.common.session.PersistenceContextInitializerImpl
- registerMBean(Object) - Method in class org.infinispan.jmx.CacheJmxRegistration
-
Registers a MBean (and tracks it to perform automatic unregistration on stop).
- registerMBean(Object, String) - Method in class org.infinispan.jmx.CacheJmxRegistration
-
Registers a MBean (and tracks it to perform automatic unregistration on stop).
- registerMBeanMetadata(String, MBeanMetadata) - Method in interface org.infinispan.factories.impl.ModuleMetadataBuilder.ModuleBuilder
- registerMetadata(ModuleMetadataBuilder.ModuleBuilder) - Method in interface org.infinispan.factories.impl.ModuleMetadataBuilder
- registerMetrics() - Method in class org.infinispan.server.core.AbstractProtocolServer
- registerNamedComponentRegistry(ComponentRegistry, String) - Method in class org.infinispan.factories.GlobalComponentRegistry
- registerNonVolatileComponent(Object, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- registerProtofile(String, String) - Method in interface org.infinispan.query.remote.client.ProtobufMetadataManagerMBean
-
Register a *.proto schema file.
- registerProtofiles(String[], String[]) - Method in interface org.infinispan.query.remote.client.ProtobufMetadataManagerMBean
-
Registers multiple *.proto schema files.
- registerRequest(XSiteResponse) - Method in class org.infinispan.xsite.status.NoOpTakeOfflineManager
- registerRequest(XSiteResponse<?>) - Method in class org.infinispan.xsite.status.DefaultTakeOfflineManager
- registerRequest(XSiteResponse<?>) - Method in interface org.infinispan.xsite.status.TakeOfflineManager
-
Registers a cross-site request made.
- registerResource(String, ResourceHandler) - Method in class org.infinispan.rest.framework.impl.ResourceManagerImpl
- registerResource(String, ResourceHandler) - Method in interface org.infinispan.rest.framework.ResourceManager
- registerSchema(SerializationContext) - Method in class org.infinispan.commons.GlobalContextInitializerImpl
- registerSchema(SerializationContext) - Method in class org.infinispan.commons.marshall.PersistenceContextInitializerImpl
- registerSchema(SerializationContext) - Method in class org.infinispan.commons.marshall.UserContextInitializerImpl
- registerSchema(SerializationContext) - Method in class org.infinispan.multimap.impl.PersistenceContextInitializerImpl
- registerSchema(SerializationContext) - Method in class org.infinispan.persistence.jdbc.impl.PersistenceContextInitializerImpl
- registerSchema(SerializationContext) - Method in class org.infinispan.persistence.rocksdb.PersistenceContextInitializerImpl
- registerSchema(SerializationContext) - Method in class org.infinispan.query.impl.PersistenceContextInitializerImpl
- registerSchema(SerializationContext) - Method in class org.infinispan.rest.distribution.DataDistributionContextInitializerImpl
- registerSchema(SerializationContext) - Method in class org.infinispan.server.core.PersistenceContextInitializerImpl
- registerSchema(SerializationContext) - Method in class org.infinispan.server.memcached.PersistenceContextInitializerImpl
- registerSchema(SerializationContext) - Method in class org.infinispan.spring.common.session.PersistenceContextInitializerImpl
- registerSegment(int) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
- registerSegment(int) - Method in interface org.infinispan.scattered.ScatteredVersionManager
-
Move the segment to
ScatteredVersionManager.SegmentState.BLOCKED
state. - registerServerMBeans() - Method in class org.infinispan.server.core.AbstractProtocolServer
- registerStateProvider(GlobalStateProvider) - Method in interface org.infinispan.globalstate.GlobalStateManager
-
Registers a state provider within this state manager
- registerStateProvider(GlobalStateProvider) - Method in class org.infinispan.globalstate.impl.GlobalStateManagerImpl
- registerSynchronization(Synchronization) - Method in class org.infinispan.commons.tx.TransactionImpl
-
Register a
Synchronization
callback with this transaction. - registerTimer(String, TimerTracker) - Method in class org.infinispan.xsite.metrics.DefaultXSiteMetricsCollector
- registerTimer(String, TimerTracker) - Method in class org.infinispan.xsite.metrics.NoOpXSiteMetricsCollector
- registerTimer(String, TimerTracker) - Method in interface org.infinispan.xsite.metrics.XSiteMetricsCollector
- registerTimer(TimerTracker) - Method in class org.infinispan.xsite.metrics.DefaultXSiteMetricsCollector
- registerTimer(TimerTracker) - Method in class org.infinispan.xsite.metrics.NoOpXSiteMetricsCollector
- registerTimer(TimerTracker) - Method in interface org.infinispan.xsite.metrics.XSiteMetricsCollector
- registerTranscoder(Transcoder) - Method in interface org.infinispan.marshall.core.EncoderRegistry
- registerTranscoder(Transcoder) - Method in class org.infinispan.marshall.core.EncoderRegistryImpl
- registerVersionGenerator(NumericVersionGenerator) - Method in class org.infinispan.factories.ComponentRegistry
- registerWrapper(Wrapper) - Method in interface org.infinispan.marshall.core.EncoderRegistry
-
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()
- registerWrapper(Wrapper) - Method in class org.infinispan.marshall.core.EncoderRegistryImpl
- RegistrationException - Exception in org.infinispan.rest.framework
- RegistrationException(String) - Constructor for exception org.infinispan.rest.framework.RegistrationException
- registry - Variable in class org.infinispan.stream.impl.AbstractCacheStream
- REGULAR_MEMBER - Enum constant in enum org.infinispan.topology.ClusterTopologyManager.ClusterManagerStatus
- regularInvalidationFinished(Object[], int[], long[], boolean[], boolean) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
- rehashAware - Variable in class org.infinispan.stream.impl.AbstractCacheStream
- reincarnate(long) - Method in class org.infinispan.container.entries.ImmortalCacheEntry
- reincarnate(long) - Method in interface org.infinispan.container.entries.InternalCacheEntry
-
"Reincarnates" an entry.
- reincarnate(long) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
- reincarnate(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
- reincarnate(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
- reincarnate(long) - Method in class org.infinispan.container.entries.MortalCacheEntry
- reincarnate(long) - Method in class org.infinispan.container.entries.TransientCacheEntry
- reincarnate(long) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
- REINDEX - Enum constant in enum org.infinispan.configuration.cache.IndexStartupMode
-
Reindex will be triggered at cache startup time.
- reindexCache(String) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
- reindexCache(String) - Method in interface org.infinispan.client.hotrod.RemoteCacheManagerAdmin
-
Performs a mass reindexing of the specified cache.
- reindexing() - Method in class org.infinispan.query.stats.impl.LocalIndexStatistics
- rejectedExecution(Runnable, ExecutorService) - Method in class org.infinispan.commons.util.concurrent.BlockingRejectedExecutionHandler
- rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.infinispan.commons.util.concurrent.BlockingRejectedExecutionHandler
- rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.infinispan.commons.util.concurrent.CallerRunsRejectOnShutdownPolicy
- rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.infinispan.commons.util.concurrent.LifecycleRejectedExecutionHandler
- rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.infinispan.commons.util.concurrent.NonBlockingRejectedExecutionHandler
- rejectFrom(String) - Method in class org.infinispan.server.core.configuration.IpFilterConfigurationBuilder
- rejectRuleMatchesRequestAddress(Object, Object) - Method in class org.infinispan.rest.logging.Messages_$bundle
- rejectRuleMatchesRequestAddress(Object, Object) - Method in interface org.infinispan.rest.logging.Messages
- rejectRuleMatchesRequestAddress$str() - Method in class org.infinispan.rest.logging.Messages_$bundle
- RELATIVE_TO - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- RELATIVE_TO - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.Attribute
- RELATIVE_TO - Static variable in class org.infinispan.configuration.global.GlobalStatePathConfiguration
- RELATIVE_TO - Static variable in class org.infinispan.configuration.global.TemporaryGlobalStatePathConfiguration
- relativeArtifactPath(char) - Method in class org.infinispan.commons.maven.MavenArtifact
-
Create a relative repository path for the given artifact coordinates.
- relativeTo() - Method in class org.infinispan.configuration.global.GlobalStatePathConfiguration
- relativeTo() - Method in class org.infinispan.configuration.global.TemporaryGlobalStatePathConfiguration
- release() - Method in class org.infinispan.rest.ServerSentEvent
- release(int) - Method in class org.infinispan.rest.ServerSentEvent
- release(Object) - Method in class org.infinispan.util.concurrent.locks.impl.InfinispanLock
-
It tries to release the lock held by
lockOwner
. - release(Object, Object) - Method in interface org.infinispan.util.concurrent.locks.impl.LockContainer
- release(Object, Object) - Method in class org.infinispan.util.concurrent.locks.impl.PerKeyLockContainer
- release(Object, Object) - Method in class org.infinispan.util.concurrent.locks.impl.StripedLockContainer
- releaseChannel(Channel) - Method in class org.infinispan.client.hotrod.counter.operation.AddListenerOperation
- releaseConnection(Connection) - Method in class org.infinispan.persistence.jdbc.common.connectionfactory.ConnectionFactory
-
Destroys a connection.
- RELEASED - Enum constant in enum org.infinispan.util.concurrent.locks.LockState
-
The lock owner released the lock.
- releaseLocksForCompletedTransaction(LocalTransaction, boolean) - Method in class org.infinispan.transaction.impl.TransactionTable
- reliability() - Method in class org.infinispan.counter.configuration.CounterManagerConfiguration
- reliability() - Method in class org.infinispan.lock.configuration.ClusteredLockManagerConfiguration
- reliability(Reliability) - Method in class org.infinispan.counter.configuration.CounterManagerConfigurationBuilder
-
Sets the
Reliability
mode. - reliability(Reliability) - Method in class org.infinispan.lock.configuration.ClusteredLockManagerConfigurationBuilder
-
Sets the
Reliability
mode. - Reliability - Enum in org.infinispan.counter.configuration
-
Reliability mode available for
CounterManager
. - Reliability - Enum in org.infinispan.lock.configuration
-
Locks are stored in a container that can privilege availability or consistency.
- RELIABILITY - Enum constant in enum org.infinispan.counter.configuration.Attribute
- RELIABILITY - Enum constant in enum org.infinispan.lock.configuration.Attribute
- reload() - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
-
Releases all used resources (IO, threads) and restarts from the mapping configuration.
- remainingTime(long, TimeUnit) - Method in class org.infinispan.commons.time.DefaultTimeService
- remainingTime(long, TimeUnit) - Method in interface org.infinispan.commons.time.TimeService
- remapAddresses(UnaryOperator<Address>) - Method in interface org.infinispan.distribution.ch.ConsistentHash
-
Returns a new ConsistentHash with the addresses remapped according to the provided
UnaryOperator
. - remapAddresses(UnaryOperator<Address>) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
- remapAddresses(UnaryOperator<Address>) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
- remapAddresses(UnaryOperator<Address>) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
- remapAddressRemoveMissing(UnaryOperator<Address>) - Method in interface org.infinispan.distribution.ch.ConsistentHash
-
Same as
ConsistentHash.remapAddresses(UnaryOperator)
but skip missing members. - remapAddressRemoveMissing(UnaryOperator<Address>) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
- remapCapacityFactors(UnaryOperator<Address>, boolean) - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
- remapMembers(UnaryOperator<Address>, boolean) - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
- REMOTE_CACHE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- REMOTE_CACHE - Static variable in class org.infinispan.configuration.cache.BackupForConfiguration
- REMOTE_CACHE_NAME - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- REMOTE_COMMAND_EXECUTOR - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- REMOTE_COMMIT_EXECUTION_TIME - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- REMOTE_EXECUTOR - Static variable in class org.infinispan.configuration.global.TransportConfiguration
- REMOTE_GET - Enum constant in enum org.infinispan.extendedstats.topK.StreamSummaryContainer.Stat
- REMOTE_GET_EXECUTION - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- REMOTE_ITERATION - Enum constant in enum org.infinispan.context.Flag
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 14.0, no longer does anything. Will be removed in 17.0.
- REMOTE_ITERATION - Static variable in class org.infinispan.context.impl.FlagBitSets
-
Deprecated, for removal: This API element is subject to removal in a future version.
- REMOTE_METADATA - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- REMOTE_PREPARE_EXECUTION_TIME - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- REMOTE_PUT - Enum constant in enum org.infinispan.extendedstats.topK.StreamSummaryContainer.Stat
- REMOTE_PUT_EXECUTION - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- REMOTE_QUERY_LOWER_BOUND - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- REMOTE_QUERY_REQUEST - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- REMOTE_QUERY_RESPONSE - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- REMOTE_ROLLBACK_EXECUTION_TIME - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- REMOTE_SERVER - Enum constant in enum org.infinispan.persistence.remote.configuration.Element
- REMOTE_SITE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- REMOTE_SITE - Enum constant in enum org.infinispan.configuration.parsing.Element
- REMOTE_SITE - Static variable in class org.infinispan.configuration.cache.BackupForConfiguration
- REMOTE_SITES - Enum constant in enum org.infinispan.configuration.parsing.Element
- REMOTE_STORE - Enum constant in enum org.infinispan.persistence.remote.configuration.Element
- REMOTE_TIMEOUT - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- REMOTE_TIMEOUT - Static variable in class org.infinispan.configuration.cache.ClusteringConfiguration
- RemoteApplicationPublishedBridge - Class in org.infinispan.spring.remote.session
-
A bridge between Infinispan Remote events and Spring.
- RemoteApplicationPublishedBridge(SpringCache) - Constructor for class org.infinispan.spring.remote.session.RemoteApplicationPublishedBridge
- remoteCache - Variable in class org.infinispan.reactive.publisher.impl.LocalPublisherManagerImpl
- remoteCache() - Method in class org.infinispan.configuration.cache.BackupForConfiguration
- remoteCache(String) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
- remoteCache(String) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- remoteCache(String) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
-
Per-cache configuration
- remoteCache(String) - Method in class org.infinispan.configuration.cache.BackupForBuilder
- RemoteCache<K,
V> - Interface in org.infinispan.client.hotrod -
Provides remote reference to a Hot Rod server/cluster.
- RemoteCacheClientStatisticsMXBean - Interface in org.infinispan.client.hotrod.jmx
-
RemoteCache client-side statistics (such as number of connections)
- RemoteCacheConfiguration - Class in org.infinispan.client.hotrod.configuration
- RemoteCacheConfigurationBuilder - Class in org.infinispan.client.hotrod.configuration
-
Per-cache configuration.
- RemoteCacheContainer - Interface in org.infinispan.client.hotrod
- RemoteCacheImpl<K,
V> - Class in org.infinispan.client.hotrod.impl - RemoteCacheImpl(RemoteCacheManager, String, ClientStatistics) - Constructor for class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- RemoteCacheImpl(RemoteCacheManager, String, TimeService) - Constructor for class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- RemoteCacheImpl(RemoteCacheManager, String, TimeService, NearCacheService<K, V>) - Constructor for class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- RemoteCacheManager - Class in org.infinispan.client.hotrod
-
Factory for
RemoteCache
s. - RemoteCacheManager() - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
-
Same as
RemoteCacheManager(boolean)
and it also starts the cache. - RemoteCacheManager(boolean) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
-
Similar to
RemoteCacheManager(Configuration, boolean)
, but it will try to lookup the config properties in the classpath, in a file named hotrod-client.properties. - RemoteCacheManager(String) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
-
Create a new RemoteCacheManager using the supplied URI.
- RemoteCacheManager(URI) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
-
Create a new RemoteCacheManager using the supplied URI.
- RemoteCacheManager(Configuration) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
-
Create a new RemoteCacheManager using the supplied
Configuration
. - RemoteCacheManager(Configuration, boolean) - Constructor for class org.infinispan.client.hotrod.RemoteCacheManager
-
Create a new RemoteCacheManager using the supplied
Configuration
. - RemoteCacheManagerAdmin - Interface in org.infinispan.client.hotrod
-
Remote Administration operations
- RemoteCacheManagerAdminImpl - Class in org.infinispan.client.hotrod.impl
- RemoteCacheManagerAdminImpl(RemoteCacheManager, OperationsFactory, EnumSet<CacheContainerAdmin.AdminFlag>, Consumer<String>) - Constructor for class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
- RemoteCacheManagerMXBean - Interface in org.infinispan.client.hotrod.jmx
-
RemoteCacheManager client-side statistics and operations
- RemoteCacheManagerNotStartedException - Exception in org.infinispan.client.hotrod.exceptions
-
Thrown when trying to use an
RemoteCache
that is associated to anRemoteCacheManager
that was not started. - RemoteCacheManagerNotStartedException(String) - Constructor for exception org.infinispan.client.hotrod.exceptions.RemoteCacheManagerNotStartedException
- remoteCacheName() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
- remoteCacheName(String) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- remoteCacheName(String) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- remoteCacheName(String) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
-
The name of the remote cache in the remote infinispan cluster, to which to connect to.
- remoteCaches() - Method in class org.infinispan.client.hotrod.configuration.Configuration
- RemoteCacheSupport<K,
V> - Class in org.infinispan.client.hotrod.impl -
Purpose: keep all delegating and unsupported methods in one place -> readability.
- RemoteCacheSupport() - Constructor for class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- RemoteCacheSupport(long, long) - Constructor for class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- remoteCacheTemplateNameXorConfiguration(String) - Method in interface org.infinispan.client.hotrod.logging.Log
- remoteCallTimeout() - Method in class org.infinispan.configuration.cache.ClusterLoaderConfiguration
-
Deprecated.
- remoteCallTimeout(long) - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
-
Deprecated.
- remoteCallTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
-
Deprecated.
- RemoteClusterListener - Class in org.infinispan.notifications.cachelistener.cluster
-
A listener that installed locally on each node when a cluster listener is installed on a given node.
- RemoteClusterListener(UUID, Address, CacheNotifier, CacheManagerNotifier, ClusterEventManager, boolean) - Constructor for class org.infinispan.notifications.cachelistener.cluster.RemoteClusterListener
- RemoteCommandsFactory - Class in org.infinispan.commands
-
Specifically used to create un-initialized
ReplicableCommand
s from a byte stream. - RemoteCommandsFactory() - Constructor for class org.infinispan.commands.RemoteCommandsFactory
- remoteCommandThreadPool() - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
- remoteCommandThreadPool() - Method in class org.infinispan.configuration.global.TransportConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.
- remoteCommandThreadPool() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
- RemoteCounterManager - Class in org.infinispan.client.hotrod.counter.impl
-
A
CounterManager
implementation for Hot Rod clients. - RemoteCounterManager() - Constructor for class org.infinispan.client.hotrod.counter.impl.RemoteCounterManager
- RemoteCounterManagerFactory - Class in org.infinispan.client.hotrod
-
A
CounterManager
factory for Hot Rod client. - RemoteException - Exception in org.infinispan.remoting
-
Represents an application-level exception originating in a remote node.
- RemoteException(String, Throwable) - Constructor for exception org.infinispan.remoting.RemoteException
- remoteExecutor(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
- RemoteExtendedStatisticsContainer - Class in org.infinispan.extendedstats.container
-
Container for the statistics corresponding to remote originated transactions.
- RemoteExtendedStatisticsContainer() - Constructor for class org.infinispan.extendedstats.container.RemoteExtendedStatisticsContainer
- RemoteIllegalLifecycleStateException - Exception in org.infinispan.client.hotrod.exceptions
-
This exception is thrown when the remote cache or cache manager does not have the right lifecycle state for operations to be called on it.
- RemoteIllegalLifecycleStateException(String, long, short) - Constructor for exception org.infinispan.client.hotrod.exceptions.RemoteIllegalLifecycleStateException
-
Deprecated, for removal: This API element is subject to removal in a future version.
- RemoteIllegalLifecycleStateException(String, long, short, SocketAddress) - Constructor for exception org.infinispan.client.hotrod.exceptions.RemoteIllegalLifecycleStateException
- RemoteLockCommand - Interface in org.infinispan.util.concurrent.locks
-
Simple interface to extract all the keys that may need to be locked.
- remoteLocksAcquired(Collection<Address>) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
- RemoteMetadata - Class in org.infinispan.container.entries
-
This is a metadata type used by scattered cache during state transfer.
- RemoteMetadata(Address, EntryVersion) - Constructor for class org.infinispan.container.entries.RemoteMetadata
- RemoteMetadata.Externalizer - Class in org.infinispan.container.entries
- RemoteMetadata$___Marshaller_4cb4a1b59ce257eb4994240cafc1894764116cb17c3875df246d2943dcbdce0d - Class in org.infinispan.container.entries
-
WARNING: Generated code! Do not edit!
- RemoteMetadata$___Marshaller_4cb4a1b59ce257eb4994240cafc1894764116cb17c3875df246d2943dcbdce0d() - Constructor for class org.infinispan.container.entries.RemoteMetadata$___Marshaller_4cb4a1b59ce257eb4994240cafc1894764116cb17c3875df246d2943dcbdce0d
- RemoteMultimapCache<K,
V> - Interface in org.infinispan.client.hotrod.multimap - RemoteMultimapCacheManager<K,
V> - Class in org.infinispan.client.hotrod.multimap - RemoteMultimapCacheManager(RemoteCacheManager) - Constructor for class org.infinispan.client.hotrod.multimap.RemoteMultimapCacheManager
- RemoteMultimapCacheManagerFactory - Class in org.infinispan.client.hotrod.multimap
- remoteNodeSuspected(Address) - Static method in class org.infinispan.remoting.transport.ResponseCollectors
- RemoteNodeSuspectException - Exception in org.infinispan.client.hotrod.exceptions
-
When a remote node is suspected and evicted from the cluster while an operation is ongoing, the Hot Rod client emits this exception.
- RemoteNodeSuspectException(String, long, short) - Constructor for exception org.infinispan.client.hotrod.exceptions.RemoteNodeSuspectException
- remoteSecurity() - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- remoteSecurity() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- remoteSecurity() - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
-
Configures connection security
- RemoteServerConfiguration - Class in org.infinispan.persistence.remote.configuration
- RemoteServerConfigurationBuilder - Class in org.infinispan.persistence.remote.configuration
- remoteSite() - Method in class org.infinispan.configuration.cache.BackupForConfiguration
- remoteSite(String) - Method in class org.infinispan.configuration.cache.BackupForBuilder
- RemoteSites(String, String) - Constructor for class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.RemoteSites
- RemoteSiteStatus - Class in org.infinispan.xsite.statetransfer
-
Cross-Site state transfer status & collector
- RemoteStore<K,
V> - Class in org.infinispan.persistence.remote -
Cache store that delegates the call to a infinispan cluster.
- RemoteStore() - Constructor for class org.infinispan.persistence.remote.RemoteStore
- RemoteStoreBlockHoundIntegration - Class in org.infinispan.persistence.remote.internal
- RemoteStoreBlockHoundIntegration() - Constructor for class org.infinispan.persistence.remote.internal.RemoteStoreBlockHoundIntegration
- RemoteStoreConfiguration - Class in org.infinispan.persistence.remote.configuration
- RemoteStoreConfiguration(AttributeSet, AsyncStoreConfiguration, ExecutorFactoryConfiguration, ConnectionPoolConfiguration, SecurityConfiguration, List<RemoteServerConfiguration>) - Constructor for class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
- RemoteStoreConfigurationBuilder - Class in org.infinispan.persistence.remote.configuration
-
RemoteStoreConfigurationBuilder.
- RemoteStoreConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- RemoteStoreConfigurationChildBuilder<S> - Interface in org.infinispan.persistence.remote.configuration
- RemoteStoreConfigurationParser - Class in org.infinispan.persistence.remote.configuration
-
Remote cache store parser.
- RemoteStoreConfigurationParser() - Constructor for class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationParser
- RemoteStoreConfigurationSerializer - Class in org.infinispan.persistence.remote.configuration
-
RemoteStoreConfigurationSerializer.
- RemoteStoreConfigurationSerializer() - Constructor for class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationSerializer
- remoteStoreNoHotRodWrapping(String) - Method in interface org.infinispan.persistence.remote.logging.Log
- remoteThreadPool() - Method in class org.infinispan.configuration.global.ThreadsConfiguration
- remoteThreadPoolName() - Method in class org.infinispan.configuration.global.TransportConfiguration
- remoteTimeout() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
-
This is the timeout used to wait for an acknowledgment when making a remote call, after which the call is aborted and an exception is thrown.
- remoteTimeout(long) - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
-
This is the timeout used to wait for an acknowledgment when making a remote call, after which the call is aborted and an exception is thrown.
- remoteTimeout(long) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
-
This is the timeout used to wait for an acknowledgment when making a remote call, after which the call is aborted and an exception is thrown.
- remoteTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
-
This is the timeout used to wait for an acknowledgment when making a remote call, after which the call is aborted and an exception is thrown.
- RemoteTransaction - Class in org.infinispan.transaction.impl
-
Defines the state of a remotely originated transaction.
- RemoteTransaction(List<WriteCommand>, GlobalTransaction, int, long) - Constructor for class org.infinispan.transaction.impl.RemoteTransaction
- RemoteTransaction(GlobalTransaction, int, long) - Constructor for class org.infinispan.transaction.impl.RemoteTransaction
- remoteTransactionCommitted(GlobalTransaction, boolean) - Method in class org.infinispan.transaction.impl.TransactionTable
-
Removes the
RemoteTransaction
corresponding to the given tx. - remoteTransactionCommitted(GlobalTransaction, boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
- RemoteTransactionManager - Class in org.infinispan.client.hotrod.transaction.manager
-
A simple
TransactionManager
implementation. - RemoteTransactionManagerLookup - Class in org.infinispan.client.hotrod.transaction.lookup
-
Returns an instance of
RemoteTransactionManager
. - remoteTransactionPrepared(GlobalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
- remoteTransactionPrepared(GlobalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
-
Marks the transaction as prepared.
- remoteTransactionRollback(GlobalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
- remoteTransactionRollback(GlobalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
- RemoteTransactionStatistics - Class in org.infinispan.extendedstats
-
Represents the statistic collected for a remote transaction
- RemoteTransactionStatistics(TimeService) - Constructor for class org.infinispan.extendedstats.RemoteTransactionStatistics
- RemoteTxInvocationContext - Class in org.infinispan.context.impl
-
Context to be used for transaction that originated remotely.
- RemoteTxInvocationContext(RemoteTransaction) - Constructor for class org.infinispan.context.impl.RemoteTxInvocationContext
- remoteValueFound(InternalCacheEntry) - Method in class org.infinispan.distribution.impl.L1ManagerImpl
- remoteValueFound(InternalCacheEntry) - Method in interface org.infinispan.distribution.RemoteValueRetrievedListener
-
Invoked when a remote value is found from a remote source
- remoteValueNotFound(Object) - Method in class org.infinispan.distribution.impl.L1ManagerImpl
- remoteValueNotFound(Object) - Method in interface org.infinispan.distribution.RemoteValueRetrievedListener
-
Invoked when a remote value is not found from the remote source for the given key
- RemoteValueRetrievedListener - Interface in org.infinispan.distribution
-
Listener that is notified when a remote value is looked up
- RemoteXid - Class in org.infinispan.client.hotrod.transaction.manager
-
Implementation of
Xid
used byRemoteTransactionManager
. - RemovableCloseableIterator<C> - Class in org.infinispan.commons.util
-
A CloseableIterator implementation that allows for a CloseableIterator that doesn't allow remove operations to implement remove by delegating the call to the provided consumer to remove the previously read value.
- RemovableCloseableIterator<K,
C> - Class in org.infinispan.stream.impl -
Deprecated.Users should use
RemovableCloseableIterator
instead - RemovableCloseableIterator(CloseableIterator<C>, Consumer<? super C>) - Constructor for class org.infinispan.commons.util.RemovableCloseableIterator
- RemovableCloseableIterator(CloseableIterator<C>, Cache<K, ?>, Function<? super C, K>) - Constructor for class org.infinispan.stream.impl.RemovableCloseableIterator
-
Deprecated.
- RemovableIterator<C> - Class in org.infinispan.commons.util
-
An Iterator implementation that allows for a Iterator that doesn't allow remove operations to implement remove by delegating the call to the provided consumer to remove the previously read value.
- RemovableIterator<K,
C> - Class in org.infinispan.stream.impl -
Deprecated.Users should use
RemovableIterator
instead - RemovableIterator(Iterator<C>, Consumer<? super C>) - Constructor for class org.infinispan.commons.util.RemovableIterator
- RemovableIterator(Iterator<C>, Cache<K, ?>, Function<? super C, K>) - Constructor for class org.infinispan.stream.impl.RemovableIterator
-
Deprecated.
- remove() - Method in class org.infinispan.client.hotrod.counter.impl.BaseCounter
- remove() - Method in class org.infinispan.commons.util.ConcatIterator
- remove() - Method in class org.infinispan.commons.util.FilterIterator
- remove() - Method in class org.infinispan.commons.util.IteratorMapper
- remove() - Method in class org.infinispan.commons.util.RemovableIterator
- remove() - Method in interface org.infinispan.counter.api.Handle
-
Removes the
CounterListener
. - remove() - Method in interface org.infinispan.counter.api.StrongCounter
-
It removes this counter from the cluster.
- remove() - Method in interface org.infinispan.counter.api.SyncStrongCounter
- remove() - Method in interface org.infinispan.counter.api.SyncWeakCounter
- remove() - Method in interface org.infinispan.counter.api.WeakCounter
-
It removes this counter from the cluster.
- remove() - Method in class org.infinispan.counter.impl.SyncStrongCounterAdapter
- remove() - Method in class org.infinispan.counter.impl.SyncWeakCounterAdapter
- remove() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator
- remove() - Method in interface org.infinispan.functional.EntryView.WriteEntryView
-
Removes the value and any metadata parameters associated with it.
- remove() - Method in interface org.infinispan.query.Indexer
-
Removes all indexes from the cache.
- remove() - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
- remove() - Method in class org.infinispan.util.DataContainerRemoveIterator
- remove(int) - Method in class org.infinispan.commons.util.ImmutableIntSet
- remove(int) - Method in class org.infinispan.commons.util.ForwardingList
- remove(int) - Method in interface org.infinispan.commons.util.IntSet
-
Removes, if present, the int from the set and returns if it was present or not
- remove(int) - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- remove(int) - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.Remove an integer from the set without boxing.
- remove(int, Object) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- remove(int, Object) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
- remove(int, Object) - Method in interface org.infinispan.container.impl.InternalDataContainer
-
Same as
DataContainer.remove(Object)
except that the segment of the key can provided to remove the entry without calculating the segment for the given key. - remove(int, Object) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- remove(Channel) - Method in class org.infinispan.server.memcached.MemcachedDecoder
- remove(Class<?>...) - Method in interface org.infinispan.query.Indexer
-
Removes all entities of a particular class from the index of the cache.
- remove(Class<T>) - Method in class org.infinispan.functional.impl.MetaParams
- remove(Object) - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
- remove(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- remove(Object) - Method in class org.infinispan.cache.impl.CacheImpl
- remove(Object) - Method in class org.infinispan.cache.impl.DecoratedCache
- remove(Object) - Method in class org.infinispan.cache.impl.EncoderCache
- remove(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySetBase
- remove(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.KeySet
- remove(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- remove(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.Values
- remove(Object) - Method in class org.infinispan.cache.impl.StatsCollectingCache
- remove(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- remove(Object) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
If the return value of this operation will be ignored by the application, the user is strongly encouraged to use the
Flag.IGNORE_RETURN_VALUES
flag when invoking this method in order to make it behave as efficiently as possible (i.e. - remove(Object) - Method in interface org.infinispan.commons.api.BasicCache
-
If the return value of this operation will be ignored by the application, the user is strongly encouraged to use the
Flag.IGNORE_RETURN_VALUES
flag when invoking this method in order to make it behave as efficiently as possible (i.e. - remove(Object) - Method in class org.infinispan.commons.dataconversion.internal.Json
-
Remove the specified Java object (converted to a Json instance) from a
Json
array. - remove(Object) - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
- remove(Object) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
- remove(Object) - Method in class org.infinispan.commons.util.ImmutableIntSet
- remove(Object) - Method in class org.infinispan.commons.util.ArrayMap
- remove(Object) - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
- remove(Object) - Method in class org.infinispan.commons.util.FastCopyHashMap.KeySet
- remove(Object) - Method in class org.infinispan.commons.util.FastCopyHashMap
- remove(Object) - Method in class org.infinispan.commons.util.ForwardingList
- remove(Object) - Method in class org.infinispan.commons.util.HopscotchHashMap
- remove(Object) - Method in class org.infinispan.commons.util.ImmutableHopscotchHashSet
- remove(Object) - Method in class org.infinispan.commons.util.ImmutableListCopy
- remove(Object) - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- remove(Object) - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- remove(Object) - Method in class org.infinispan.commons.util.WeakValueHashMap
- remove(Object) - Method in interface org.infinispan.container.DataContainer
-
Removes an entry from the cache
- remove(Object) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- remove(Object) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
- remove(Object) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- remove(Object) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- remove(Object) - Method in class org.infinispan.InternalCacheSet
- remove(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
- remove(Object) - Method in class org.infinispan.util.CollectionMapper
- remove(Object) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
- remove(Object, Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- remove(Object, Object) - Method in class org.infinispan.cache.impl.CacheImpl
- remove(Object, Object) - Method in class org.infinispan.cache.impl.DecoratedCache
- remove(Object, Object) - Method in class org.infinispan.cache.impl.EncoderCache
- remove(Object, Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- remove(Object, Object) - Method in class org.infinispan.cache.impl.StatsCollectingCache
- remove(Object, Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- remove(Object, Object) - Method in interface org.infinispan.client.hotrod.RemoteCache
- remove(Object, Object) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
- remove(Object, Object) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- remove(Object, Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
- remove(String) - Method in class org.infinispan.client.hotrod.counter.impl.RemoteCounterManager
- remove(String) - Method in interface org.infinispan.counter.api.CounterManager
-
It removes the counter from the cluster.
- remove(String) - Method in interface org.infinispan.lock.api.ClusteredLockManager
-
Removes a
ClusteredLock
if such exists. - remove(Predicate<? super V>) - Method in interface org.infinispan.multimap.api.embedded.MultimapCache
-
Asynchronous method.
- remove(Predicate<? super V>) - Method in class org.infinispan.multimap.impl.EmbeddedMultimapCache
- remove(K) - Method in interface org.infinispan.client.hotrod.near.NearCache
- remove(K) - Method in class org.infinispan.client.hotrod.near.NearCacheService
- remove(K) - Method in interface org.infinispan.multimap.api.BasicMultimapCache
-
Removes all the key-value pairs associated with the key from this multimap cache, if such exists.
- remove(K) - Method in class org.infinispan.multimap.impl.EmbeddedMultimapCache
- remove(K, MetadataValue<V>) - Method in interface org.infinispan.client.hotrod.near.NearCache
- remove(K, MetadataValue<V>) - Method in class org.infinispan.client.hotrod.near.NearCacheService
- remove(K, V) - Method in interface org.infinispan.multimap.api.BasicMultimapCache
-
Removes a key-value pair from this multimap cache, if such exists.
- remove(K, V) - Method in class org.infinispan.multimap.impl.EmbeddedMultimapCache
- remove(Json) - Method in class org.infinispan.commons.dataconversion.internal.Json
-
Remove the specified element from a
Json
array. - remove(CacheXid) - Method in class org.infinispan.server.hotrod.tx.table.GlobalTxTable
- remove(SerializablePredicate<? super V>) - Method in interface org.infinispan.multimap.api.embedded.MultimapCache
-
Overloaded method of
MultimapCache.remove(Predicate)
withSerializablePredicate
. - remove(T) - Method in class org.infinispan.util.DependencyGraph
-
Remove element from the graph
- remove(V, boolean) - Method in class org.infinispan.multimap.impl.Bucket
- Remove - Class in org.infinispan.persistence.modifications
-
Represents a
CacheWriter.delete(Object)
(Object)} modification - Remove(Object) - Constructor for class org.infinispan.persistence.modifications.Remove
- REMOVE - Enum constant in enum org.infinispan.eviction.EvictionStrategy
-
Strategy where the cache will remove entries to make room for new ones while staying under the configured size
- REMOVE - Enum constant in enum org.infinispan.notifications.cachemanagerlistener.event.ConfigurationChangedEvent.EventType
- REMOVE - Enum constant in enum org.infinispan.persistence.modifications.Modification.Type
- REMOVE - Enum constant in enum org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.StackCombine
- REMOVE - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- REMOVE - Enum constant in enum org.infinispan.util.concurrent.DataOperationOrderer.Operation
- REMOVE_ALL - Enum constant in enum org.infinispan.conflict.MergePolicy
- REMOVE_CLIENT_LISTENER - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- REMOVE_CLIENT_LISTENER_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- REMOVE_ENTRY_MULTIMAP - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- REMOVE_ENTRY_MULTIMAP_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- REMOVE_HITS - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
-
Number of removal hits.
- REMOVE_IF_UNMODIFIED - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- REMOVE_IF_UNMODIFIED_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- REMOVE_KEY_MULTIMAP_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- REMOVE_KEY_VALUE_FUNCTION - Static variable in interface org.infinispan.multimap.impl.ExternalizerIds
- REMOVE_MISSES - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
-
Number of removal misses.
- REMOVE_MULTIMAP - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- REMOVE_OP - Enum constant in enum org.infinispan.server.hotrod.tx.ControlByte
- REMOVE_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- removeAll() - Method in class org.infinispan.container.offheap.MemoryAddressHash
-
Removes all the address lookups by setting them to 0.
- removeAll(int, int) - Method in class org.infinispan.container.offheap.MemoryAddressHash
-
Removes all the address lookups by setting them to 0 within the given offset, limiting the removal to only a specific count of addresses.
- removeAll(Collection<?>) - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
- removeAll(Collection<?>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySetBase
- removeAll(Collection<?>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.KeySet
- removeAll(Collection<?>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.Values
- removeAll(Collection<?>) - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
- removeAll(Collection<?>) - Method in class org.infinispan.commons.util.ImmutableIntSet
- removeAll(Collection<?>) - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
- removeAll(Collection<?>) - Method in class org.infinispan.commons.util.ForwardingList
- removeAll(Collection<?>) - Method in class org.infinispan.commons.util.ImmutableHopscotchHashSet
- removeAll(Collection<?>) - Method in class org.infinispan.commons.util.ImmutableListCopy
- removeAll(Collection<?>) - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- removeAll(Collection<?>) - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- removeAll(Collection<?>) - Method in class org.infinispan.InternalCacheSet
- removeAll(Collection<?>) - Method in class org.infinispan.util.CollectionMapper
- removeAll(Collection<?>) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
- removeAll(IntSet) - Method in class org.infinispan.commons.util.ImmutableIntSet
- removeAll(IntSet) - Method in interface org.infinispan.commons.util.IntSet
-
Removes all ints from this IntSet that are in the provided IntSet
- removeAll(IntSet) - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- removeAll(IntSet) - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- removeAllListeners() - Method in class org.infinispan.client.hotrod.event.impl.ContinuousQueryImpl
- removeAllListeners() - Method in interface org.infinispan.query.api.continuous.ContinuousQuery
-
Unregisters all listeners.
- removeAndUnlock(TemporaryTable.LockedEntry, int, Object) - Method in class org.infinispan.persistence.sifs.TemporaryTable
- removeAsync(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- removeAsync(Object) - Method in class org.infinispan.cache.impl.CacheImpl
- removeAsync(Object) - Method in class org.infinispan.cache.impl.DecoratedCache
- removeAsync(Object) - Method in class org.infinispan.cache.impl.EncoderCache
- removeAsync(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- removeAsync(Object) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- removeAsync(Object) - Method in class org.infinispan.client.hotrod.impl.InvalidatedNearRemoteCache
- removeAsync(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- removeAsync(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- removeAsync(Object) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
BasicCache.remove(Object)
. - removeAsync(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
- removeAsync(Object, Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- removeAsync(Object, Object) - Method in class org.infinispan.cache.impl.CacheImpl
- removeAsync(Object, Object) - Method in class org.infinispan.cache.impl.DecoratedCache
- removeAsync(Object, Object) - Method in class org.infinispan.cache.impl.EncoderCache
- removeAsync(Object, Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- removeAsync(Object, Object) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- removeAsync(Object, Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- removeAsync(Object, Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- removeAsync(Object, Object) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
ConcurrentMap.remove(Object, Object)
. - removeAsync(Object, Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
- removeAsyncEntry(Object) - Method in interface org.infinispan.AdvancedCache
-
An extension of
AsyncCache.removeAsync(Object)
, which returns aCacheEntry
instead of only the value. - removeAsyncEntry(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- removeAsyncEntry(Object) - Method in class org.infinispan.cache.impl.CacheImpl
- removeAsyncEntry(Object) - Method in class org.infinispan.cache.impl.DecoratedCache
- removeAsyncEntry(Object) - Method in class org.infinispan.cache.impl.EncoderCache
- removeAsyncEntry(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- removeAsyncEntry(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
- removeAsyncReturnEntry(K) - Method in interface org.infinispan.AdvancedCache
- removeAsyncReturnEntry(K) - Method in class org.infinispan.cache.impl.EncoderCache
- removeAsyncReturnEntry(K) - Method in class org.infinispan.security.impl.SecureCacheImpl
- removeAttribute(String) - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository.InfinispanSession
- removeBackup(String) - Method in class org.infinispan.server.core.backup.BackupManagerImpl
- removeBackup(String) - Method in interface org.infinispan.server.core.BackupManager
-
Remove the created backup file from the server.
- removeBackupLock(Object) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
- removeBackupLock(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
-
It cleans up the backup for
key
. - removeBackupLocks(Collection<?>) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
- removeBackupLocks(Collection<?>) - Method in interface org.infinispan.transaction.xa.CacheTransaction
-
It cleans up the backup lock for the
keys
. - removeCache(String) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
- removeCache(String) - Method in interface org.infinispan.client.hotrod.RemoteCacheManagerAdmin
-
Removes a cache from the remote server cluster.
- removeCache(String) - Method in interface org.infinispan.commons.api.CacheContainerAdmin
-
Removes a cache from the cache container.
- removeCache(String) - Method in class org.infinispan.factories.GlobalComponentRegistry
-
Removes a cache with the given name, returning true if the cache was removed.
- removeCache(String) - Method in class org.infinispan.manager.DefaultCacheManager
- removeCache(String) - Method in class org.infinispan.manager.DefaultCacheManagerAdmin
- removeCache(String) - Method in interface org.infinispan.manager.EmbeddedCacheManager
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 9.2, obtain a
CacheContainerAdmin
instance usingEmbeddedCacheManager.administration()
and invoke theCacheContainerAdmin.removeCache(String)
method - removeCache(String) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
- removeCache(String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.GlobalConfigurationManager
-
Removes a cluster-wide cache and its configuration
- removeCache(String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.GlobalConfigurationManagerImpl
- removeCache(String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.ImmutableLocalConfigurationStorage
- removeCache(String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.OverlayLocalConfigurationStorage
- removeCache(String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
- removeCache(String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.LocalConfigurationStorage
-
Removes the specified cache.
- removeCacheEventConverterFactory(String) - Method in class org.infinispan.server.hotrod.HotRodServer
- removeCacheEventFilterConverterFactory(String) - Method in class org.infinispan.server.hotrod.HotRodServer
- removeCacheEventFilterFactory(String) - Method in class org.infinispan.server.hotrod.HotRodServer
- removeCacheSync(String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
- removeClientListener(byte[]) - Method in class org.infinispan.client.hotrod.event.impl.ClientListenerNotifier
- removeClientListener(Object) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- removeClientListener(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- removeClientListener(Object) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
Remove a previously added client listener.
- removeConditionally(int, Object, int, int) - Method in class org.infinispan.persistence.sifs.TemporaryTable
- removeConfiguration(String) - Method in class org.infinispan.configuration.ConfigurationManager
- removeConsumer() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- removeContinuousQueryListener(ContinuousQueryListener<K, ?>) - Method in class org.infinispan.client.hotrod.event.impl.ContinuousQueryImpl
- removeContinuousQueryListener(ContinuousQueryListener<K, ?>) - Method in interface org.infinispan.query.api.continuous.ContinuousQuery
-
Remove a continuous query listener.
- removeCounterListener(byte[], String) - Method in class org.infinispan.server.hotrod.counter.listener.ClientCounterManagerNotificationManager
- REMOVED - Enum constant in enum org.infinispan.container.entries.ReadCommittedEntry.Flags
- REMOVED - Static variable in interface org.infinispan.notifications.cachelistener.QueueingSegmentListener
- REMOVED_FILTER - Static variable in interface org.infinispan.persistence.remote.ExternalizerIds
- RemovedAttribute(Enum<?>, int, int) - Constructor for class org.infinispan.commons.configuration.attributes.AttributeSet.RemovedAttribute
- RemovedAttribute(String, int, int) - Constructor for class org.infinispan.commons.configuration.attributes.AttributeSet.RemovedAttribute
- removeDependency(T, T) - Method in class org.infinispan.util.DependencyGraph
-
Remove a dependency
- RemovedEventImpl<K> - Class in org.infinispan.client.hotrod.event.impl
- RemovedEventImpl(byte[], K, boolean) - Constructor for class org.infinispan.client.hotrod.event.impl.RemovedEventImpl
- RemovedFilter<K,
V> - Class in org.infinispan.persistence.remote.upgrade - RemovedFilter() - Constructor for class org.infinispan.persistence.remote.upgrade.RemovedFilter
- RemovedFilter.Externalizer - Class in org.infinispan.persistence.remote.upgrade
- removedUnclosedIterator(String) - Method in interface org.infinispan.server.hotrod.logging.Log
- removeEntry(Object) - Method in class org.infinispan.persistence.support.BatchModification
- removeEntry(Map.Entry<K, V>) - Method in interface org.infinispan.client.hotrod.impl.InternalRemoteCache
- removeEntry(K, V) - Method in interface org.infinispan.client.hotrod.impl.InternalRemoteCache
- removeEntryInMap(PeekableTouchableMap<K, V>, int, Object) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
- removeEntryInMap(PeekableTouchableMap<K, V>, int, Object) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
- removeExtraBackupOwners(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
- removeFromCacheWithoutNotifications(String) - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository
- removeFromCacheWithoutNotifications(String) - Method in class org.infinispan.spring.embedded.session.InfinispanEmbeddedSessionRepository
- removeFromCacheWithoutNotifications(String) - Method in class org.infinispan.spring.remote.session.InfinispanRemoteSessionRepository
- removeGroup(String) - Method in interface org.infinispan.AdvancedCache
-
It removes all the key which belongs to a group.
- removeGroup(String) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- removeGroup(String) - Method in class org.infinispan.cache.impl.CacheImpl
- removeGroup(String) - Method in class org.infinispan.cache.impl.DecoratedCache
- removeGroup(String) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- removeGroup(String) - Method in class org.infinispan.security.impl.SecureCacheImpl
- removeIf(IntPredicate) - Method in class org.infinispan.commons.util.ImmutableIntSet
- removeIf(IntPredicate) - Method in interface org.infinispan.commons.util.IntSet
-
Removes all of the ints of this set that satisfy the given predicate.
- removeIf(IntPredicate) - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- removeIf(IntPredicate) - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- removeIf(Predicate<? super E>) - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
- removeIf(Predicate<? super E>) - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
- removeIf(Predicate<? super E>) - Method in class org.infinispan.commons.util.ImmutableHopscotchHashSet
- removeIf(Predicate<? super E>) - Method in class org.infinispan.InternalCacheSet
- removeIf(Predicate<? super Integer>) - Method in class org.infinispan.commons.util.ImmutableIntSet
- removeIf(Predicate<? super R>) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
- removeIf(Predicate<? super V>) - Method in class org.infinispan.multimap.impl.Bucket
- removeIfValueEqualsReturnBoolean() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- removeInterceptor(int) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
-
Removes the interceptor at the given position.
- removeInterceptor(int) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
- removeInterceptor(Class<? extends AsyncInterceptor>) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
-
Removes all the occurrences of supplied interceptor type from the chain.
- removeInterceptor(Class<? extends AsyncInterceptor>) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
- removeInternalListener(Object) - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
- removeInternalListener(Object) - Method in interface org.infinispan.expiration.impl.InternalExpirationManager
-
Removes a previous registered
InternalExpirationManager.ExpirationConsumer
. - removeInvalidationsFinished() - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
- removeKeyValueFilterConverterFactory(String) - Method in class org.infinispan.server.hotrod.HotRodServer
- removeKeyValueFilterConverterFactory(String) - Method in class org.infinispan.server.hotrod.iteration.DefaultIterationManager
- removeKeyValueFilterConverterFactory(String) - Method in interface org.infinispan.server.hotrod.iteration.IterationManager
- removeLifespanExpired(K, V, Long) - Method in interface org.infinispan.AdvancedCache
-
Attempts to remove the entry if it is expired.
- removeLifespanExpired(K, V, Long) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- removeLifespanExpired(K, V, Long) - Method in class org.infinispan.cache.impl.CacheImpl
- removeLifespanExpired(K, V, Long) - Method in class org.infinispan.cache.impl.DecoratedCache
- removeLifespanExpired(K, V, Long) - Method in class org.infinispan.cache.impl.EncoderCache
- removeLifespanExpired(K, V, Long) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- removeLifespanExpired(K, V, Long) - Method in class org.infinispan.security.impl.SecureCacheImpl
- removeListener() - Method in class org.infinispan.notifications.cachelistener.cluster.RemoteClusterListener
- removeListener(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- removeListener(Object) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
- removeListener(Object) - Method in interface org.infinispan.notifications.Listenable
-
Removes a listener from the component.
- removeListener(AttributeListener<T>) - Method in class org.infinispan.commons.configuration.attributes.Attribute
- removeListenerAsync(Object) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- removeListenerAsync(Object) - Method in class org.infinispan.cache.impl.CacheImpl
- removeListenerAsync(Object) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- removeListenerAsync(Object) - Method in class org.infinispan.manager.DefaultCacheManager
- removeListenerAsync(Object) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
- removeListenerAsync(Object) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- removeListenerAsync(Object) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
- removeListenerAsync(Object) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
- removeListenerAsync(Object) - Method in interface org.infinispan.notifications.Listenable
-
Asynchronous version of
Listenable.removeListener(Object)
- removeListenerAsync(Object) - Method in class org.infinispan.security.impl.SecureCacheImpl
- RemoveListenerAsyncAction - Class in org.infinispan.security.actions
-
removeListenerAsync action
- RemoveListenerAsyncAction(Listenable, Object) - Constructor for class org.infinispan.security.actions.RemoveListenerAsyncAction
- removeListenerFromMaps(Object) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
- removeListenerInvocation(Class<? extends Annotation>, Object) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- removeListenerInvocation(Class<? extends Annotation>, Object) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
- RemoveListenerOperation - Class in org.infinispan.client.hotrod.counter.operation
-
A remove listener operation for
Handle.remove()
. - RemoveListenerOperation(ChannelFactory, AtomicReference<ClientTopology>, Configuration, String, byte[], SocketAddress) - Constructor for class org.infinispan.client.hotrod.counter.operation.RemoveListenerOperation
- removeLocalTransaction(LocalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
-
Removes the
TransactionXaAdapter
corresponding to the given tx. - removeLocalTransaction(LocalTransaction) - Method in class org.infinispan.transaction.xa.XaTransactionTable
- removeLocalTx(XidImpl) - Method in class org.infinispan.server.hotrod.tx.table.PerCacheTxTable
-
Removes the local
EmbeddedTransaction
associated toxid
. - removeLookedUpEntries(Collection<?>) - Method in interface org.infinispan.context.EntryLookup
- removeLookedUpEntry(Object) - Method in interface org.infinispan.context.EntryLookup
- removeLookedUpEntry(Object) - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
- removeLookedUpEntry(Object) - Method in class org.infinispan.context.impl.ClearInvocationContext
- removeLookedUpEntry(Object) - Method in class org.infinispan.context.impl.ImmutableContext
- removeLookedUpEntry(Object) - Method in class org.infinispan.context.impl.NonTxInvocationContext
- removeLookedUpEntry(Object) - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
- removeLookedUpEntry(Object) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
- removeLookedUpEntry(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
- removeMaxIdleExpired(K, V) - Method in interface org.infinispan.AdvancedCache
-
Attempts to remove the entry for the given key, if it has expired due to max idle.
- removeMaxIdleExpired(K, V) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- removeMaxIdleExpired(K, V) - Method in class org.infinispan.cache.impl.CacheImpl
- removeMaxIdleExpired(K, V) - Method in class org.infinispan.cache.impl.DecoratedCache
- removeMaxIdleExpired(K, V) - Method in class org.infinispan.cache.impl.EncoderCache
- removeMaxIdleExpired(K, V) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- removeMaxIdleExpired(K, V) - Method in class org.infinispan.security.impl.SecureCacheImpl
- RemoveOperation - Class in org.infinispan.client.hotrod.counter.operation
-
A counter operation for
CounterManager.remove(String)
,StrongCounter.remove()
andWeakCounter.remove()
. - RemoveOperation(ChannelFactory, AtomicReference<ClientTopology>, Configuration, String, boolean) - Constructor for class org.infinispan.client.hotrod.counter.operation.RemoveOperation
- removeOwner(int, Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
- removePersistentAddressMapping(Address) - Method in interface org.infinispan.topology.PersistentUUIDManager
-
Removes any address mapping for the specified
Address
- removePersistentAddressMapping(Address) - Method in class org.infinispan.topology.PersistentUUIDManagerImpl
- removePersistentAddressMapping(PersistentUUID) - Method in interface org.infinispan.topology.PersistentUUIDManager
-
Removes any address mapping for the specified
PersistentUUID
- removePersistentAddressMapping(PersistentUUID) - Method in class org.infinispan.topology.PersistentUUIDManagerImpl
- removeProperty(String) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
-
Deprecated.
- removeProperty(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
- removeRange(int, int) - Method in class org.infinispan.commons.util.ImmutableListCopy.ImmutableSubList
- removeRecoveryInformation(Long) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
-
Same as
RecoveryManager.removeRecoveryInformation(XidImpl)
but identifies the tx by its internal id. - removeRecoveryInformation(Long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
- removeRecoveryInformation(Collection<Address>, XidImpl, GlobalTransaction, boolean) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
-
Removes from the specified nodes (or all nodes if the value of 'where' is null) the recovery information associated with these Xids.
- removeRecoveryInformation(Collection<Address>, XidImpl, GlobalTransaction, boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
- removeRecoveryInformation(XidImpl) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
-
Remove recovery information stored on this node (doesn't involve rpc).
- removeRecoveryInformation(XidImpl) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
- removeRecoveryInformationFromCluster(Collection<Address>, long) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
-
Same as
RecoveryManager.removeRecoveryInformation(Collection, XidImpl, GlobalTransaction, boolean)
but the transaction is identified by its internal id, and not by its xid. - removeRecoveryInformationFromCluster(Collection<Address>, long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
- removeRemoteCache(String) - Method in class org.infinispan.client.hotrod.configuration.Configuration
-
Remove a
RemoteCacheConfiguration
from thisConfiguration
. - removeRemoteTransaction(XidImpl) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
- removeRemoteTransaction(GlobalTransaction) - Method in class org.infinispan.transaction.impl.TransactionTable
- removeRemovalListener(Object) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- removeRemovalListener(Object) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
- removeRemovalListener(Object) - Method in interface org.infinispan.container.impl.InternalDataContainer
-
Removes a previously registered listener via
InternalDataContainer.addRemovalListener(Consumer)
. - removeRemovalListener(Object) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- removeRequest(long) - Method in class org.infinispan.remoting.transport.impl.RequestRepository
- RemoveRequest - Enum constant in enum org.infinispan.server.memcached.MemcachedOperation
- removeRestore(String) - Method in class org.infinispan.server.core.backup.BackupManagerImpl
- removeRestore(String) - Method in interface org.infinispan.server.core.BackupManager
-
Remove the meta information associated with a restoration.
- removeReturnBoolean() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- removeReturnPrevOrNull() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- removeRole(String) - Method in class org.infinispan.security.mappers.ClusterPermissionMapper
- removeRole(String) - Method in interface org.infinispan.security.MutableRolePermissionMapper
-
Removes a role
- removeScript(String) - Method in interface org.infinispan.scripting.ScriptingManager
-
Removes a script.
- removeSegments(IntSet) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- removeSegments(IntSet) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
- removeSegments(IntSet) - Method in class org.infinispan.container.impl.DefaultDataContainer
- removeSegments(IntSet) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
- removeSegments(IntSet) - Method in interface org.infinispan.container.impl.InternalDataContainer
-
Removes and un-associates the given segments.
- removeSegments(IntSet) - Method in class org.infinispan.container.impl.L1SegmentedDataContainer
- removeSegments(IntSet) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- removeSegments(IntSet) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
- removeSegments(IntSet) - Method in class org.infinispan.persistence.async.AsyncNonBlockingStore
- removeSegments(IntSet) - Method in class org.infinispan.persistence.file.SingleFileStore
- removeSegments(IntSet) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- removeSegments(IntSet) - Method in class org.infinispan.persistence.remote.RemoteStore
- removeSegments(IntSet) - Method in class org.infinispan.persistence.rocksdb.RocksDBStore
- removeSegments(IntSet) - Method in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
- removeSegments(IntSet) - Method in class org.infinispan.persistence.sifs.TemporaryTable
- removeSegments(IntSet) - Method in interface org.infinispan.persistence.spi.NonBlockingStore
-
Invoked when a node loses ownership of the given segments.
- removeSegments(IntSet) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
-
Deprecated.Invoked when a node loses ownership of a segment.
- removeSegments(IntSet) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- removeSegments(IntSet) - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
- removeSegments(IntSet) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- removeSegments(IntSet) - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
- removeShutdownHook() - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- removeShutdownHook() - Method in class org.infinispan.factories.GlobalComponentRegistry
- removeStaleData(IntSet) - Method in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
- removeState(IracManagerKeyInfo) - Method in class org.infinispan.xsite.irac.DefaultIracManager
- removeState(IracManagerKeyInfo) - Method in interface org.infinispan.xsite.irac.IracManager
-
Removes the state associated to a single key.
- removeState(IracManagerKeyInfo) - Method in enum org.infinispan.xsite.irac.NoOpIracManager
- removeStoreListener(PersistenceManager.StoreChangeListener) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- removeTemplate(String) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
- removeTemplate(String) - Method in interface org.infinispan.commons.api.CacheContainerAdmin
-
Removes a template from the cache container.
- removeTemplate(String) - Method in class org.infinispan.manager.DefaultCacheManagerAdmin
- removeTemplate(String) - Method in interface org.infinispan.manager.EmbeddedCacheManagerAdmin
-
Removes a template from the cache container.
- removeTemplate(String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.GlobalConfigurationManager
-
Removes a cluster-wide template
- removeTemplate(String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.GlobalConfigurationManagerImpl
- removeTemplate(String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.ImmutableLocalConfigurationStorage
- removeTemplate(String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.OverlayLocalConfigurationStorage
- removeTemplate(String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
- removeTemplate(String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.LocalConfigurationStorage
-
Removes the specified template.
- removeTemplateSync(String, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
- removeTombstone(Object) - Method in class org.infinispan.container.versioning.irac.DefaultIracTombstoneManager
- removeTombstone(Object) - Method in interface org.infinispan.container.versioning.irac.IracTombstoneManager
-
Removes the tombstone for
key
. - removeTombstone(Object) - Method in class org.infinispan.container.versioning.irac.NoOpIracTombstoneManager
- removeTombstone(IracTombstoneInfo) - Method in class org.infinispan.container.versioning.irac.DefaultIracTombstoneManager
- removeTombstone(IracTombstoneInfo) - Method in interface org.infinispan.container.versioning.irac.IracTombstoneManager
-
Removes the tombstone if it matches.
- removeTombstone(IracTombstoneInfo) - Method in class org.infinispan.container.versioning.irac.NoOpIracTombstoneManager
- removeWithVersion(K, long) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- removeWithVersion(K, long) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
Removes the given entry only if its version matches the supplied version.
- removeWithVersionAsync(K, long) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- removeWithVersionAsync(K, long) - Method in class org.infinispan.client.hotrod.impl.InvalidatedNearRemoteCache
- removeWithVersionAsync(K, long) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- removeWithVersionAsync(K, long) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- removeWithVersionAsync(K, long) - Method in interface org.infinispan.client.hotrod.RemoteCache
- removingServer(SocketAddress) - Method in interface org.infinispan.client.hotrod.logging.Log
- renameTempFile(File, File, File) - Static method in class org.infinispan.commons.util.Util
- renameTo(File) - Method in class org.infinispan.io.GridFile
-
Deprecated.
- render() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMappingKey
- renewRemoteBias(Object, Address) - Method in interface org.infinispan.scattered.BiasManager
-
Notify the component that the node is reading the biased entry and the bias should not be revoked unless necessary.
- renewRemoteBias(Object, Address) - Method in class org.infinispan.scattered.impl.BiasManagerImpl
- REPEATABLE_READ - Enum constant in enum org.infinispan.util.concurrent.IsolationLevel
- RepeatableReadEntry<K,
V> - Class in org.infinispan.container.entries -
An extension of
ReadCommittedEntry
that provides Repeatable Read semantics - RepeatableReadEntry(K, V, Metadata) - Constructor for class org.infinispan.container.entries.RepeatableReadEntry
- repeated - Variable in class org.infinispan.commons.configuration.attributes.ConfigurationElement
- repeatedAttributes() - Method in class org.infinispan.commons.configuration.Combine
- repeatedFieldsNotSupported(String, String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- REPL - Enum constant in enum org.infinispan.configuration.parsing.ParsedCacheMode
- REPL_ASYNC - Enum constant in enum org.infinispan.client.hotrod.DefaultTemplate
- REPL_ASYNC - Enum constant in enum org.infinispan.configuration.cache.CacheMode
-
Data replicated asynchronously.
- REPL_SYNC - Enum constant in enum org.infinispan.client.hotrod.DefaultTemplate
- REPL_SYNC - Enum constant in enum org.infinispan.configuration.cache.CacheMode
-
Data replicated synchronously.
- replace(ByteBuf) - Method in class org.infinispan.rest.ServerSentEvent
- replace(Channel) - Method in class org.infinispan.server.memcached.MemcachedDecoder
- replace(Class<T>, Function<T, T>) - Method in class org.infinispan.functional.impl.MetaParams
- replace(K, MetadataValue<V>, MetadataValue<V>) - Method in interface org.infinispan.client.hotrod.near.NearCache
- replace(K, MetadataValue<V>, MetadataValue<V>) - Method in class org.infinispan.client.hotrod.near.NearCacheService
- replace(K, V) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- replace(K, V) - Method in class org.infinispan.cache.impl.CacheImpl
- replace(K, V) - Method in class org.infinispan.cache.impl.DecoratedCache
- replace(K, V) - Method in class org.infinispan.cache.impl.EncoderCache
- replace(K, V) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- replace(K, V) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- replace(K, V) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
- replace(K, V) - Method in class org.infinispan.security.impl.SecureCacheImpl
- replace(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- replace(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- replace(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
- replace(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- replace(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- replace(K, V, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- replace(K, V, long, TimeUnit) - Method in interface org.infinispan.commons.api.BasicCache
-
An overloaded form of
ConcurrentMap.replace(Object, Object)
, which takes in lifespan parameters. - replace(K, V, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
- replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- replace(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.BasicCache
-
An overloaded form of
ConcurrentMap.replace(Object, Object)
, which takes in lifespan parameters. - replace(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- replace(K, V, Metadata) - Method in interface org.infinispan.AdvancedCache
-
An overloaded form of
#replace(K, V)
, which takes in an instance ofMetadata
which can be used to provide metadata information for the entry being stored, such as lifespan, version of value...etc. - replace(K, V, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- replace(K, V, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
- replace(K, V, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
- replace(K, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
- replace(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- replace(K, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
- replace(K, V, V) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- replace(K, V, V) - Method in class org.infinispan.cache.impl.CacheImpl
- replace(K, V, V) - Method in class org.infinispan.cache.impl.DecoratedCache
- replace(K, V, V) - Method in class org.infinispan.cache.impl.EncoderCache
- replace(K, V, V) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- replace(K, V, V) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- replace(K, V, V) - Method in interface org.infinispan.client.hotrod.RemoteCache
- replace(K, V, V) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
- replace(K, V, V) - Method in class org.infinispan.security.impl.SecureCacheImpl
- replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
- replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- replace(K, V, V, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
An overloaded form of
ConcurrentMap.replace(Object, Object, Object)
, which takes in lifespan parameters. - replace(K, V, V, long, TimeUnit) - Method in interface org.infinispan.commons.api.BasicCache
-
An overloaded form of
ConcurrentMap.replace(Object, Object, Object)
, which takes in lifespan parameters. - replace(K, V, V, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
- replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
An overloaded form of
ConcurrentMap.replace(Object, Object, Object)
, which takes in lifespan parameters. - replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.BasicCache
-
An overloaded form of
ConcurrentMap.replace(Object, Object, Object)
, which takes in lifespan parameters. - replace(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- replace(K, V, V, Metadata) - Method in interface org.infinispan.AdvancedCache
-
An overloaded form of
#replace(K, V, V)
, which takes in an instance ofMetadata
which can be used to provide metadata information for the entry being stored, such as lifespan, version of value...etc. - replace(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- replace(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
- replace(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
- replace(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
- replace(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- replace(K, V, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
- replace(Json, Json) - Method in class org.infinispan.commons.dataconversion.internal.Json
- replace(WrappedBytes, InternalCacheEntry<WrappedBytes, WrappedBytes>) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- replace(WrappedBytes, InternalCacheEntry<WrappedBytes, WrappedBytes>, InternalCacheEntry<WrappedBytes, WrappedBytes>) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- REPLACE - Enum constant in enum org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.StackCombine
- REPLACE - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- REPLACE_IF_UNMODIFIED - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- REPLACE_IF_UNMODIFIED_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- REPLACE_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.EncoderCache
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
- replaceAsync(K, V) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- replaceAsync(K, V) - Method in class org.infinispan.cache.impl.CacheImpl
- replaceAsync(K, V) - Method in class org.infinispan.cache.impl.DecoratedCache
- replaceAsync(K, V) - Method in class org.infinispan.cache.impl.EncoderCache
- replaceAsync(K, V) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- replaceAsync(K, V) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- replaceAsync(K, V) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
ConcurrentMap.replace(Object, Object)
. - replaceAsync(K, V) - Method in class org.infinispan.security.impl.SecureCacheImpl
- replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
- replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- replaceAsync(K, V, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
BasicCache.replace(Object, Object, long, TimeUnit)
. - replaceAsync(K, V, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
- replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.InvalidatedNearRemoteCache
- replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
BasicCache.replace(Object, Object, long, TimeUnit, long, TimeUnit)
. - replaceAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- replaceAsync(K, V, Metadata) - Method in interface org.infinispan.AdvancedCache
-
An overloaded form of
#replaceAsync(K, V)
, which takes in an instance ofMetadata
which can be used to provide metadata information for the entry being stored, such as lifespan, version of value...etc. - replaceAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- replaceAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
- replaceAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
- replaceAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
- replaceAsync(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- replaceAsync(K, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
- replaceAsync(K, V, V) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- replaceAsync(K, V, V) - Method in class org.infinispan.cache.impl.CacheImpl
- replaceAsync(K, V, V) - Method in class org.infinispan.cache.impl.DecoratedCache
- replaceAsync(K, V, V) - Method in class org.infinispan.cache.impl.EncoderCache
- replaceAsync(K, V, V) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- replaceAsync(K, V, V) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- replaceAsync(K, V, V) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
ConcurrentMap.replace(Object, Object, Object)
. - replaceAsync(K, V, V) - Method in class org.infinispan.security.impl.SecureCacheImpl
- replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
- replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- replaceAsync(K, V, V, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
BasicCache.replace(Object, Object, Object, long, TimeUnit)
. - replaceAsync(K, V, V, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.CacheImpl
- replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.DecoratedCache
- replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.EncoderCache
- replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
BasicCache.replace(Object, Object, Object, long, TimeUnit, long, TimeUnit)
. - replaceAsync(K, V, V, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.security.impl.SecureCacheImpl
- replaceAsync(K, V, V, Metadata) - Method in interface org.infinispan.AdvancedCache
- replaceAsync(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- replaceAsync(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
- replaceAsync(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
- replaceAsync(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
- replaceAsync(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- replaceAsync(K, V, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
- replaceAsyncEntry(K, V, Metadata) - Method in interface org.infinispan.AdvancedCache
-
An extension of
AdvancedCache.replaceAsync(K, V, Metadata)
, which returns aCacheEntry
instead of only the value. - replaceAsyncEntry(K, V, Metadata) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- replaceAsyncEntry(K, V, Metadata) - Method in class org.infinispan.cache.impl.CacheImpl
- replaceAsyncEntry(K, V, Metadata) - Method in class org.infinispan.cache.impl.DecoratedCache
- replaceAsyncEntry(K, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
- replaceAsyncEntry(K, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- replaceAsyncEntry(K, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
- replaceAsyncReturnEntry(K, V, Metadata) - Method in interface org.infinispan.AdvancedCache
- replaceAsyncReturnEntry(K, V, Metadata) - Method in class org.infinispan.cache.impl.EncoderCache
- replaceAsyncReturnEntry(K, V, Metadata) - Method in class org.infinispan.security.impl.SecureCacheImpl
- replaceBackupOwners(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
- replaceComponent(String, Object, boolean) - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
-
Replace an existing component.
- replaceComponent(String, Object, boolean) - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
- replaceComponent(String, Object, Object) - Method in interface org.infinispan.extendedstats.logging.Log
- replaceComponents() - Method in interface org.infinispan.extendedstats.logging.Log
- replaceIfUnmodified(Channel) - Method in class org.infinispan.server.memcached.MemcachedDecoder
- ReplaceIfUnmodifiedRequest - Enum constant in enum org.infinispan.server.memcached.MemcachedOperation
- replaceInterceptor(AsyncInterceptor, Class<? extends AsyncInterceptor>) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
-
Replaces an existing interceptor of the given type in the interceptor chain with a new interceptor instance passed as parameter.
- replaceInterceptor(AsyncInterceptor, Class<? extends AsyncInterceptor>) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
- replaceInternal(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- replaceInternal(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.StatsCollectingCache
- replaceOrLock(int, Object, int, int, int, int) - Method in class org.infinispan.persistence.sifs.TemporaryTable
- replacePrimaryOwners(DefaultConsistentHashFactory.Builder, int) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
- replacePrimaryOwners(ScatteredConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory
- replacePrimaryOwnerWithBackup(int, Address) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Builder
- replaceProperties(String) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationReader
- replaceProperties(String) - Static method in class org.infinispan.commons.util.StringPropertyReplacer
-
Go through the input string and replace any occurance of ${p} with the System.getProperty(p) value.
- replaceProperties(String, Properties) - Method in class org.infinispan.commons.configuration.io.PropertyReplacer.Default
- replaceProperties(String, Properties) - Method in interface org.infinispan.commons.configuration.io.PropertyReplacer
- replaceProperties(String, Properties) - Static method in class org.infinispan.commons.util.StringPropertyReplacer
-
Go through the input string and replace any occurance of ${p} with the props.getProperty(p) value.
- replaceProperties(Map<String, String>, Properties) - Static method in class org.infinispan.commons.util.StringPropertyReplacer
- ReplaceRequest - Enum constant in enum org.infinispan.server.memcached.MemcachedOperation
- replaceWithVersion(K, long) - Method in class org.infinispan.client.hotrod.impl.StreamingRemoteCacheImpl
- replaceWithVersion(K, long) - Method in interface org.infinispan.client.hotrod.StreamingRemoteCache
-
A form of
StreamingRemoteCache.put(Object)
, which takes in a version. - replaceWithVersion(K, long, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.StreamingRemoteCacheImpl
- replaceWithVersion(K, long, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.StreamingRemoteCache
-
An overloaded form of
StreamingRemoteCache.replaceWithVersion(Object, long)
which takes in lifespan parameters. - replaceWithVersion(K, long, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.StreamingRemoteCacheImpl
- replaceWithVersion(K, long, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.StreamingRemoteCache
-
An overloaded form of
StreamingRemoteCache.replaceWithVersion(Object, long)
which takes in lifespan and maxIdle parameters. - replaceWithVersion(K, V, long) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- replaceWithVersion(K, V, long) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
Replaces the given value only if its version matches the supplied version.
- replaceWithVersion(K, V, long, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- replaceWithVersion(K, V, long, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
A overloaded form of
RemoteCache.replaceWithVersion(Object, Object, long)
which takes in lifespan parameters. - replaceWithVersion(K, V, long, int, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- replaceWithVersion(K, V, long, int, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
A overloaded form of
RemoteCache.replaceWithVersion(Object, Object, long)
which takes in lifespan and maximum idle time parameters. - replaceWithVersion(K, V, long, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- replaceWithVersion(K, V, long, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
A overloaded form of
RemoteCache.replaceWithVersion(Object, Object, long)
which takes in lifespan and maximum idle time parameters. - replaceWithVersionAsync(K, V, long) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- replaceWithVersionAsync(K, V, long) - Method in interface org.infinispan.client.hotrod.RemoteCache
- replaceWithVersionAsync(K, V, long, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- replaceWithVersionAsync(K, V, long, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
- replaceWithVersionAsync(K, V, long, int, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- replaceWithVersionAsync(K, V, long, int, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
- replaceWithVersionAsync(K, V, long, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- replaceWithVersionAsync(K, V, long, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.InvalidatedNearRemoteCache
- replaceWithVersionAsync(K, V, long, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- replaceWithVersionAsync(K, V, long, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.client.hotrod.RemoteCache
- REPLICABLE_COMMAND - Static variable in interface org.infinispan.commons.marshall.Ids
- ReplicableCommand - Interface in org.infinispan.commands
-
The core of the command-based cache framework.
- ReplicableCommandExternalizer - Class in org.infinispan.marshall.exts
-
ReplicableCommandExternalizer.
- ReplicableCommandExternalizer(RemoteCommandsFactory, GlobalComponentRegistry) - Constructor for class org.infinispan.marshall.exts.ReplicableCommandExternalizer
- ReplicableManagerFunctionCommand - Class in org.infinispan.manager.impl
-
Replicable Command that runs the given Function passing the
EmbeddedCacheManager
as an argument - ReplicableManagerFunctionCommand() - Constructor for class org.infinispan.manager.impl.ReplicableManagerFunctionCommand
- ReplicableManagerFunctionCommand(Function<? super EmbeddedCacheManager, ?>, Subject) - Constructor for class org.infinispan.manager.impl.ReplicableManagerFunctionCommand
- ReplicableRunnableCommand - Class in org.infinispan.manager.impl
-
Replicable Command that runs the given Runnable
- ReplicableRunnableCommand() - Constructor for class org.infinispan.manager.impl.ReplicableRunnableCommand
- ReplicableRunnableCommand(Runnable) - Constructor for class org.infinispan.manager.impl.ReplicableRunnableCommand
- REPLICATED_CACHE - Enum constant in enum org.infinispan.configuration.parsing.Element
- REPLICATED_CACHE_CONFIGURATION - Enum constant in enum org.infinispan.configuration.parsing.Element
- REPLICATED_CONSISTENT_HASH - Static variable in interface org.infinispan.commons.marshall.Ids
- REPLICATED_CONSISTENT_HASH_FACTORY - Static variable in interface org.infinispan.commons.marshall.Ids
- ReplicatedConsistentHash - Class in org.infinispan.distribution.ch.impl
-
Special implementation of
ConsistentHash
for replicated caches. - ReplicatedConsistentHash(List<Address>, int[]) - Constructor for class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
- ReplicatedConsistentHash(List<Address>, Map<Address, Float>, List<Address>, int[]) - Constructor for class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
- ReplicatedConsistentHash.Externalizer - Class in org.infinispan.distribution.ch.impl
- ReplicatedConsistentHashFactory - Class in org.infinispan.distribution.ch.impl
-
Factory for ReplicatedConsistentHash.
- ReplicatedConsistentHashFactory() - Constructor for class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory
- ReplicatedConsistentHashFactory.Externalizer - Class in org.infinispan.distribution.ch.impl
- REPLICATION - Enum constant in enum org.infinispan.configuration.cache.CacheType
- REPLICATION_MODE_ID - Static variable in class org.infinispan.functional.ParamIds
- REPLICATION_QUEUE_EXECUTOR - Enum constant in enum org.infinispan.configuration.parsing.Attribute
-
Deprecated, for removal: This API element is subject to removal in a future version.
- REPLICATION_TIMEOUT - Enum constant in enum org.infinispan.server.hotrod.configuration.Attribute
- REPLICATION_TIMEOUT - Static variable in class org.infinispan.configuration.cache.BackupConfiguration
- replicationTimeout() - Method in class org.infinispan.configuration.cache.BackupConfiguration
- replicationTimeout() - Method in class org.infinispan.server.hotrod.configuration.TopologyCacheConfiguration
- replicationTimeout(long) - 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
- replicationTimeout(long) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
-
Timeout(millis) used for replicating calls to other sites.
- replicationTimeout(long) - Method in class org.infinispan.server.hotrod.configuration.TopologyCacheConfigurationBuilder
- REPLY_FLAGS - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- repository - Variable in class org.infinispan.remoting.transport.AbstractRequest
- Request<T> - Interface in org.infinispan.remoting.transport.impl
-
A remote command invocation request.
- REQUEST_BALANCING_STRATEGY - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- REQUEST_COUNT - Static variable in enum org.infinispan.server.hotrod.HotRodOperation
- REQUEST_FLAGS_PER_SENDER - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- REQUEST_FLAGS_UNORDERED - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- requestBytes - Variable in class org.infinispan.server.hotrod.AccessLoggingHeader
- requestBytes() - Method in class org.infinispan.server.hotrod.HotRodDecoder
- requestEnd(Object) - Method in class org.infinispan.rest.tracing.RestTelemetryService
- requestEnd(Object) - Method in class org.infinispan.server.core.telemetry.impl.OpenTelemetryService
- requestEnd(Object) - Method in class org.infinispan.server.core.telemetry.TelemetryService.NoTelemetry
- requestEnd(Object) - Method in interface org.infinispan.server.core.telemetry.TelemetryService
- requestEnd(Object) - Method in class org.infinispan.server.hotrod.tracing.HotRodTelemetryService
- RequestHeader - Enum in org.infinispan.rest
- requestId - Variable in class org.infinispan.remoting.transport.AbstractRequest
- requestNotAllowedToInternalCaches(String) - Method in interface org.infinispan.rest.logging.Log
- requestNotAllowedToInternalCachesWithoutAuthz(String) - Method in interface org.infinispan.rest.logging.Log
- RequestRepository - Class in org.infinispan.remoting.transport.impl
- RequestRepository() - Constructor for class org.infinispan.remoting.transport.impl.RequestRepository
- requestStart - Variable in class org.infinispan.server.hotrod.AccessLoggingHeader
- requestStart(String, TextMapGetter<T>, T) - Method in class org.infinispan.server.core.telemetry.impl.OpenTelemetryService
- requestStart(String, TextMapGetter<T>, T) - Method in class org.infinispan.server.core.telemetry.TelemetryService.NoTelemetry
- requestStart(String, TextMapGetter<T>, T) - Method in interface org.infinispan.server.core.telemetry.TelemetryService
- requestStart(String, Map<String, byte[]>) - Method in class org.infinispan.server.hotrod.tracing.HotRodTelemetryService
- requestStart(String, RestRequest) - Method in class org.infinispan.rest.tracing.RestTelemetryService
- requestState(Address, IntSet) - Method in class org.infinispan.xsite.irac.DefaultIracManager
- requestState(Address, IntSet) - Method in interface org.infinispan.xsite.irac.IracManager
-
Requests the state stored in this instance for the given
segments
. - requestState(Address, IntSet) - Method in enum org.infinispan.xsite.irac.NoOpIracManager
- RequestTracker - Interface in org.infinispan.remoting.transport.jgroups
-
A tracker for synchronous requests.
- require(int, String, String) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- require(int, String, String) - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
-
Test if the current event is of the given type and if the namespace and name do match.
- require(Map<String, String>) - Method in enum org.infinispan.server.core.admin.AdminOperationParameter
- require(ConfigurationReader.ElementType) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
- require(ConfigurationReader.ElementType, String, Enum<?>) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
- require(ConfigurationReader.ElementType, String, String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
- require(ConfigurationReader.ElementType, String, String) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationReader
- require(ConfigurationReader.ElementType, String, String) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationReader
- require(ConfigurationReader.ElementType, String, String) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader
- REQUIRE_SSL_CLIENT_AUTH - Enum constant in enum org.infinispan.server.hotrod.configuration.Attribute
- requireAttributeProperty(ConfigurationReader, int) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- requireAttributes(ConfigurationReader, boolean, String...) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Require all the named attributes, returning their values in order.
- requireAttributes(ConfigurationReader, Enum<?>...) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- requireAttributes(ConfigurationReader, String...) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- requireClientAuth() - Method in class org.infinispan.server.core.configuration.EncryptionConfiguration
- requireClientAuth() - Method in class org.infinispan.server.core.configuration.SslConfiguration
- requireClientAuth(boolean) - Method in class org.infinispan.server.core.configuration.EncryptionConfigurationBuilder
- requireClientAuth(boolean) - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
-
Enables client certificate authentication
- requireClustered() - Method in interface org.infinispan.lock.logging.Log
- requiredModules() - Element in annotation type org.infinispan.factories.annotations.InfinispanModule
-
The set of required dependencies (module names).
- requiredSchemaFieldNotPresent(String, String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- requiredStatementsForQueryStoreLoader() - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- requiredStatementsForQueryStoreWriter() - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- requireInput(char, char[]) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- requireNextS() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- requireNoAttributes(ConfigurationReader) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Checks that the current element has no attributes, throwing an
ConfigurationReaderException
if one is found. - requireNoContent(ConfigurationReader) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Consumes the remainder of the current element, throwing an
ConfigurationReaderException
if it contains any child elements. - requireNoNamespaceAttribute(ConfigurationReader, int) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- requireNonNullElse(T, T) - Static method in class org.infinispan.commons.util.Util
- requireParameter(Map<String, List<String>>, String) - Method in class org.infinispan.server.core.admin.AdminServerTask
- requireSingleAttribute(ConfigurationReader, Enum<?>) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- requireSingleAttribute(ConfigurationReader, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Require that the current element have only a single attribute with the given name.
- requireValid(String, Log) - Static method in enum org.infinispan.configuration.cache.IndexStartupMode
- requireValid(String, Log) - Static method in enum org.infinispan.configuration.cache.IndexStorage
- ReservoirSampler - Class in org.infinispan.extendedstats.percentiles
-
Keeps the sample for percentile calculations.
- ReservoirSampler() - Constructor for class org.infinispan.extendedstats.percentiles.ReservoirSampler
- ReservoirSampler(int) - Constructor for class org.infinispan.extendedstats.percentiles.ReservoirSampler
- reset() - Method in class org.infinispan.client.hotrod.counter.impl.BaseCounter
- reset() - Method in class org.infinispan.client.hotrod.counter.operation.GetCounterNamesOperation
- reset() - Method in class org.infinispan.commons.configuration.attributes.Attribute
- reset() - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
- reset() - Method in interface org.infinispan.commons.configuration.Builder
- reset() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- reset() - Method in class org.infinispan.commons.stat.DefaultSimpleStat
- reset() - Method in interface org.infinispan.commons.stat.SimpleStat
- reset() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
-
Wipe out all indexing configuration settings and disable indexing.
- reset() - Method in interface org.infinispan.counter.api.StrongCounter
-
Resets the counter to its initial value.
- reset() - Method in interface org.infinispan.counter.api.SyncStrongCounter
- reset() - Method in interface org.infinispan.counter.api.SyncWeakCounter
- reset() - Method in interface org.infinispan.counter.api.WeakCounter
-
Resets the counter to its initial value.
- reset() - Method in class org.infinispan.counter.impl.SyncStrongCounterAdapter
- reset() - Method in class org.infinispan.counter.impl.SyncWeakCounterAdapter
- reset() - Method in class org.infinispan.extendedstats.CacheStatisticCollector
-
reset all the statistics collected so far.
- reset() - Method in class org.infinispan.extendedstats.CacheStatisticManager
-
Resets the cache statistics collected so far.
- reset() - Method in class org.infinispan.extendedstats.container.ConcurrentGlobalContainer
- reset() - Method in class org.infinispan.extendedstats.percentiles.ReservoirSampler
- reset() - Method in interface org.infinispan.stats.ClusterContainerStats
-
Reset the collected statistics
- reset() - Method in class org.infinispan.stats.impl.ClusterContainerStatsImpl
- reset() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
-
Deprecated.
- reset() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
- reset() - Method in class org.infinispan.stats.impl.StatsCollector
- reset() - Method in class org.infinispan.stats.impl.StatsImpl
- reset() - Method in interface org.infinispan.stats.Stats
-
Reset statistics
- reset() - Method in interface org.infinispan.util.ExponentialBackOff
-
Resets its state.
- reset() - Method in class org.infinispan.util.ExponentialBackOffImpl
- reset(AtomicLongFieldUpdater<T>) - Method in class org.infinispan.commons.util.concurrent.StripedCounters
- reset(WrappedBytes) - Method in class org.infinispan.client.hotrod.impl.TopologyInfo
-
Reset a single ache to the initial server list.
- resetAll() - Method in class org.infinispan.extendedstats.topK.StreamSummaryContainer
-
Resets all the top-key collected so far.
- resetCurrentValue() - Method in interface org.infinispan.container.entries.MVCCEntry
-
Reset the current value of the entry to the value before the command was executed the first time.
- resetCurrentValue() - Method in class org.infinispan.container.entries.ReadCommittedEntry
- ResetOperation - Class in org.infinispan.client.hotrod.counter.operation
-
A counter operation for
StrongCounter.reset()
andWeakCounter.reset()
. - ResetOperation(ChannelFactory, AtomicReference<ClientTopology>, Configuration, String, boolean) - Constructor for class org.infinispan.client.hotrod.counter.operation.ResetOperation
- resetRequestReceived() - Method in class org.infinispan.xsite.metrics.DefaultXSiteMetricsCollector
- resetRequestReceived() - Method in class org.infinispan.xsite.metrics.NoOpXSiteMetricsCollector
- resetRequestReceived() - Method in interface org.infinispan.xsite.metrics.XSiteMetricsCollector
- resetRequestsSent() - Method in class org.infinispan.xsite.metrics.DefaultXSiteMetricsCollector
- resetRequestsSent() - Method in class org.infinispan.xsite.metrics.NoOpXSiteMetricsCollector
- resetRequestsSent() - Method in interface org.infinispan.xsite.metrics.XSiteMetricsCollector
- resetSendTime() - Method in interface org.infinispan.remoting.transport.jgroups.RequestTracker
-
Resets the send time to the current time.
- resetState() - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
- resetStatistics() - Method in class org.infinispan.client.hotrod.impl.ClientStatistics
- resetStatistics() - Method in interface org.infinispan.client.hotrod.jmx.RemoteCacheClientStatisticsMXBean
-
Resets statistics.
- resetStatistics() - Method in class org.infinispan.eviction.impl.AbstractPassivationManager
- resetStatistics() - Method in class org.infinispan.eviction.impl.ActivationManagerImpl
- resetStatistics() - Method in interface org.infinispan.eviction.impl.PassivationManager
- resetStatistics() - Method in class org.infinispan.eviction.impl.PassivationManagerImpl
- resetStatistics() - Method in class org.infinispan.eviction.impl.PassivationManagerStub
- resetStatistics() - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
- resetStatistics() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
- resetStatistics() - Method in interface org.infinispan.jmx.JmxStatisticsExposer
-
Resets an interceptor's cache statistics
- resetStatistics() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- resetStatistics() - Method in class org.infinispan.stats.impl.ClusterContainerStatsImpl
- resetStatistics() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
-
Deprecated.
- resetStatistics() - Method in class org.infinispan.stats.impl.StatsCollector
- resetStatistics() - Method in class org.infinispan.util.concurrent.ActionSequencer
- resetStatistics() - Method in class org.infinispan.xsite.irac.DefaultIracManager
-
Resets statistics gathered.
- RESIN_3 - Enum constant in enum org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
- RESIN_ORION_JONAS - Enum constant in enum org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
- resize(int) - Method in interface org.infinispan.container.offheap.OffHeapConcurrentMap.EntryListener
-
Invoked when a resize event occurs.
- resize(long) - Method in interface org.infinispan.container.DataContainer
-
Resizes the capacity of the underlying container.
- resize(long) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- resize(long) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
- resize(long) - Method in class org.infinispan.container.impl.DefaultDataContainer
- resolve(AdvancedCache<?, ?>) - Static method in class org.infinispan.rest.distribution.CacheDistributionInfo
- resolve(AdvancedCache<?, ?>, CacheManagerInfo) - Static method in class org.infinispan.rest.distribution.CacheDistributionInfo
- resolve(CacheManagerInfo, GlobalComponentRegistry) - Static method in class org.infinispan.rest.distribution.NodeDistributionInfo
- resolveArtifact() - Method in interface org.infinispan.commons.maven.Artifact
- resolveArtifact() - Method in class org.infinispan.commons.maven.LocalArtifact
- resolveArtifact() - Method in class org.infinispan.commons.maven.MavenArtifact
- resolveArtifact() - Method in class org.infinispan.commons.maven.URLArtifact
- resolveClass(ObjectStreamClass) - Method in class org.infinispan.commons.marshall.CheckedInputStream
- resolveClass(Unmarshaller, String, long) - Method in class org.infinispan.jboss.marshalling.commons.CheckedClassResolver
- resolveConflicts() - Method in interface org.infinispan.conflict.ConflictManager
-
Utilises
ConflictManager.getConflicts()
to discover conflicts between Key replicas and utilises the configuredEntryMergePolicy
to determine which entry should take precedence. - resolveConflicts(EntryMergePolicy<K, V>) - Method in interface org.infinispan.conflict.ConflictManager
-
Utilises
ConflictManager.getConflicts()
to discover conflicts between Key replicas and utilises the providedEntryMergePolicy
to determine which entry should take precedence. - resolveConflictsOnMerge() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
- resolveConflictsOnMerge() - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
- resolveConflictsOnMerge() - Method in class org.infinispan.topology.ClusterCacheStatus
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.infinispan.spring.common.config.InfinispanContainerCacheManagerBeanDefinitionParser
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.infinispan.spring.common.config.InfinispanEmbeddedCacheManagerBeanDefinitionParser
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.infinispan.spring.common.config.InfinispanRemoteCacheManagerBeanDefinitionParser
- resolvePath(String, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- resolvePointer(String, Json) - Static method in class org.infinispan.commons.dataconversion.internal.Json.help
-
Given a JSON Pointer, as per RFC 6901, return the nested JSON value within the
element
parameter. - resolvePrincipal(Session) - Method in class org.infinispan.spring.common.session.PrincipalNameResolver
-
Resolves Principal Name (e.g.
- resolveResource(String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationResourceResolver
- resolveResource(String) - Method in class org.infinispan.commons.configuration.io.URLConfigurationResourceResolver
- resolveStorage(boolean) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- resolveStorage(boolean) - Method in interface org.infinispan.client.hotrod.impl.InternalRemoteCache
- resolveStorage(boolean) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- resolveStorage(MediaType, MediaType, boolean) - Method in interface org.infinispan.client.hotrod.impl.InternalRemoteCache
- resolveStorage(MediaType, MediaType, boolean) - Method in class org.infinispan.client.hotrod.impl.InvalidatedNearRemoteCache
- resolveStorage(MediaType, MediaType, boolean) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- ResourceDMBean - Class in org.infinispan.jmx
-
This class was copied from JGroups and adapted.
- ResourceHandler - Interface in org.infinispan.rest.framework
-
Handles all the logic related to a REST resource.
- ResourceManager - Interface in org.infinispan.rest.framework
-
Handles registration and lookup of
ResourceHandler
. - ResourceManagerImpl - Class in org.infinispan.rest.framework.impl
- ResourceManagerImpl() - Constructor for class org.infinispan.rest.framework.impl.ResourceManagerImpl
- ResourceNotFoundException - Exception in org.infinispan.rest.operations.exceptions
- ResourceNotFoundException() - Constructor for exception org.infinispan.rest.operations.exceptions.ResourceNotFoundException
- resources - Variable in class org.infinispan.server.core.backup.resources.CounterResource
- Response - Interface in org.infinispan.remoting.responses
-
A response to be sent back to a remote caller
- RESPONSE_TIME - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- responseCollector - Variable in class org.infinispan.remoting.transport.AbstractRequest
- ResponseCollector<T> - Interface in org.infinispan.remoting.transport
-
A representation of a request's responses.
- ResponseCollectors - Class in org.infinispan.remoting.transport
- ResponseCollectors() - Constructor for class org.infinispan.remoting.transport.ResponseCollectors
- ResponseFilter - Interface in org.infinispan.remoting.rpc
-
A mechanism of filtering RPC responses.
- ResponseGenerator - Interface in org.infinispan.remoting.responses
-
A component that generates responses as is expected by different cache setups
- ResponseGeneratorFactory - Class in org.infinispan.factories
-
Creates a ResponseGenerator
- ResponseGeneratorFactory() - Constructor for class org.infinispan.factories.ResponseGeneratorFactory
- ResponseHeader - Enum in org.infinispan.rest
- ResponseMode - Enum in org.infinispan.remoting.rpc
-
Represents different handling mechanisms when dealing with remote command responses.
- ResponseWriter - Enum in org.infinispan.rest
- REST - Static variable in interface org.infinispan.rest.logging.Log
- RestAccessLoggingHandler - Class in org.infinispan.rest.logging
-
Logging filter that can be used to output requests in a similar fashion to HTTPD log output
- RestAccessLoggingHandler() - Constructor for class org.infinispan.rest.logging.RestAccessLoggingHandler
- restart() - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
-
Releases some used resources (e.g.: threads), preserving some others (e.g.: IO) and restarts from the mapping configuration.
- restartComponent(Lifecycle) - Method in class org.infinispan.util.concurrent.SynchronizedRestarter
- restartConflictResolution(List<Address>) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
-
If CR is in progress, then this method cancels the current CR and starts a new CR phase with an updated topology based upon newMembers and the previously queued CR topology
- restartConflictResolution(List<Address>) - Method in class org.infinispan.topology.ClusterCacheStatus
- restartStateTransfer(Collection<Address>) - Method in class org.infinispan.xsite.statetransfer.RemoteSiteStatus
- RestChannelInitializer - Class in org.infinispan.rest
-
Creates Netty Channels for this server.
- RestChannelInitializer(RestServer, NettyTransport) - Constructor for class org.infinispan.rest.RestChannelInitializer
-
Creates new
RestChannelInitializer
. - RestDispatcher - Interface in org.infinispan.rest.framework
-
Routes a particular
RestRequest
to be executed by the correct {link @Invocation}, and produces theRestResponse
. - RestDispatcherImpl - Class in org.infinispan.rest.framework.impl
- RestDispatcherImpl(ResourceManager, Authorizer) - Constructor for class org.infinispan.rest.framework.impl.RestDispatcherImpl
- restore(String, Path) - Method in class org.infinispan.server.core.backup.BackupManagerImpl
- restore(String, Path) - Method in interface org.infinispan.server.core.BackupManager
-
Restore content from the provided backup file.
- restore(String, Path, Map<String, BackupManager.Resources>) - Method in class org.infinispan.server.core.backup.BackupManagerImpl
- restore(String, Path, Map<String, BackupManager.Resources>) - Method in interface org.infinispan.server.core.BackupManager
-
Restore content from the provided backup file.
- restore(ZipFile) - Method in interface org.infinispan.server.core.backup.ContainerResource
-
Restores the
BackupManager.Resources.Type
content from the providedZipFile
to the target container. - restore(ZipFile) - Method in class org.infinispan.server.core.backup.resources.CacheResource
- restore(ZipFile) - Method in class org.infinispan.server.core.backup.resources.CounterResource
- restoreAlreadyExists(String) - Method in interface org.infinispan.server.core.logging.Log
- restoreCacheTopology(ScopedPersistentState) - Method in class org.infinispan.topology.ClusterCacheStatus
- restoreComplete(String) - Method in interface org.infinispan.server.core.logging.Log
- restoreFailed() - Method in interface org.infinispan.rest.logging.Log
- restoreInProgress() - Method in interface org.infinispan.server.core.logging.Log
- RestRequest - Interface in org.infinispan.rest.framework
- RestRequestBuilder<B extends RestRequestBuilder<B>> - Interface in org.infinispan.rest.framework.impl
- RestRequestHandler - Class in org.infinispan.rest
-
Netty handler for REST requests.
- RestResponse - Interface in org.infinispan.rest.framework
- RestResponseBuilder<B extends RestResponseBuilder<B>> - Interface in org.infinispan.rest.framework.impl
- RestResponseException - Exception in org.infinispan.rest
-
An exception representing non-critical HTTP processing errors which will be translated into
RestResponse
and sent back to the client. - RestResponseException(HttpResponseStatus, String) - Constructor for exception org.infinispan.rest.RestResponseException
-
Creates new
RestResponseException
. - RestResponseException(HttpResponseStatus, String, Throwable) - Constructor for exception org.infinispan.rest.RestResponseException
-
Creates a new
RestResponseException
. - RestResponseException(HttpResponseStatus, Throwable) - Constructor for exception org.infinispan.rest.RestResponseException
-
Creates a new
RestResponseException
. - RestResponseException(Throwable) - Constructor for exception org.infinispan.rest.RestResponseException
-
Creates a new
RestResponseException
whose status is 500. - restServer - Variable in class org.infinispan.rest.ALPNHandler
- restServer - Variable in class org.infinispan.rest.RestRequestHandler
- RestServer - Class in org.infinispan.rest
-
REST Protocol Server.
- RestServer() - Constructor for class org.infinispan.rest.RestServer
- RestServerConfiguration - Class in org.infinispan.rest.configuration
- RestServerConfigurationBuilder - Class in org.infinispan.rest.configuration
-
RestServerConfigurationBuilder.
- RestServerConfigurationBuilder() - Constructor for class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- RestTelemetryService - Class in org.infinispan.rest.tracing
- RestTelemetryService(TelemetryService) - Constructor for class org.infinispan.rest.tracing.RestTelemetryService
- resultJoining(K, V) - Method in interface org.infinispan.query.api.continuous.ContinuousQueryListener
-
Receives notification that a cache entry has joined the matching set.
- resultLeaving(K) - Method in interface org.infinispan.query.api.continuous.ContinuousQueryListener
-
Receives notification that a cache entry has left the matching set.
- ResultSetEntryIterator(ResultSet, Predicate<? super K>, boolean) - Constructor for class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations.ResultSetEntryIterator
- resultUpdated(K, V) - Method in interface org.infinispan.query.api.continuous.ContinuousQueryListener
-
Receives notification that a cache entry from the matching set was updated and continues to match the query.
- resume() - Method in class org.infinispan.persistence.sifs.LogAppender
- resume(Transaction) - Method in class org.infinispan.commons.tx.TransactionManagerImpl
- resumeIfNeeded(Transaction) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- resumeIfNeeded(Transaction) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
- resumeIfNeeded(Transaction) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
- resumeOnCPU(CompletionStage<Void>, Object) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
- retain() - Method in class org.infinispan.rest.ServerSentEvent
- retain(int) - Method in class org.infinispan.rest.ServerSentEvent
- retainAll(Collection<?>) - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
- retainAll(Collection<?>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySetBase
- retainAll(Collection<?>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.KeySet
- retainAll(Collection<?>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.Values
- retainAll(Collection<?>) - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
- retainAll(Collection<?>) - Method in class org.infinispan.commons.util.ImmutableIntSet
- retainAll(Collection<?>) - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
- retainAll(Collection<?>) - Method in class org.infinispan.commons.util.ForwardingList
- retainAll(Collection<?>) - Method in class org.infinispan.commons.util.ImmutableHopscotchHashSet
- retainAll(Collection<?>) - Method in class org.infinispan.commons.util.ImmutableListCopy
- retainAll(Collection<?>) - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- retainAll(Collection<?>) - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- retainAll(Collection<?>) - Method in class org.infinispan.InternalCacheSet
- retainAll(Collection<?>) - Method in class org.infinispan.util.CollectionMapper
- retainAll(Collection<?>) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
- retainAll(IntSet) - Method in class org.infinispan.commons.util.ImmutableIntSet
- retainAll(IntSet) - Method in interface org.infinispan.commons.util.IntSet
-
Modifies this set to remove all ints that are not present in the provided IntSet
- retainAll(IntSet) - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- retainAll(IntSet) - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- retainedDuplicate() - Method in class org.infinispan.rest.ServerSentEvent
- rethrowExceptionIfPresent(Throwable) - Static method in class org.infinispan.commons.util.concurrent.CompletableFutures
- RETRIEVALS - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
-
Number of get operations.
- retrieveClusterListenerCallablesToInstall() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- retrieveClusterListenerCallablesToInstall() - Method in interface org.infinispan.notifications.cachelistener.cluster.ClusterCacheNotifier
-
This method is invoked so that this node can send the details required for a new node to be bootstrapped with the existing cluster listeners that are already installed.
- retrievedEntries - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
- retrieveEntries(String, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
- retrieveEntries(String, Object[], Set<Integer>, int) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- retrieveEntries(String, Object[], Set<Integer>, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- retrieveEntries(String, Object[], Set<Integer>, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
Retrieve entries from the server.
- retrieveEntries(String, Set<Integer>, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
- retrieveEntriesByQuery(Query<?>, Set<Integer>, int) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- retrieveEntriesByQuery(Query<?>, Set<Integer>, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- retrieveEntriesByQuery(Query<?>, Set<Integer>, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
Retrieve entries from the server matching a query.
- retrieveEntriesWithMetadata(Set<Integer>, int) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- retrieveEntriesWithMetadata(Set<Integer>, int) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- retrieveEntriesWithMetadata(Set<Integer>, int) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
Retrieve entries with metadata information
- returnReadOnlyFindIsPresent() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- returnReadOnlyFindOrNull() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- returnReadWriteFind() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- returnReadWriteGet() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- returnReadWriteView() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- reuseBuilder() - Static method in class org.infinispan.reactive.publisher.impl.Notifications
- reverseIterator() - Method in interface org.infinispan.commons.util.ReversibleOrderedSet
- ReversibleOrderedSet<E> - Interface in org.infinispan.commons.util
-
A set that allows reverse iteration of the set elements, exposed via the
ReversibleOrderedSet.reverseIterator()
method. - revertCacheToInitialServerList(Collection<String>) - Method in interface org.infinispan.client.hotrod.logging.Log
- revokeLocalBias(Object) - Method in interface org.infinispan.scattered.BiasManager
-
Stop reading local data.
- revokeLocalBias(Object) - Method in class org.infinispan.scattered.impl.BiasManagerImpl
- revokeLocalBiasForSegments(IntSet) - Method in interface org.infinispan.scattered.BiasManager
-
Stop reading local data from this segment.
- revokeLocalBiasForSegments(IntSet) - Method in class org.infinispan.scattered.impl.BiasManagerImpl
- rewire() - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.Rewires components.
- rewire() - Method in class org.infinispan.factories.ComponentRegistry
- rewire() - Method in class org.infinispan.factories.GlobalComponentRegistry
- rewire() - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
-
Rewire all the injections after a component was replaced with
BasicComponentRegistry.replaceComponent(String, Object, boolean)
. - rewire() - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
- rewireNamedRegistries() - Method in class org.infinispan.factories.GlobalComponentRegistry
- rewrap(ExecutionException) - Static method in class org.infinispan.client.hotrod.impl.Util
- rewrap(AdvancedCache) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
-
No generics because some methods return
AdvancedCache<?, ?>
, and returning the proper type would require erasure anyway. - rewrap(AdvancedCache) - Method in class org.infinispan.cache.impl.DecoratedCache
- rewrap(AdvancedCache) - Method in class org.infinispan.cache.impl.EncoderCache
- rewrapAsCacheException(Throwable) - Static method in class org.infinispan.commons.util.Util
- rewrite(String, StaticContentResource) - Method in interface org.infinispan.rest.resources.StaticContentResource.ResourceResolver
-
Resolves a path to a resource name
- RFC1112_RESERVED - Static variable in class org.infinispan.server.hotrod.MultiHomedServerAddress.InetAddressWithNetMask
- RFC1918_CIDR_10 - Static variable in class org.infinispan.server.hotrod.MultiHomedServerAddress.InetAddressWithNetMask
- RFC1918_CIDR_172 - Static variable in class org.infinispan.server.hotrod.MultiHomedServerAddress.InetAddressWithNetMask
- RFC1918_CIDR_192 - Static variable in class org.infinispan.server.hotrod.MultiHomedServerAddress.InetAddressWithNetMask
- RFC3927_LINK_LOCAL - Static variable in class org.infinispan.server.hotrod.MultiHomedServerAddress.InetAddressWithNetMask
- RFC4193_LINK_LOCAL - Static variable in class org.infinispan.server.hotrod.MultiHomedServerAddress.InetAddressWithNetMask
- RFC4193_ULA - Static variable in class org.infinispan.server.hotrod.MultiHomedServerAddress.InetAddressWithNetMask
- RFC6598_SHARED_SPACE - Static variable in class org.infinispan.server.hotrod.MultiHomedServerAddress.InetAddressWithNetMask
- right() - Method in class org.infinispan.commons.util.Either
- right(byte, int) - Static method in class org.infinispan.server.hotrod.BitShift
- RIGHT - Enum constant in enum org.infinispan.commons.util.Either.Type
- RiverCloseListener - Interface in org.infinispan.jboss.marshalling.commons
-
RiverCloseListener is used by Infinispan's extension of River Marshaller and Unmarshaller so that pools can be notified of instances not being in use anymore.
- rnd - Static variable in class org.infinispan.affinity.impl.RndKeyGenerator
- RndKeyGenerator - Class in org.infinispan.affinity.impl
-
Key provider that relies on
Random
's distribution to generate keys. - RndKeyGenerator() - Constructor for class org.infinispan.affinity.impl.RndKeyGenerator
- RO_LOCAL_EXECUTION - Enum constant in enum org.infinispan.extendedstats.percentiles.PercentileStatistic
- RO_REMOTE_EXECUTION - Enum constant in enum org.infinispan.extendedstats.percentiles.PercentileStatistic
- RO_TX_ABORTED_EXECUTION_TIME - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- RO_TX_SUCCESSFUL_EXECUTION_TIME - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- ROCKSDB_EXPIRY_BUCKET - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- ROCKSDB_LOWER_BOUND - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- ROCKSDB_PERSISTED_METADATA - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- ROCKSDB_STORE - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.Element
- RocksDBBlockHoundIntegration - Class in org.infinispan.persistence.rocksdb.internal
- RocksDBBlockHoundIntegration() - Constructor for class org.infinispan.persistence.rocksdb.internal.RocksDBBlockHoundIntegration
- RocksDBExpirationConfiguration - Class in org.infinispan.persistence.rocksdb.configuration
- RocksDBExpirationConfigurationBuilder - Class in org.infinispan.persistence.rocksdb.configuration
-
since 10.0
- RocksDBStore<K,
V> - Class in org.infinispan.persistence.rocksdb - RocksDBStore() - Constructor for class org.infinispan.persistence.rocksdb.RocksDBStore
- RocksDBStoreConfiguration - Class in org.infinispan.persistence.rocksdb.configuration
- RocksDBStoreConfiguration(AttributeSet, AsyncStoreConfiguration, RocksDBExpirationConfiguration) - Constructor for class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfiguration
- RocksDBStoreConfigurationBuilder - Class in org.infinispan.persistence.rocksdb.configuration
- RocksDBStoreConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
- RocksDBStoreConfigurationBuilder(PersistenceConfigurationBuilder, AttributeSet) - Constructor for class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
- RocksDBStoreConfigurationParser - Class in org.infinispan.persistence.rocksdb.configuration
-
RocksDB XML Parser
- RocksDBStoreConfigurationParser() - Constructor for class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationParser
- RocksDBStoreConfigurationSerializer - Class in org.infinispan.persistence.rocksdb.configuration
-
RocksDBStoreConfigurationSerializer.
- RocksDBStoreConfigurationSerializer() - Constructor for class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationSerializer
- rocksDBUnknownPropertiesSupplied(String) - Method in interface org.infinispan.persistence.rocksdb.logging.Log
- role(String) - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
-
Adds a role that can work with this cache.
- role(String) - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
- role(String) - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
- role(String) - Method in interface org.infinispan.configuration.global.GlobalRolesConfigurationChildBuilder
- Role - Interface in org.infinispan.security
-
A role to permission mapping.
- ROLE - Enum constant in enum org.infinispan.configuration.parsing.Element
- ROLE - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- ROLE_SET - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- roleMapper() - Method in class org.infinispan.configuration.global.PrincipalRoleMapperConfiguration
- roleMapperConfiguration() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
- rolePermissionMapper() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
- rolePermissionMapper(RolePermissionMapper) - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
-
The class of a mapper which maps
Role
s toAuthorizationPermission
s - RolePermissionMapper - Interface in org.infinispan.security
-
Maps roles to permissions
- RolePermissionMapperConfiguration - Class in org.infinispan.configuration.global
- RolePermissionMapperConfigurationBuilder - Class in org.infinispan.configuration.global
- rolePermissionMapperNotMutable() - Method in interface org.infinispan.rest.logging.Log
- roles() - Method in class org.infinispan.configuration.cache.AuthorizationConfiguration
- roles() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
- roles(String...) - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
-
Adds roles that can work with this cache.
- ROLES - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- ROLES - Enum constant in enum org.infinispan.configuration.parsing.Element
- ROLES - Static variable in class org.infinispan.configuration.cache.AuthorizationConfiguration
- ROLES - Static variable in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
- RoleSet$___Marshaller_2fda1a742ac008d38f1c852650748615da7cca98a60afaa87bb162ebc6157665 - Class in org.infinispan.security.mappers
-
WARNING: Generated code! Do not edit!
- RoleSet$___Marshaller_2fda1a742ac008d38f1c852650748615da7cca98a60afaa87bb162ebc6157665() - Constructor for class org.infinispan.security.mappers.RoleSet$___Marshaller_2fda1a742ac008d38f1c852650748615da7cca98a60afaa87bb162ebc6157665
- rollback() - Method in class org.infinispan.commons.tx.TransactionImpl
-
Rolls back this transaction.
- rollback() - Method in class org.infinispan.commons.tx.TransactionManagerImpl
- rollback() - Method in class org.infinispan.server.hotrod.tx.PrepareCoordinator
-
Rollbacks the transaction if an exception happens during the transaction execution.
- rollback() - Method in class org.infinispan.transaction.tm.EmbeddedUserTransaction
- rollback(Transaction) - Method in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
- rollback(Transaction) - Method in interface org.infinispan.persistence.spi.NonBlockingStore
-
Roll back the changes from the provided transaction to the underlying store.
- rollback(Transaction) - Method in interface org.infinispan.persistence.spi.TransactionalCacheWriter
-
Deprecated.Rollback the provided transaction's changes to the underlying store.
- rollback(Transaction) - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
- rollback(Transaction) - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
- rollback(Xid) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
-
Same comment as for
TransactionXaAdapter.prepare(javax.transaction.xa.Xid)
applies for commit. - rollback(LocalTransaction) - Method in class org.infinispan.transaction.impl.TransactionCoordinator
- ROLLBACK_EXECUTION_TIME - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- ROLLBACK_TX - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- ROLLBACK_TX - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- rollbackAllTxStores(TxInvocationContext<AbstractCacheTransaction>, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- rollbackAsync(TransactionResourceConverter) - Method in class org.infinispan.commons.tx.TransactionImpl
- rollbackLocalTransaction(AdvancedCache<?, ?>, XidImpl, long) - Static method in class org.infinispan.server.hotrod.tx.operation.Util
- rollbackRemoteTransaction(GlobalTransaction) - Method in class org.infinispan.server.hotrod.tx.PrepareCoordinator
-
Rollbacks a transaction that is remove in all the cluster members.
- RollbackTransactionOperation - Class in org.infinispan.server.hotrod.tx.operation
-
It rollbacks a transaction in all involved caches.
- RollbackTransactionOperation(HotRodHeader, HotRodServer, Subject, XidImpl, BiConsumer<HotRodHeader, Integer>) - Constructor for class org.infinispan.server.hotrod.tx.operation.RollbackTransactionOperation
- ROLLED_BACK - Enum constant in enum org.infinispan.server.hotrod.tx.table.Status
-
The client transaction is rolled back.
- ROLLING_UPGRADE - Enum constant in enum org.infinispan.context.Flag
-
Flag to identity that data is being written as part of a Rolling Upgrade.
- ROLLING_UPGRADE - Static variable in class org.infinispan.context.impl.FlagBitSets
- RollingUpgradeManager - Class in org.infinispan.upgrade
-
RollingUpgradeManager handles the synchronization of data between Infinispan clusters when performing rolling upgrades.
- RollingUpgradeManager() - Constructor for class org.infinispan.upgrade.RollingUpgradeManager
- root - Variable in class org.infinispan.server.core.backup.resources.CounterResource
- root() - Element in annotation type org.infinispan.configuration.parsing.Namespace
-
The root element of this namespace.
- ROOT - Enum constant in enum org.infinispan.configuration.parsing.Element
- roundtripSupported - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- roundUpToNearest8(long) - Static method in class org.infinispan.commons.util.AbstractEntrySizeCalculatorHelper
- routingKey - Variable in class org.infinispan.search.mapper.work.impl.IndexingOperation
- row - Variable in exception org.infinispan.commons.configuration.io.xml.XmlPullParserException
- RpcException - Exception in org.infinispan.remoting
-
Thrown when an RPC problem occurred on the caller.
- RpcException() - Constructor for exception org.infinispan.remoting.RpcException
- RpcException(String) - Constructor for exception org.infinispan.remoting.RpcException
- RpcException(String, Throwable) - Constructor for exception org.infinispan.remoting.RpcException
- RpcException(Throwable) - Constructor for exception org.infinispan.remoting.RpcException
- rpcManager - Variable in class org.infinispan.cache.impl.CacheImpl
- rpcManager - Variable in class org.infinispan.expiration.impl.ClusterExpirationManager
- rpcManager - Variable in class org.infinispan.transaction.impl.TransactionTable
- RpcManager - Interface in org.infinispan.remoting.rpc
-
Provides a mechanism for communicating with other caches in the cluster, by formatting and passing requests down to the registered
Transport
. - RpcManagerFactory - Class in org.infinispan.factories
-
A factory for the RpcManager
- RpcManagerFactory() - Constructor for class org.infinispan.factories.RpcManagerFactory
- RpcManagerImpl - Class in org.infinispan.remoting.rpc
-
This component really is just a wrapper around a
Transport
implementation, and is used to set up the transport and provide lifecycle and dependency hooks into external transport implementations. - RpcManagerImpl() - Constructor for class org.infinispan.remoting.rpc.RpcManagerImpl
- rpcOptions - Variable in class org.infinispan.reactive.publisher.impl.ClusterPublisherManagerImpl
- RpcOptions - Class in org.infinispan.remoting.rpc
-
Classes that wraps all the configuration parameters to configure a remote invocation.
- RpcOptions(DeliverOrder, long, TimeUnit) - Constructor for class org.infinispan.remoting.rpc.RpcOptions
- rules() - Method in class org.infinispan.server.core.configuration.IpFilterConfiguration
- rules(List<IpSubnetFilterRule>) - Method in class org.infinispan.server.core.configuration.IpFilterConfiguration
- ruleType() - Method in class org.infinispan.server.core.transport.IpSubnetFilterRule
- run() - Method in class org.infinispan.client.hotrod.event.impl.ReconnectTask
- run() - Method in class org.infinispan.commons.reactive.AbstractAsyncPublisherHandler
-
This is invoked when the Subscription is cancelled
- run() - Method in interface org.infinispan.query.Indexer
-
Deletes all indexes for the cache and rebuilds them.
- run() - Method in class org.infinispan.reactive.publisher.impl.InnerPublisherSubscription
-
This is invoked when the flowable is completed - need to close any pending publishers
- run() - Method in class org.infinispan.security.actions.AddCacheDependencyAction
- run() - Method in class org.infinispan.security.actions.AddCacheManagerListenerAction
- run() - Method in class org.infinispan.security.actions.AddCacheManagerListenerAsyncAction
- run() - Method in class org.infinispan.security.actions.AddLoggerListenerAsyncAction
- run() - Method in class org.infinispan.security.actions.DefineConfigurationAction
- run() - Method in class org.infinispan.security.actions.GetCacheAction
- run() - Method in class org.infinispan.security.actions.GetCacheAuthorizationManagerAction
- run() - Method in class org.infinispan.security.actions.GetCacheAvailabilityAction
- run() - Method in class org.infinispan.security.actions.GetCacheComponentRegistryAction
- run() - Method in class org.infinispan.security.actions.GetCacheConfigurationAction
- run() - Method in class org.infinispan.security.actions.GetCacheConfigurationFromManagerAction
- run() - Method in class org.infinispan.security.actions.GetCacheDistributionManagerAction
- run() - Method in class org.infinispan.security.actions.GetCacheEntryAction
- run() - Method in class org.infinispan.security.actions.GetCacheEntryAsyncAction
- run() - Method in class org.infinispan.security.actions.GetCacheInterceptorChainAction
- run() - Method in class org.infinispan.security.actions.GetCacheLockManagerAction
- run() - Method in class org.infinispan.security.actions.GetCacheManagerAddress
- run() - Method in class org.infinispan.security.actions.GetCacheManagerClusterAvailabilityAction
- run() - Method in class org.infinispan.security.actions.GetCacheManagerClusterNameAction
- run() - Method in class org.infinispan.security.actions.GetCacheManagerConfigurationAction
- run() - Method in class org.infinispan.security.actions.GetCacheManagerCoordinatorAddress
- run() - Method in class org.infinispan.security.actions.GetCacheManagerHealthAction
- run() - Method in class org.infinispan.security.actions.GetCacheManagerIsCoordinatorAction
- run() - Method in class org.infinispan.security.actions.GetCacheManagerStatusAction
- run() - Method in class org.infinispan.security.actions.GetCacheRpcManagerAction
- run() - Method in class org.infinispan.security.actions.GetCacheStatusAction
- run() - Method in class org.infinispan.security.actions.GetClassInstanceAction
- run() - Method in class org.infinispan.security.actions.GetClusterExecutorAction
- run() - Method in class org.infinispan.security.actions.GetEmbeddedCacheManagerAction
- run() - Method in class org.infinispan.security.actions.GetGlobalComponentRegistryAction
- run() - Method in class org.infinispan.security.actions.GetOrCreateCacheAction
- run() - Method in class org.infinispan.security.actions.GetOrCreateTemplateAction
- run() - Method in class org.infinispan.security.actions.GetPersistenceManagerAction
- run() - Method in class org.infinispan.security.actions.GetSystemPropertyAction
- run() - Method in class org.infinispan.security.actions.GetSystemPropertyAsBooleanAction
- run() - Method in class org.infinispan.security.actions.GetSystemPropertyAsIntegerAction
- run() - Method in class org.infinispan.security.actions.GetUnwrappedCacheAction
- run() - Method in class org.infinispan.security.actions.RemoveListenerAsyncAction
- run() - Method in class org.infinispan.security.actions.SetCacheAvailabilityAction
- run() - Method in class org.infinispan.security.actions.SetThreadContextClassLoaderAction
- run() - Method in class org.infinispan.security.actions.SetThreadNameAction
- run() - Method in class org.infinispan.security.actions.UndefineConfigurationAction
- run() - Method in class org.infinispan.server.hotrod.tx.operation.CommitTransactionOperation
- run() - Method in class org.infinispan.server.hotrod.tx.operation.RollbackTransactionOperation
- run() - Method in class org.infinispan.server.hotrod.tx.table.GlobalTxTable
-
periodically checks for idle transactions and rollbacks them.
- run() - Method in class org.infinispan.xsite.irac.IracClearResponseCollector
- run() - Method in class org.infinispan.xsite.irac.IracExecutor
-
Executes, in a new thread, or queues the task.
- run() - Method in class org.infinispan.xsite.irac.IracResponseCollector
- run(Object...) - Method in interface org.infinispan.query.Indexer
-
Re-indexes values associated with the provided keys only.
- run(SearchMapping, Indexer, Configuration) - Static method in class org.infinispan.query.impl.IndexStartupRunner
- runBlocking(Runnable, Object) - Method in interface org.infinispan.util.concurrent.BlockingManager
-
Replacement for
CompletionStage.runAsync()
that invokes theRunnable
in a blocking thread if the current thread is non-blocking or in the current thread if the current thread is blocking. - runBlocking(Runnable, Object) - Method in class org.infinispan.util.concurrent.BlockingManagerImpl
- runCleanupAndWait() - Method in class org.infinispan.container.versioning.irac.DefaultIracTombstoneManager
- runCommit(boolean) - Method in class org.infinispan.commons.tx.TransactionImpl
-
Runs the second phase of two-phase-commit protocol.
- runCommitAsync(boolean, TransactionResourceConverter) - Method in class org.infinispan.commons.tx.TransactionImpl
- runLocal() - Method in interface org.infinispan.query.Indexer
-
same as
Indexer.run()
but will only re-index data from the local member. - running - Variable in class org.infinispan.transaction.impl.TransactionTable
- running() - Method in interface org.infinispan.factories.impl.ComponentRef
- RUNNING - Enum constant in enum org.infinispan.lifecycle.ComponentStatus
-
The
start()
method has been completed and the component is running. - runPrepare() - Method in class org.infinispan.commons.tx.TransactionImpl
- runPrepareAsync(TransactionResourceConverter) - Method in class org.infinispan.commons.tx.TransactionImpl
- runScript(String) - Method in interface org.infinispan.scripting.ScriptingManager
-
Runs a named script
- runScript(String, TaskContext) - Method in interface org.infinispan.scripting.ScriptingManager
-
Runs a named script using the specified
TaskContext
- runTask(String, TaskContext, BlockingManager) - Method in class org.infinispan.server.core.admin.AdminOperationsHandler
- runtimeIntrospector() - Method in class org.infinispan.search.mapper.search.loading.context.impl.InfinispanLoadingContext
- runtimeIntrospector() - Method in class org.infinispan.search.mapper.session.impl.InfinispanSearchSession
- RxJavaInterop - Class in org.infinispan.commons.reactive
-
Static factory class that provides methods to obtain commonly used instances for interoperation between RxJava and standard JRE.
- RxJavaInterop - Class in org.infinispan.reactive
-
Static factory class that provides methods to obtain commonly used instances for interoperation between RxJava and standard JRE.
- RxJavaInterop() - Constructor for class org.infinispan.commons.reactive.RxJavaInterop
S
- SAFE_HANDSHAKE_PROTOCOL_VERSION - Static variable in enum org.infinispan.client.hotrod.ProtocolVersion
- safeClose(Connection) - Static method in class org.infinispan.persistence.jdbc.common.JdbcUtil
- safeClose(ResultSet) - Static method in class org.infinispan.persistence.jdbc.common.JdbcUtil
- safeClose(Statement) - Static method in class org.infinispan.persistence.jdbc.common.JdbcUtil
- safeEquals(Object, Object) - Static method in class org.infinispan.commons.util.Util
-
Null-safe equality test.
- SAME_MACHINE - Enum constant in enum org.infinispan.manager.ClusterExecutionPolicy
-
The command can be executed only on the same machine from where it was initiated.
- SAME_RACK - Enum constant in enum org.infinispan.manager.ClusterExecutionPolicy
-
The command will be executed on a machine on the same rack.
- SAME_SITE - Enum constant in enum org.infinispan.manager.ClusterExecutionPolicy
-
The command will be executed on a machine on the same site.
- sameXid(XidImpl) - Method in class org.infinispan.server.hotrod.tx.table.CacheXid
- sanitizedCacheName(String) - Static method in class org.infinispan.persistence.PersistenceUtil
-
Replace unwanted characters from cache names so they can be used as filenames
- sasl() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfiguration
- sasl() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
- SASL - Enum constant in enum org.infinispan.server.hotrod.configuration.Element
- SASL_MECHANISM - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- SASL_MECHANISM - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- SASL_PROPERTIES_PREFIX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- SASL_PROPERTIES_PREFIX_REGEX - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- SaslConfiguration - Class in org.infinispan.server.hotrod.configuration
- SaslConfigurationBuilder - Class in org.infinispan.server.hotrod.configuration
- saslMechanism() - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfiguration
- saslMechanism() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
- saslMechanism() - Method in class org.infinispan.persistence.remote.configuration.MechanismConfiguration
- saslMechanism(String) - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
-
Selects the SASL mechanism to use for the connection to the server.
- saslMechanism(String) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
-
Selects the SASL mechanism to use for the connection to the server
- saslMechanism(String) - Method in class org.infinispan.persistence.remote.configuration.MechanismConfigurationBuilder
- saslProperties() - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfiguration
- saslProperties() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
- saslProperties(Map<String, String>) - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
-
Sets the SASL properties.
- saslProperties(Map<String, String>) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
-
Sets the SASL properties
- saslQop(SaslQop...) - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
-
Sets the SASL QOP property.
- SaslQop - Enum in org.infinispan.client.hotrod.configuration
-
SaslQop.
- SaslQopHandler - Class in org.infinispan.server.core.transport
-
Handles QOP of the SASL protocol.
- SaslQopHandler(SaslServer) - Constructor for class org.infinispan.server.core.transport.SaslQopHandler
- saslStrength(SaslStrength...) - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
-
Sets the SASL strength property.
- SaslStrength - Enum in org.infinispan.client.hotrod.configuration
-
SaslStrength.
- SaslUtils - Class in org.infinispan.commons.util
-
Utility methods for handling SASL authentication
- SaslUtils() - Constructor for class org.infinispan.commons.util.SaslUtils
- save(AbstractInfinispanSessionRepository.InfinispanSession) - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository
- saveMode - Variable in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository
- SCATTERED - Enum constant in enum org.infinispan.configuration.cache.CacheType
- SCATTERED_CACHE - Enum constant in enum org.infinispan.configuration.parsing.Element
-
Deprecated, for removal: This API element is subject to removal in a future version.
- SCATTERED_CACHE_CONFIGURATION - Enum constant in enum org.infinispan.configuration.parsing.Element
-
Deprecated, for removal: This API element is subject to removal in a future version.
- SCATTERED_CONSISTENT_HASH - Static variable in interface org.infinispan.commons.marshall.Ids
- SCATTERED_CONSISTENT_HASH_FACTORY - Static variable in interface org.infinispan.commons.marshall.Ids
- SCATTERED_SYNC - Enum constant in enum org.infinispan.client.hotrod.DefaultTemplate
- SCATTERED_SYNC - Enum constant in enum org.infinispan.configuration.cache.CacheMode
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 14.0, will be removed in 16.0. Please use
CacheMode.DIST_SYNC
instead. - ScatteredConsistentHash - Class in org.infinispan.distribution.ch.impl
-
CH used by scattered caches.
- ScatteredConsistentHash(int, List<Address>, Map<Address, Float>, Address[], boolean) - Constructor for class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
- ScatteredConsistentHash.Externalizer - Class in org.infinispan.distribution.ch.impl
- ScatteredConsistentHashFactory - Class in org.infinispan.distribution.ch.impl
-
Based on
DefaultConsistentHashFactory
. - ScatteredConsistentHashFactory() - Constructor for class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory
- ScatteredConsistentHashFactory.Builder - Class in org.infinispan.distribution.ch.impl
- ScatteredConsistentHashFactory.Externalizer - Class in org.infinispan.distribution.ch.impl
- scatteredLostDataCheck(ConsistentHash, List<Address>) - Static method in class org.infinispan.topology.ClusterTopologyManagerImpl
- ScatteredPartitionHandlingManagerImpl - Class in org.infinispan.scattered.impl
- ScatteredPartitionHandlingManagerImpl(Configuration) - Constructor for class org.infinispan.scattered.impl.ScatteredPartitionHandlingManagerImpl
- ScatteredPreloadManager - Class in org.infinispan.scattered.impl
-
Scattered caches always need to preload all entries.
- ScatteredPreloadManager() - Constructor for class org.infinispan.scattered.impl.ScatteredPreloadManager
- ScatteredStateConsumerImpl - Class in org.infinispan.scattered.impl
- ScatteredStateConsumerImpl() - Constructor for class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
- ScatteredStateConsumerImpl.KeyAndVersion - Class in org.infinispan.scattered.impl
- ScatteredStateProvider - Interface in org.infinispan.scattered
- ScatteredStateProviderImpl - Class in org.infinispan.scattered.impl
- ScatteredStateProviderImpl() - Constructor for class org.infinispan.scattered.impl.ScatteredStateProviderImpl
- ScatteredVersionManager<K> - Interface in org.infinispan.scattered
-
Manages versions of entries and states of segments.
- ScatteredVersionManager.SegmentState - Enum in org.infinispan.scattered
- ScatteredVersionManagerImpl<K> - Class in org.infinispan.scattered.impl
- ScatteredVersionManagerImpl() - Constructor for class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
- schedule(Runnable, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
- schedule(Runnable, long, TimeUnit) - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- schedule(Runnable, ScheduledExecutorService, long, TimeUnit) - Static method in class org.infinispan.util.concurrent.CompletionStages
- schedule(Callable<T>, ScheduledExecutorService, long, TimeUnit) - Static method in class org.infinispan.util.concurrent.CompletionStages
- schedule(Callable<V>, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
- schedule(Callable<V>, long, TimeUnit) - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- SCHEDULED_THREAD_POOL - Enum constant in enum org.infinispan.configuration.parsing.Element
- ScheduledExecutorFactory - Interface in org.infinispan.executors
-
Used to configure and create scheduled executors
- ScheduledExecutorFactoryConfiguration - Class in org.infinispan.configuration.global
- ScheduledExecutorFactoryConfigurationBuilder - Class in org.infinispan.configuration.global
-
Configures executor factory.
- ScheduledThreadPoolConfigurationBuilder - Class in org.infinispan.configuration.global
- ScheduledThreadPoolExecutorFactory - Enum in org.infinispan.commons.executors
- scheduledThreadPools() - Method in class org.infinispan.configuration.global.ThreadsConfiguration
- scheduleKeyInvalidation(K, EntryVersion, boolean) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
- scheduleKeyInvalidation(K, EntryVersion, boolean) - Method in interface org.infinispan.scattered.ScatteredVersionManager
-
Notifies the manager that an operation on given key with version previously retrieved from
ScatteredVersionManager.incrementVersion(int)
has finished. - scheduleNonBlocking(Callable<? extends CompletionStage<T>>, ScheduledExecutorService, long, TimeUnit) - Static method in class org.infinispan.util.concurrent.CompletionStages
- scheduler - Variable in class org.infinispan.server.memcached.MemcachedServer
- scheduleRunBlockingAtFixedRate(Runnable, long, long, TimeUnit, Object) - Method in interface org.infinispan.util.concurrent.BlockingManager
- scheduleRunBlockingAtFixedRate(Runnable, long, long, TimeUnit, Object) - Method in class org.infinispan.util.concurrent.BlockingManagerImpl
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- scheduleWithFixedDelay(Supplier<CompletionStage<?>>, long, long, TimeUnit) - Method in interface org.infinispan.util.concurrent.NonBlockingManager
-
Schedules the supplier that is executed after the initialDelay period and subsequently runs delay after the previous stage completes.
- scheduleWithFixedDelay(Supplier<CompletionStage<?>>, long, long, TimeUnit, Predicate<? super Throwable>) - Method in interface org.infinispan.util.concurrent.NonBlockingManager
-
Schedules the supplier that is executed after the initialDelay period and subsequently runs delay after the previous stage completes.
- scheduleWithFixedDelay(Supplier<CompletionStage<?>>, long, long, TimeUnit, Predicate<? super Throwable>) - Method in class org.infinispan.util.concurrent.NonBlockingManagerImpl
- schema() - Method in class org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfiguration
- schema() - Method in class org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfigurationBuilder
- schema(URI) - Static method in class org.infinispan.commons.dataconversion.internal.Json
- schema(URI, Json.Function<URI, Json>) - Static method in class org.infinispan.commons.dataconversion.internal.Json
- schema(Json) - Static method in class org.infinispan.commons.dataconversion.internal.Json
- schema(Json, URI) - Static method in class org.infinispan.commons.dataconversion.internal.Json
- Schema - Class in org.infinispan.configuration.parsing
-
Schema.
- Schema(String, int, int) - Constructor for class org.infinispan.configuration.parsing.Schema
- SCHEMA - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
- SCHEMA_MANAGER_ROLE - Static variable in interface org.infinispan.query.remote.ProtobufMetadataManager
-
Deprecated, for removal: This API element is subject to removal in a future version.since 12.1. Will be removed in 15.0. Use the CREATE permission instead.
- schemaBuilder - Variable in class org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfigurationBuilder
- SchemaJdbcConfiguration - Class in org.infinispan.persistence.sql.configuration
- schemaJdbcConfigurationBuilder() - Method in class org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.use
AbstractSchemaJdbcConfigurationBuilder.schema()
instead - SchemaJdbcConfigurationBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,
S>> - Class in org.infinispan.persistence.sql.configuration - SchemaJdbcConfigurationBuilder(AbstractJdbcStoreConfigurationBuilder<?, S>) - Constructor for class org.infinispan.persistence.sql.configuration.SchemaJdbcConfigurationBuilder
- schemaNotFound(String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- SchemaTableOperations(AbstractSchemaJdbcStore.ProtoSchemaOptions<K, V, C>, AbstractSchemaJdbcStore.Parameter[]) - Constructor for class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.SchemaTableOperations
- scope() - Element in annotation type org.infinispan.configuration.serializing.SerializedWith
- scope(Class<E>) - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
-
Create a
SearchScope
limited to the given type. - scope(Class<E>) - Method in interface org.infinispan.search.mapper.session.SearchSession
-
Create a
SearchScope
limited to the given type. - scope(Class<T>, String) - Method in interface org.infinispan.search.mapper.session.SearchSession
-
Create a
SearchScope
limited to entity types referenced by their name. - scope(Class<T>, Collection<String>) - Method in class org.infinispan.search.mapper.session.impl.InfinispanSearchSession
- scope(Class<T>, Collection<String>) - Method in interface org.infinispan.search.mapper.session.SearchSession
-
Create a
SearchScope
limited to entity types referenced by their name. - scope(Collection<? extends Class<? extends E>>) - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
- scope(Collection<? extends Class<? extends E>>) - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
-
Create a
SearchScope
limited to the given types. - scope(Collection<? extends Class<? extends E>>) - Method in class org.infinispan.search.mapper.session.impl.InfinispanSearchSession
- scope(Collection<? extends Class<? extends E>>) - Method in interface org.infinispan.search.mapper.session.SearchSession
-
Create a
SearchScope
limited to the given types. - Scope - Annotation Type in org.infinispan.factories.scopes
-
Defines the scope of a component in a cache system.
- scopeAll() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
- scopeAll() - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
- SCOPED_STATE - Static variable in interface org.infinispan.commons.marshall.Ids
- SCOPED_STATE_FILTER - Static variable in interface org.infinispan.commons.marshall.Ids
- ScopedPersistentState - Interface in org.infinispan.globalstate
-
ScopedPersistentState represents state which needs to be persisted, scoped by name (e.g.
- ScopedPersistentStateImpl - Class in org.infinispan.globalstate.impl
-
ScopedPersistentStateImpl.
- ScopedPersistentStateImpl(String) - Constructor for class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
- ScopedState - Class in org.infinispan.globalstate
-
Key for scoped entries in the ClusterConfigurationManager state cache
- ScopedState(String, String) - Constructor for class org.infinispan.globalstate.ScopedState
- ScopedState.Externalizer - Class in org.infinispan.globalstate
- ScopeFilter - Class in org.infinispan.globalstate
-
A filter for
ScopedState
that allows listeners of the global state cache to choose events by scope. - ScopeFilter(String) - Constructor for class org.infinispan.globalstate.ScopeFilter
- ScopeFilter.Externalizer - Class in org.infinispan.globalstate
- Scopes - Enum in org.infinispan.factories.impl
-
Copy of
Scopes
to avoid a runtime dependency on the annotations module. - Scopes - Enum in org.infinispan.factories.scopes
-
The different scopes that can be declared for a component.
- SCORE_PROJECTION_KEY - Static variable in class org.infinispan.query.remote.json.JsonQueryResponse
- SCRIPT_CACHE - Static variable in interface org.infinispan.scripting.ScriptingManager
- SCRIPT_MANAGER_ROLE - Static variable in interface org.infinispan.scripting.ScriptingManager
-
Deprecated, for removal: This API element is subject to removal in a future version.since 12.1. Will be removed in 15.0. Use the CREATE permission instead.
- SCRIPT_METADATA - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- scriptCompilationException(Throwable, String) - Method in interface org.infinispan.scripting.logging.Log
- ScriptConversions - Class in org.infinispan.scripting.utils
- ScriptConversions(EncoderRegistry) - Constructor for class org.infinispan.scripting.utils.ScriptConversions
- scriptExecutionError(Throwable) - Method in interface org.infinispan.scripting.logging.Log
- SCRIPTING_LOWER_BOUND - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- ScriptingManager - Interface in org.infinispan.scripting
-
ScriptingManager.
- scriptsCanOnlyAccessNamedCaches() - Method in interface org.infinispan.scripting.logging.Log
- ScrollerIteratorAdaptor<E> - Class in org.infinispan.query.impl
-
Adaptor to use a link
SearchScroll
as an iterator. - ScrollerIteratorAdaptor(SearchScroll<E>) - Constructor for class org.infinispan.query.impl.ScrollerIteratorAdaptor
- search(PojoScopeSessionContext, DocumentReferenceConverter<EntityReference>) - Method in class org.infinispan.search.mapper.scope.impl.SearchScopeImpl
- search(SearchScope<E>) - Method in class org.infinispan.search.mapper.session.impl.InfinispanSearchSession
- search(SearchScope<E>) - Method in interface org.infinispan.search.mapper.session.SearchSession
-
Initiate the building of a search query.
- Search - Class in org.infinispan.client.hotrod
- Search - Class in org.infinispan.query
-
Entry point for performing Infinispan queries.
- SEARCH_STATISTICS - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- SearchAdminResource - Class in org.infinispan.rest.resources
- SearchAdminResource(InvocationHelper) - Constructor for class org.infinispan.rest.resources.SearchAdminResource
- SearchIndexedEntity - Interface in org.infinispan.search.mapper.mapping
-
A descriptor of an indexed entity type, exposing in particular the index manager for this entity.
- SearchIndexer - Interface in org.infinispan.search.mapper.work
- SearchIndexerImpl - Class in org.infinispan.search.mapper.work.impl
- SearchIndexerImpl(PojoIndexer, EntityConverter, InfinispanTypeContextProvider, BlockingManager, NonBlockingManager) - Constructor for class org.infinispan.search.mapper.work.impl.SearchIndexerImpl
- SearchMapping - Interface in org.infinispan.search.mapper.mapping
- SearchMappingBuilder - Class in org.infinispan.search.mapper.mapping
- SearchMappingCommonBuilding - Class in org.infinispan.search.mapper.mapping
-
Stores some fields that could be useful to build a
SearchMappingBuilder
also at a later time. - SearchMappingCommonBuilding(BeanReference<? extends IdentifierBridge<Object>>, Map<String, Object>, ClassLoader, Collection<ProgrammaticSearchMappingProvider>, BlockingManager, NonBlockingManager) - Constructor for class org.infinispan.search.mapper.mapping.SearchMappingCommonBuilding
- searchMappingUnavailable() - Method in interface org.infinispan.query.logging.Log
- SearchScope<E> - Interface in org.infinispan.search.mapper.scope
-
Represents a set of types and the corresponding indexes, allowing to build search-related objects (query, predicate, ...) taking into account the relevant indexes and their metadata (underlying technology, field types, ...).
- SearchScopeImpl<E> - Class in org.infinispan.search.mapper.scope.impl
- SearchScopeImpl(BackendMappingContext, PojoScopeDelegate<EntityReference, E, PojoRawTypeIdentifier<? extends E>>, PojoSelectionEntityLoader<E>) - Constructor for class org.infinispan.search.mapper.scope.impl.SearchScopeImpl
- SearchSession - Interface in org.infinispan.search.mapper.session
- SearchTimeoutException - Exception in org.infinispan.query
-
Thrown when a query timeout occurs.
- SearchTimeoutException() - Constructor for exception org.infinispan.query.SearchTimeoutException
- SearchTimeoutException(String) - Constructor for exception org.infinispan.query.SearchTimeoutException
- SearchWorkspace - Interface in org.infinispan.search.mapper.scope
-
The entry point for explicit index operations.
- SECONDS - Enum constant in enum org.infinispan.server.hotrod.TimeUnitValue
- SecondsInAMonth - Static variable in class org.infinispan.server.memcached.MemcachedDecoder
- SECRET - Static variable in interface org.infinispan.commons.configuration.attributes.AttributeSerializer
- SECRET_SUPPLIER - Static variable in interface org.infinispan.commons.configuration.attributes.AttributeSerializer
- SecureCache<K,
V> - Interface in org.infinispan.security -
SecureCache.
- SecureCacheImpl<K,
V> - Class in org.infinispan.security.impl -
SecureCacheImpl.
- SecureCacheImpl(AdvancedCache<K, V>) - Constructor for class org.infinispan.security.impl.SecureCacheImpl
- SecureTypeIdResolver - Class in org.infinispan.server.core.dataconversion.json
-
Deprecated, for removal: This API element is subject to removal in a future version.JSON to POJO conversion is deprecated and will be removed in a future version.
- SecureTypeResolverBuilder - Class in org.infinispan.server.core.dataconversion.json
-
Deprecated, for removal: This API element is subject to removal in a future version.JSON to POJO conversion is deprecated and will be removed in a future version.
- SecureTypeResolverBuilder(ObjectMapper.DefaultTyping, ClassAllowList) - Constructor for class org.infinispan.server.core.dataconversion.json.SecureTypeResolverBuilder
-
Deprecated.
- security() - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
- security() - Method in class org.infinispan.client.hotrod.configuration.Configuration
- security() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- security() - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
-
Security Configuration
- security() - Method in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
- security() - Method in class org.infinispan.configuration.cache.Configuration
- security() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- security() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- security() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
- security() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
- security() - Method in class org.infinispan.configuration.global.GlobalConfiguration
- security() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- security() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Security-related configuration
- security() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
- Security - Class in org.infinispan.security
-
Security.
- Security() - Constructor for class org.infinispan.security.Security
- SECURITY - Enum constant in enum org.infinispan.configuration.parsing.Element
- SECURITY - Enum constant in enum org.infinispan.persistence.remote.configuration.Element
- SECURITY - Static variable in interface org.infinispan.server.core.logging.Log
- SECURITY_REALM - Enum constant in enum org.infinispan.server.hotrod.configuration.Attribute
- SECURITY_REALM - Static variable in class org.infinispan.rest.configuration.AuthenticationConfiguration
- SecurityActions - Class in org.infinispan.rest.distribution
-
SecurityActions for the org.infinispan.rest.distribution package.
- SecurityActions() - Constructor for class org.infinispan.rest.distribution.SecurityActions
- SecurityAwareExecutorFactory - Interface in org.infinispan.commons.executors
-
Used to configure and create executors which are aware of the current security context
- SecurityAwareScheduledExecutorFactory - Interface in org.infinispan.executors
- securityCacheSize() - Method in class org.infinispan.configuration.global.GlobalSecurityConfiguration
- securityCacheSize(int) - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
- securityCacheSize(int) - Method in interface org.infinispan.configuration.global.GlobalSecurityConfigurationChildBuilder
-
Defines the size for the access role cache.
- securityCacheTimeout() - Method in class org.infinispan.configuration.global.GlobalSecurityConfiguration
- securityCacheTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
- securityCacheTimeout(long, TimeUnit) - Method in interface org.infinispan.configuration.global.GlobalSecurityConfigurationChildBuilder
-
Defines the timeout for which to cache user access roles.
- SecurityConfiguration - Class in org.infinispan.client.hotrod.configuration
-
SecurityConfiguration.
- SecurityConfiguration - Class in org.infinispan.configuration.cache
-
SecurityConfiguration.
- SecurityConfiguration - Class in org.infinispan.persistence.remote.configuration
-
SecurityConfiguration.
- SecurityConfigurationBuilder - Class in org.infinispan.client.hotrod.configuration
-
SecurityConfigurationBuilder.
- SecurityConfigurationBuilder - Class in org.infinispan.configuration.cache
-
SecurityConfigurationBuilder.
- SecurityConfigurationBuilder - Class in org.infinispan.persistence.remote.configuration
-
SecurityConfigurationBuilder.
- SecurityConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.SecurityConfigurationBuilder
- SecurityConfigurationChildBuilder - Interface in org.infinispan.configuration.cache
- SecurityDomain - Interface in org.infinispan.rest.authentication
-
Pluggable security domain which could be used as a bridge between
Authenticator
and WildFly Security Realms. - securityOverviewReport() - Method in interface org.infinispan.server.core.ServerManagement
- securityRealm() - Method in class org.infinispan.rest.configuration.AuthenticationConfiguration
- securityRealm() - Method in class org.infinispan.rest.configuration.AuthenticationConfigurationBuilder
- securityRealm() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
- securityRealm(String) - Method in class org.infinispan.rest.configuration.AuthenticationConfigurationBuilder
- securityRealm(String) - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
- SecurityResource - Class in org.infinispan.rest.resources
- SecurityResource(InvocationHelper, String, String) - Constructor for class org.infinispan.rest.resources.SecurityResource
- seenAmpersand - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- seenDocdecl - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- seenEndTag - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- seenMarkup - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- seenRoot - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- seenStartTag - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- SEGMENT_0 - Static variable in class org.infinispan.stats.impl.StatsCollector
- SEGMENT_CLUSTERED_QUERY - Static variable in interface org.infinispan.query.impl.ModuleCommandIds
- SEGMENT_COLUMN - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
- SEGMENT_COLUMN_NAME - Static variable in class org.infinispan.persistence.jdbc.configuration.SegmentColumnConfiguration
- SEGMENT_COLUMN_TYPE - Static variable in class org.infinispan.persistence.jdbc.configuration.SegmentColumnConfiguration
- SEGMENTABLE - Enum constant in enum org.infinispan.persistence.spi.NonBlockingStore.Characteristic
-
If this store supports segmentation.
- segmentationNotSupportedInThisVersion(ProtocolVersion) - Method in interface org.infinispan.persistence.remote.logging.Log
- segmentationNotSupportedWithGroups() - Method in interface org.infinispan.persistence.remote.logging.Log
- segmentationRequiresEqualMediaTypes(MediaType, MediaType) - Method in interface org.infinispan.persistence.remote.logging.Log
- segmentationRequiresEqualSegments(int, Integer) - Method in interface org.infinispan.persistence.remote.logging.Log
- segmentAwareEntrySet - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
- SegmentAwareKey<K> - Class in org.infinispan.commons.util
-
Encapsulates the key and its segment.
- SegmentAwareKey(K, int) - Constructor for class org.infinispan.commons.util.SegmentAwareKey
- segmentAwareKeySet - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
- SegmentAwareOperation - Interface in org.infinispan.stream.impl
-
Terminal stream operation that is aware of segments being lost.
- SegmentAwarePublisherSupplier<R> - Interface in org.infinispan.reactive.publisher.impl
-
This is the same as
SegmentPublisherSupplier
except that it also allows listening for when a segment is lost. - SegmentAwarePublisherSupplier.NotificationWithLost<R> - Interface in org.infinispan.reactive.publisher.impl
-
Notification that can also contains lost segments.
- segmentColumnConfiguration() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- SegmentColumnConfiguration - Class in org.infinispan.persistence.jdbc.configuration
- SegmentColumnConfiguration(AttributeSet) - Constructor for class org.infinispan.persistence.jdbc.configuration.SegmentColumnConfiguration
- SegmentColumnConfigurationBuilder - Class in org.infinispan.persistence.jdbc.configuration
- segmentColumnName() - Method in class org.infinispan.persistence.jdbc.configuration.SegmentColumnConfiguration
- segmentColumnName() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- segmentColumnName(String) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
-
The name of the database column used to store the segments
- segmentColumnType() - Method in class org.infinispan.persistence.jdbc.configuration.SegmentColumnConfiguration
- segmentColumnType() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- segmentColumnType(String) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
-
The type of the database column used to store the segments
- segmentComplete(int) - Method in interface org.infinispan.reactive.publisher.impl.Notifications.NotificationBuilder
- segmentComplete(int) - Static method in class org.infinispan.reactive.publisher.impl.Notifications
- segmentCompleted(Set<Integer>) - Method in interface org.infinispan.BaseCacheStream.SegmentCompletionListener
-
Deprecated, for removal: This API element is subject to removal in a future version.This method requires boxing for each segment. Please use
BaseCacheStream.SegmentCompletionListener.accept(Supplier)
instead - segmentCompletionListener - Variable in class org.infinispan.stream.impl.AbstractCacheStream
- segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in interface org.infinispan.BaseCacheStream
-
Allows registration of a segment completion listener that is notified when a segment has completed processing.
- segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in interface org.infinispan.CacheStream
-
Allows registration of a segment completion listener that is notified when a segment has completed processing.
- segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in interface org.infinispan.DoubleCacheStream
-
Allows registration of a segment completion listener that is notified when a segment has completed processing.
- segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in interface org.infinispan.IntCacheStream
-
Allows registration of a segment completion listener that is notified when a segment has completed processing.
- segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in interface org.infinispan.LockedStream
-
This method is not supported when using a
LockedStream
- segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in interface org.infinispan.LongCacheStream
-
Allows registration of a segment completion listener that is notified when a segment has completed processing.
- segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.stream.impl.DistributedCacheStream
- segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.stream.impl.LockedStreamImpl
- segmentCompletionListener(BaseCacheStream.SegmentCompletionListener) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- segmented() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- segmented() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
-
Whether or not this store is configured to be segmented.
- segmented(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
- segmented(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
- segmented(boolean) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
-
If true this store should either be non shared (segmenting can be done automatically for non shared stores) or the shared store must implement the
SegmentedAdvancedLoadWriteStore
interface. - SEGMENTED - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- SEGMENTED - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- SegmentedAdvancedLoadWriteStore<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
- SegmentedBoundedOffHeapDataContainer - Class in org.infinispan.container.offheap
- SegmentedBoundedOffHeapDataContainer(int, long, EvictionType) - Constructor for class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
- segmentedStore() - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
- segmentId() - Method in class org.infinispan.distribution.DistributionInfo
- segmentLost(int) - Method in interface org.infinispan.reactive.publisher.impl.Notifications.NotificationBuilder
- segmentLost(int) - Static method in class org.infinispan.reactive.publisher.impl.Notifications
- SegmentPublisherSupplier<R> - Interface in org.infinispan.reactive.publisher.impl
-
A
Publisher
that also notifies in a thread safe manner when a segment has sent all values upstream. - SegmentPublisherSupplier.Notification<R> - Interface in org.infinispan.reactive.publisher.impl
-
Wrapper around an element returned that can either be a value or a segment completion.
- SegmentPublisherWrapper<Type> - Class in org.infinispan.persistence.support
- segmentRemoved(Map<K, InternalCacheEntry<K, V>>) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
- SegmentResult(int, int) - Constructor for class org.infinispan.reactive.publisher.impl.PublisherHandler.SegmentResult
- SEGMENTS - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- segmentsLost(IntSet) - Method in interface org.infinispan.reactive.publisher.impl.LocalPublisherManager
-
Method to invoke when a set of segments are being removed from this node.
- segmentsLost(IntSet) - Method in class org.infinispan.reactive.publisher.impl.LocalPublisherManagerImpl
- SegmentSpecificCommand - Interface in org.infinispan.commands
-
Interface to be implemented when the command can define a single segment for its operation.
- segmentsToBytes() - Method in class org.infinispan.server.hotrod.iteration.IterableIterationResult
- segmentsToFilter - Variable in class org.infinispan.stream.impl.AbstractCacheStream
- select() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfiguration
- select(String) - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfigurationBuilder
-
Configures the select statement to be used when reading entries from the database.
- select(String...) - Method in interface org.infinispan.query.dsl.QueryBuilder
-
Deprecated.
- select(Expression...) - Method in interface org.infinispan.query.dsl.QueryBuilder
-
Deprecated.
- SELECT - Static variable in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfiguration
- SELECT_ALL - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
- SELECT_ALL - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
- SELECT_ALL - Static variable in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfiguration
- SELECT_SINGLE - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
- SELECT_SINGLE - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
- selectAll() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfiguration
- selectAll(String) - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfigurationBuilder
-
Configures the select all statement to be used when reading all entries from the database.
- selectAllCannotHaveParameters(String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- self() - Method in interface org.infinispan.commons.configuration.Self
- self() - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
-
Deprecated.
- self() - Method in class org.infinispan.configuration.cache.CustomStoreConfigurationBuilder
- self() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
- self() - Method in class org.infinispan.counter.configuration.StrongCounterConfigurationBuilder
- self() - Method in class org.infinispan.counter.configuration.WeakCounterConfigurationBuilder
- self() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
- self() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder.StringTableManipulationConfigurationBuilder
- self() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- self() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
- self() - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
- self() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfigurationBuilder
- self() - Method in class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfigurationBuilder
- self() - Method in class org.infinispan.rest.configuration.AuthenticationConfigurationBuilder
- self() - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- self() - Method in class org.infinispan.server.core.configuration.IpFilterConfigurationBuilder
- self() - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
- self() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
- self() - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
- Self<S extends Self<S>> - Interface in org.infinispan.commons.configuration
-
This interface simplifies the task of writing fluent builders which need to inherit from other builders (abstract or concrete).
- SemaphoreCompletionService<T> - Class in org.infinispan.executors
-
Executes tasks in the given executor, but never has more than
maxConcurrentTasks
tasks running at the same time. - SemaphoreCompletionService(Executor, int) - Constructor for class org.infinispan.executors.SemaphoreCompletionService
- SEND_BUF_SIZE - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- SEND_CANCELED - Enum constant in enum org.infinispan.xsite.statetransfer.StateTransferStatus
- SEND_FAILED - Enum constant in enum org.infinispan.xsite.statetransfer.StateTransferStatus
- SEND_OK - Enum constant in enum org.infinispan.xsite.statetransfer.StateTransferStatus
- sendBufSize() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- sendBufSize(int) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- sendBufSize(int) - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
- sendBufSize(int) - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- sendBufSize(int) - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
-
Sets the size of the send buffer
- sendCancel(Target) - Method in class org.infinispan.commons.reactive.AbstractAsyncPublisherHandler
- sendEvent(ServerSentEvent) - Method in class org.infinispan.rest.EventStream
- sendEvents(Object) - Method in interface org.infinispan.notifications.cachelistener.cluster.ClusterEventManager
-
Sends all previously added events for the given identifier
- sendEvents(Object) - Method in class org.infinispan.notifications.cachelistener.cluster.impl.BatchingClusterEventManagerImpl
- sendEvents(Object) - Method in class org.infinispan.notifications.cachelistener.cluster.impl.ClusterEventManagerStub
- SENDING - Enum constant in enum org.infinispan.xsite.statetransfer.StateTransferStatus
- sendInitialCommand(Target, int) - Method in class org.infinispan.commons.reactive.AbstractAsyncPublisherHandler
- sendNextCommand(Target, int) - Method in class org.infinispan.commons.reactive.AbstractAsyncPublisherHandler
- sendStateTo(Address, IntSet) - Method in class org.infinispan.container.versioning.irac.DefaultIracTombstoneManager
- sendStateTo(Address, IntSet) - Method in interface org.infinispan.container.versioning.irac.IracTombstoneManager
-
Sends the tombstone belonging to the segments in
segment
to theoriginator
- sendStateTo(Address, IntSet) - Method in class org.infinispan.container.versioning.irac.NoOpIracTombstoneManager
- sendTo(Address, ReplicableCommand, DeliverOrder) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticRpcManager
- sendTo(Address, ReplicableCommand, DeliverOrder) - Method in interface org.infinispan.remoting.rpc.RpcManager
-
Asynchronously sends the
ReplicableCommand
to the destination using the specifiedDeliverOrder
. - sendTo(Address, ReplicableCommand, DeliverOrder) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- sendTo(Address, ReplicableCommand, DeliverOrder) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- sendTo(Address, ReplicableCommand, DeliverOrder) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- sendTo(Address, ReplicableCommand, DeliverOrder) - Method in interface org.infinispan.remoting.transport.Transport
-
Asynchronously sends the
ReplicableCommand
to the destination using the specifiedDeliverOrder
. - sendToAll(ReplicableCommand, DeliverOrder) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticRpcManager
- sendToAll(ReplicableCommand, DeliverOrder) - Method in interface org.infinispan.remoting.rpc.RpcManager
-
Asynchronously sends the
ReplicableCommand
to the entire cluster. - sendToAll(ReplicableCommand, DeliverOrder) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- sendToAll(ReplicableCommand, DeliverOrder) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- sendToAll(ReplicableCommand, DeliverOrder) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- sendToAll(ReplicableCommand, DeliverOrder) - Method in interface org.infinispan.remoting.transport.Transport
-
Asynchronously sends the
ReplicableCommand
to the entire cluster. - sendToMany(Collection<Address>, ReplicableCommand, DeliverOrder) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticRpcManager
- sendToMany(Collection<Address>, ReplicableCommand, DeliverOrder) - Method in interface org.infinispan.remoting.rpc.RpcManager
-
Asynchronously sends the
ReplicableCommand
to the set of destination using the specifiedDeliverOrder
. - sendToMany(Collection<Address>, ReplicableCommand, DeliverOrder) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- sendToMany(Collection<Address>, ReplicableCommand, DeliverOrder) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- sendToMany(Collection<Address>, ReplicableCommand, DeliverOrder) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- sendToMany(Collection<Address>, ReplicableCommand, DeliverOrder) - Method in interface org.infinispan.remoting.transport.Transport
-
Asynchronously sends the
ReplicableCommand
to the set of destination using the specifiedDeliverOrder
. - sendToTargets() - Method in class org.infinispan.notifications.cachelistener.cluster.impl.BatchingClusterEventManagerImpl.UnicastEventContext
- seqId() - Method in class org.infinispan.persistence.sifs.EntryHeader
- sequence(List<CompletableFuture<T>>) - Static method in class org.infinispan.commons.util.concurrent.CompletableFutures
- sequential() - Method in interface org.infinispan.CacheStream
- sequential() - Method in interface org.infinispan.DoubleCacheStream
- sequential() - Method in interface org.infinispan.IntCacheStream
- sequential() - Method in interface org.infinispan.LongCacheStream
- sequential() - Method in class org.infinispan.stream.impl.AbstractCacheStream
- sequential() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- sequential() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- sequential() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- sequential() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- sequential() - Method in class org.infinispan.stream.impl.LockedStreamImpl
- sequential() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- sequentialDistribution() - Method in interface org.infinispan.BaseCacheStream
-
This would disable sending requests to all other remote nodes compared to one at a time.
- sequentialDistribution() - Method in interface org.infinispan.CacheStream
-
This would disable sending requests to all other remote nodes compared to one at a time.
- sequentialDistribution() - Method in interface org.infinispan.DoubleCacheStream
-
This would disable sending requests to all other remote nodes compared to one at a time.
- sequentialDistribution() - Method in interface org.infinispan.IntCacheStream
-
This would disable sending requests to all other remote nodes compared to one at a time.
- sequentialDistribution() - Method in interface org.infinispan.LockedStream
-
This would disable sending requests to all other remote nodes compared to one at a time.
- sequentialDistribution() - Method in interface org.infinispan.LongCacheStream
-
This would disable sending requests to all other remote nodes compared to one at a time.
- sequentialDistribution() - Method in class org.infinispan.stream.impl.DistributedCacheStream
- sequentialDistribution() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- sequentialDistribution() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- sequentialDistribution() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- sequentialDistribution() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- sequentialDistribution() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- sequentialDistribution() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- sequentialDistribution() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- sequentialDistribution() - Method in class org.infinispan.stream.impl.LockedStreamImpl
- sequentialDistribution() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- sequentialInterceptorClass() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
- serialAllowList() - Method in class org.infinispan.client.hotrod.configuration.Configuration
- SERIALIZABLE - Enum constant in enum org.infinispan.util.concurrent.IsolationLevel
- SerializableBiConsumer<T,
U> - Interface in org.infinispan.util.function -
This is a functional interface that is the same as a
BiConsumer
except that it must also beSerializable
- SerializableBiFunction<T,
U, R> - Interface in org.infinispan.util.function -
This is a functional interface that is the same as a
BiFunction
except that it must also beSerializable
- SerializableBinaryOperator<T> - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
BinaryOperator
except that it must also beSerializable
- SerializableCallable<V> - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
Callable
except that it must also beSerializable
- serializableCollector(SerializableSupplier<Collector<T, ?, R>>) - Static method in class org.infinispan.stream.CacheCollectors
-
Creates a collector that is serializable and will upon usage create a collector using the serializable supplier provided by the user.
- SerializableComparator<T> - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
Comparator
except that it must also beSerializable
- SerializableConsumer<T> - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
Consumer
except that it must also beSerializable
- SerializableDoubleBinaryOperator - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
DoubleBinaryOperator
except that it must also beSerializable
- SerializableDoubleConsumer - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
DoubleConsumer
except that it must also beSerializable
- SerializableDoubleFunction<R> - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
DoubleFunction
except that it must also beSerializable
- SerializableDoublePredicate - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
DoublePredicate
except that it must also beSerializable
- SerializableDoubleToIntFunction - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
DoubleToIntFunction
except that it must also beSerializable
- SerializableDoubleToLongFunction - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
DoubleToLongFunction
except that it must also beSerializable
- SerializableDoubleUnaryOperator - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
DoubleUnaryOperator
except that it must also beSerializable
- SerializableFunction<T,
R> - Interface in org.infinispan.util.function -
This is a functional interface that is the same as a
Function
except that it must also beSerializable
- SerializableIntBinaryOperator - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
IntBinaryOperator
except that it must also beSerializable
- SerializableIntConsumer - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
IntConsumer
except that it must also beSerializable
- SerializableIntFunction<R> - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
IntFunction
except that it must also beSerializable
- SerializableIntPredicate - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
IntPredicate
except that it must also beSerializable
- SerializableIntToDoubleFunction - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
IntToDoubleFunction
except that it must also beSerializable
- SerializableIntToLongFunction - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
IntToLongFunction
except that it must also beSerializable
- SerializableIntUnaryOperator - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
IntUnaryOperator
except that it must also beSerializable
- SerializableLongBinaryOperator - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
LongBinaryOperator
except that it must also beSerializable
- SerializableLongConsumer - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
LongConsumer
except that it must also beSerializable
- SerializableLongFunction<R> - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
LongFunction
except that it must also beSerializable
- SerializableLongPredicate - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
LongPredicate
except that it must also beSerializable
- SerializableLongToDoubleFunction - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
LongToDoubleFunction
except that it must also beSerializable
- SerializableLongToIntFunction - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
LongToIntFunction
except that it must also beSerializable
- SerializableLongUnaryOperator - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
LongUnaryOperator
except that it must also beSerializable
- SerializableObjDoubleConsumer<T> - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
ObjDoubleConsumer
except that it must also beSerializable
- SerializableObjIntConsumer<T> - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
ObjIntConsumer
except that it must also beSerializable
- SerializableObjLongConsumer<T> - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
ObjLongConsumer
except that it must also beSerializable
- SerializablePredicate<T> - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
Predicate
except that it must also beSerializable
- SerializableRunnable - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
Runnable
except that it must also beSerializable
- SerializableSupplier<T> - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
Supplier
except that it must also beSerializable
- SerializableToDoubleFunction<T> - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
ToDoubleFunction
except that it must also beSerializable
- SerializableToIntFunction<T> - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
ToIntFunction
except that it must also beSerializable
- SerializableToLongFunction<T> - Interface in org.infinispan.util.function
-
This is a functional interface that is the same as a
ToLongFunction
except that it must also beSerializable
- serialization() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
- serialization() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
- serialization() - Method in class org.infinispan.configuration.global.GlobalConfiguration
- serialization() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- serialization() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Global serialization (i.e.
- SERIALIZATION - Enum constant in enum org.infinispan.configuration.parsing.Element
- SERIALIZATION_CONTEXT_INITIALIZER - Enum constant in enum org.infinispan.configuration.parsing.Element
- SERIALIZATION_CONTEXT_INITIALIZERS - Enum constant in enum org.infinispan.configuration.parsing.Element
- SERIALIZATION_CONTEXT_INITIALIZERS - Static variable in class org.infinispan.configuration.global.SerializationConfiguration
- SerializationConfiguration - Class in org.infinispan.configuration.global
- SerializationConfigurationBuilder - Class in org.infinispan.configuration.global
-
Configures serialization and marshalling settings.
- serializationContext - Variable in class org.infinispan.commons.marshall.ImmutableProtoStreamMarshaller
- SerializationUtils - Class in org.infinispan.persistence.remote.upgrade
-
Utilities to parse and serialize
RemoteStoreConfiguration
to and from JSON. - serialize(OutputStream, String, Configuration) - Method in class org.infinispan.configuration.parsing.ParserRegistry
-
Deprecated, for removal: This API element is subject to removal in a future version.
- serialize(OutputStream, GlobalConfiguration, Map<String, Configuration>) - Method in class org.infinispan.configuration.parsing.ParserRegistry
-
Deprecated, for removal: This API element is subject to removal in a future version.
- serialize(String, Configuration) - Method in class org.infinispan.configuration.parsing.ParserRegistry
-
Deprecated, for removal: This API element is subject to removal in a future version.
- serialize(ConfigurationWriter, String, Map<?, ?>) - Method in class org.infinispan.commons.configuration.attributes.PropertiesAttributeSerializer
- serialize(ConfigurationWriter, String, Configuration) - Method in class org.infinispan.configuration.parsing.ParserRegistry
-
Serializes a single cache configuration
- serialize(ConfigurationWriter, String, T) - Method in interface org.infinispan.commons.configuration.attributes.AttributeSerializer
- serialize(ConfigurationWriter, GlobalConfiguration, Map<String, Configuration>) - Method in class org.infinispan.configuration.parsing.ParserRegistry
-
Serializes a full configuration to an
ConfigurationWriter
- serialize(ConfigurationWriter, ConfigurationHolder) - Method in class org.infinispan.configuration.serializing.CoreConfigurationSerializer
- serialize(ConfigurationWriter, CounterManagerConfiguration) - Method in class org.infinispan.counter.configuration.CounterConfigurationSerializer
- serialize(ConfigurationWriter, MicrometerMeterRegistryConfiguration) - Method in class org.infinispan.metrics.config.MicrometerMeterRegistryConfigurationSerializer
- serialize(ConfigurationWriter, JdbcStringBasedStoreConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationSerializer
- serialize(ConfigurationWriter, RemoteStoreConfiguration) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationSerializer
- serialize(ConfigurationWriter, RocksDBStoreConfiguration) - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationSerializer
- serialize(ConfigurationWriter, QueriesJdbcStoreConfiguration) - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfigurationSerializer
- serialize(ConfigurationWriter, TableJdbcStoreConfiguration) - Method in class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfigurationSerializer
- serialize(ConfigurationWriter, T) - Method in interface org.infinispan.configuration.serializing.ConfigurationSerializer
- serializeConfiguration(ConfigurationWriter) - Method in interface org.infinispan.server.core.ServerManagement
- serializeConfiguration(ConfigurationWriter, AbstractCounterConfiguration) - Method in class org.infinispan.counter.configuration.CounterConfigurationSerializer
-
Serializes a single counter configuration
- serializeConfigurations(OutputStream, Collection<AbstractCounterConfiguration>) - Method in class org.infinispan.counter.configuration.CounterConfigurationSerializer
- SerializedWith - Annotation Type in org.infinispan.configuration.serializing
-
SerializedWith, specifies the
ConfigurationSerializer
to use to serialize the annotated class - SerializeFunctionWith - Annotation Type in org.infinispan.commons.marshall
-
Indicate that this function should be serialized with an instance of the given
Externalizer
class. - serializer() - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
- serializer(AttributeSerializer<? super T>) - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition.Builder
- SerializeUtils - Class in org.infinispan.configuration.serializing
- serializeWith(ConfigurationWriter, ConfigurationSerializer<T>, T) - Method in class org.infinispan.configuration.parsing.ParserRegistry
- SerializeWith - Annotation Type 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 customMarshaller
implementation via the SerializationConfiguration. - SerializeWithExtFactory - Class in org.infinispan.jboss.marshalling.commons
-
JBoss Marshalling plugin class for
ClassExternalizerFactory
that allows for Infinispan annotations to be used instead of JBoss Marshalling ones in order to discover which classes are serializable with Infinispan externalizers. - SerializeWithExtFactory() - Constructor for class org.infinispan.jboss.marshalling.commons.SerializeWithExtFactory
- serialWhitelist() - 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.serialAllowList()
instead. To be removed in 14.0. - server - Variable in class org.infinispan.server.core.AbstractProtocolServer
- server - Variable in class org.infinispan.server.core.transport.NettyChannelInitializer
- server - Variable in class org.infinispan.server.hotrod.HotRodDecoder
- server - Variable in class org.infinispan.server.hotrod.BaseRequestProcessor
- server() - Method in class org.infinispan.client.hotrod.DataFormat
- SERVER - Enum constant in enum org.infinispan.security.AuditContext
- SERVER - Static variable in interface org.infinispan.server.core.logging.Log
- SERVER_CORE_LOWER_BOUND - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- SERVER_ENTRY_VERSION - Static variable in class org.infinispan.server.core.ExternalizerIds
- SERVER_ERROR - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- SERVER_EVENT_IMPL - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- SERVER_LIST - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- SERVER_NAME - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- SERVER_NAME - Enum constant in enum org.infinispan.server.hotrod.configuration.Attribute
- SERVER_NAME - Static variable in class org.infinispan.server.hotrod.configuration.SaslConfiguration
- SERVER_PRINCIPAL - Enum constant in enum org.infinispan.server.hotrod.configuration.Attribute
- ServerAddress - Interface in org.infinispan.server.hotrod
-
A Hot Rod server address
- serverAuthenticationProvider() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfiguration
- serverAuthenticationProvider() - Method in interface org.infinispan.server.hotrod.logging.Log
- serverAuthenticationProvider(ServerAuthenticationProvider) - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
- ServerAuthenticationProvider - Interface in org.infinispan.server.core.security
- ServerConfiguration - Class in org.infinispan.client.hotrod.configuration
-
ServerConfiguration.
- ServerConfigurationBuilder - Class in org.infinispan.client.hotrod.configuration
-
ServerConfigurationBuilder.
- ServerConstants - Class in org.infinispan.server.core
-
Server Constant values
- ServerCoreBlockHoundIntegration - Class in org.infinispan.server.core
- ServerCoreBlockHoundIntegration() - Constructor for class org.infinispan.server.core.ServerCoreBlockHoundIntegration
- serverDataFormat(DataFormat.Builder) - Method in class org.infinispan.client.hotrod.DataFormat.Builder
- ServerError - Enum constant in enum org.infinispan.server.hotrod.OperationStatus
- ServerHotRodBlockHoundIntegration - Class in org.infinispan.server.hotrod
- ServerHotRodBlockHoundIntegration() - Constructor for class org.infinispan.server.hotrod.ServerHotRodBlockHoundIntegration
- serverKeyTypeNotRecognized(MediaType) - Method in interface org.infinispan.client.hotrod.logging.Log
- ServerManagement - Interface in org.infinispan.server.core
- serverName() - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfiguration
- serverName() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
- serverName() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfiguration
- serverName() - Method in class org.infinispan.server.hotrod.configuration.SaslConfiguration
- serverName() - Method in class org.infinispan.server.hotrod.configuration.SaslConfigurationBuilder
- serverName(String) - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
-
Sets the name of the server as expected by the SASL protocol Setting this property also implicitly enables authentication (see
AuthenticationConfigurationBuilder.enable()
This defaults toAuthenticationConfigurationBuilder.DEFAULT_SERVER_NAME
. - serverName(String) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
-
Sets the name of the server as expected by the SASL protocol
- serverName(String) - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
- serverName(String) - Method in class org.infinispan.server.hotrod.configuration.SaslConfigurationBuilder
- ServerResource - Class in org.infinispan.rest.resources
- ServerResource(InvocationHelper) - Constructor for class org.infinispan.rest.resources.ServerResource
- ServerRestBlockHoundIntegration - Class in org.infinispan.rest
- ServerRestBlockHoundIntegration() - Constructor for class org.infinispan.rest.ServerRestBlockHoundIntegration
- servers() - Method in class org.infinispan.client.hotrod.configuration.Configuration
- servers() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- servers() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
- SERVERS - Enum constant in enum org.infinispan.persistence.remote.configuration.Element
- ServerSentEvent - Class in org.infinispan.rest
- ServerSentEvent(String, String) - Constructor for class org.infinispan.rest.ServerSentEvent
- serverSocketChannelClass() - Static method in class org.infinispan.server.core.transport.IOURingNativeTransport
- serverSocketChannelClass() - Static method in class org.infinispan.server.core.transport.NativeTransport
- ServerStateManager - Interface in org.infinispan.server.core
- serverStatistics() - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- serverStatistics() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- serverStatistics() - Method in interface org.infinispan.client.hotrod.RemoteCache
-
Returns server-side statistics for this cache.
- ServerStatistics - Interface in org.infinispan.client.hotrod
-
Defines the possible list of statistics defined by the Hot Rod server.
- serverStatisticsAsync() - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- serverStatisticsAsync() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- serverStatisticsAsync() - Method in interface org.infinispan.client.hotrod.RemoteCache
-
Returns server-side statistics for this cache.
- ServerStatisticsImpl - Class in org.infinispan.client.hotrod.impl
- ServerStatisticsImpl() - Constructor for class org.infinispan.client.hotrod.impl.ServerStatisticsImpl
- serverStop(List<String>) - Method in interface org.infinispan.server.core.ServerManagement
- serverSubject() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfiguration
- serverSubject(Subject) - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
- ServerTask<V> - Interface in org.infinispan.tasks
-
An interface representing a deployed server task.
- ServerTransactionOriginatorChecker - Class in org.infinispan.server.hotrod.tx
-
A
TransactionOriginatorChecker
implementation that is aware of client transactions. - ServerTransactionOriginatorChecker() - Constructor for class org.infinispan.server.hotrod.tx.ServerTransactionOriginatorChecker
- ServiceFinder - Class in org.infinispan.commons.util
-
ServiceFinder is a
ServiceLoader
replacement which understands multiple classpaths. - ServiceFinder() - Constructor for class org.infinispan.commons.util.ServiceFinder
- ServiceUnavailableException - Exception in org.infinispan.rest.operations.exceptions
- ServiceUnavailableException(String) - Constructor for exception org.infinispan.rest.operations.exceptions.ServiceUnavailableException
- SessionAttribute(String, Object) - Constructor for class org.infinispan.spring.common.session.MapSessionProtoAdapter.SessionAttribute
- SessionAttribute$___Marshaller_5dcef48338013ff033aa3ebdfe72b959048a23f1ab1b4e671508996ffee0358b - Class in org.infinispan.spring.common.session
-
WARNING: Generated code! Do not edit!
- SessionAttribute$___Marshaller_5dcef48338013ff033aa3ebdfe72b959048a23f1ab1b4e671508996ffee0358b() - Constructor for class org.infinispan.spring.common.session.SessionAttribute$___Marshaller_5dcef48338013ff033aa3ebdfe72b959048a23f1ab1b4e671508996ffee0358b
- SessionAttributeRawMarshaller(JavaSerializationMarshaller) - Constructor for class org.infinispan.spring.common.session.MapSessionProtoAdapter.SessionAttributeRawMarshaller
- sessionRepository(SpringEmbeddedCacheManager, ApplicationEventPublisher) - Method in class org.infinispan.spring.embedded.session.configuration.InfinispanEmbeddedHttpSessionConfiguration
- sessionRepository(SpringRemoteCacheManager, ApplicationEventPublisher) - Method in class org.infinispan.spring.remote.session.configuration.InfinispanRemoteHttpSessionConfiguration
- SessionUpdateRemappingFunction - Class in org.infinispan.spring.common.session
- SessionUpdateRemappingFunction() - Constructor for class org.infinispan.spring.common.session.SessionUpdateRemappingFunction
- SessionUpdateRemappingFunctionProtoAdapter - Class in org.infinispan.spring.common.session
-
Protostream adapter for
SessionUpdateRemappingFunction
. - SessionUpdateRemappingFunctionProtoAdapter() - Constructor for class org.infinispan.spring.common.session.SessionUpdateRemappingFunctionProtoAdapter
- SessionUpdateRemappingFunctionProtoAdapter$___Marshaller_9c0544bb624c0af23e5a5e11e8120017e963b2cee452968f8524051818abdb2b - Class in org.infinispan.spring.common.session
-
WARNING: Generated code! Do not edit!
- SessionUpdateRemappingFunctionProtoAdapter$___Marshaller_9c0544bb624c0af23e5a5e11e8120017e963b2cee452968f8524051818abdb2b() - Constructor for class org.infinispan.spring.common.session.SessionUpdateRemappingFunctionProtoAdapter$___Marshaller_9c0544bb624c0af23e5a5e11e8120017e963b2cee452968f8524051818abdb2b
- set - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
- set(boolean) - Method in class org.infinispan.commons.util.ByRef.Boolean
- set(byte) - Method in enum org.infinispan.server.hotrod.tx.ControlByte
-
Sets
this
flag to thebitSet
. - set(int) - Method in class org.infinispan.commons.util.ImmutableIntSet
- set(int) - Method in class org.infinispan.commons.util.ByRef.Integer
- set(int) - Method in interface org.infinispan.commons.util.IntSet
-
Adds or sets the int without returning whether it was previously set
- set(int) - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- set(int) - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.Add an integer to the set without boxing the parameter or checking if the integer was already present in the set.
- set(int, boolean) - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.If
value
istrue
, add the integer to the set, otherwise remove the integer from the set. - set(int, E) - Method in class org.infinispan.commons.util.ForwardingList
- set(int, Object) - Method in class org.infinispan.commons.dataconversion.internal.Json
-
Change the value of a JSON array element.
- set(int, Object, int, int) - Method in class org.infinispan.persistence.sifs.TemporaryTable
- set(long) - Method in class org.infinispan.commons.util.ByRef.Long
- set(String, Object) - Method in class org.infinispan.commons.dataconversion.internal.Json
-
Set a
Json
objects's property. - set(String, Json) - Method in class org.infinispan.commons.dataconversion.internal.Json
-
Set a
Json
objects's property. - set(K, V, V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntryChange
- set(T) - Method in class org.infinispan.commons.configuration.attributes.Attribute
- set(T) - Method in class org.infinispan.commons.util.ByRef
- set(V, MetaParam.Writable...) - Method in interface org.infinispan.functional.EntryView.WriteEntryView
-
Set this value along with optional metadata parameters.
- set(V, Metadata) - Method in class org.infinispan.cache.impl.SimpleCacheImpl.ValueAndMetadata
- set(V, Metadata) - Method in interface org.infinispan.functional.EntryView.WriteEntryView
-
Set this value along with metadata object.
- setAccessibly(Object, Field, Object) - Static method in class org.infinispan.commons.util.ReflectionUtil
- setAclCache(Map<CacheSubjectPair, SubjectACL>) - Method in class org.infinispan.security.impl.Authorizer
- setAction(String) - Method in interface org.infinispan.rest.framework.RestRequest
- setAction(String) - Method in class org.infinispan.rest.NettyRestRequest
- setAddress(Address) - Method in class org.infinispan.transaction.xa.GlobalTransaction
- setAnnotation(Class<? extends Annotation>) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.infinispan.spring.common.session.AbstractApplicationPublisherBridge
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository
- setAsyncExecutorFactory(String) - Method in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
- setAsyncExecutorFactory(String) - Method in class org.infinispan.spring.remote.ConfigurationPropertiesOverrides
- setAttribute(String, Object) - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository.InfinispanSession
- setAttribute(Attribute) - Method in class org.infinispan.jmx.ResourceDMBean
- setAttributes(AttributeList) - Method in class org.infinispan.jmx.ResourceDMBean
- setAttributeValue(String, Enum<?>, String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
- setAttributeValue(String, String, String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
- setAttributeValue(String, String, String) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationReader
- setAttributeValue(String, String, String) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationReader
- setAttributeValue(String, String, String) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader
- setAuthPassword(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setAuthRealm(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setAuthServerName(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setAuthToken(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setAuthUsername(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setAutomaticStateTransfer(String, XSiteStateTransferMode) - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateTransferManager
- setAutomaticStateTransfer(String, XSiteStateTransferMode) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
-
Sets the
XSiteStateTransferMode
to the remote site. - setAutomaticStateTransfer(String, XSiteStateTransferMode) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
- setAvailability(AvailabilityMode) - Method in interface org.infinispan.AdvancedCache
-
Manually change the availability of the cache.
- setAvailability(AvailabilityMode) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- setAvailability(AvailabilityMode) - Method in class org.infinispan.cache.impl.CacheImpl
- setAvailability(AvailabilityMode) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- setAvailability(AvailabilityMode) - Method in class org.infinispan.security.impl.SecureCacheImpl
- setAvailabilityMode(AvailabilityMode) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- setAvailabilityMode(AvailabilityMode) - Method in class org.infinispan.partitionhandling.impl.AvailablePartitionHandlingManager
- setAvailabilityMode(AvailabilityMode) - Method in interface org.infinispan.partitionhandling.impl.PartitionHandlingManager
- setAvailabilityMode(AvailabilityMode) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingManagerImpl
- setAvailable(boolean) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- setBackOff(ExponentialBackOff) - Method in class org.infinispan.xsite.irac.DefaultIracManager
- setBackOff(ExponentialBackOff) - Method in class org.infinispan.xsite.irac.IracExecutor
- setBatchSize(int) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setBeanName(String) - Method in class org.infinispan.spring.embedded.support.InfinispanNamedEmbeddedCacheFactoryBean
- setBeanName(String) - Method in class org.infinispan.spring.remote.support.InfinispanNamedRemoteCacheFactoryBean
- setBits(IntSet) - Method in class org.infinispan.commons.util.BloomFilter
-
Clears all current bits and sets them to the values in the provided
IntSet
. - setBloomListenerAddress(SocketAddress) - Method in class org.infinispan.client.hotrod.impl.InvalidatedNearRemoteCache
- setCacheAvailability(String) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- setCacheAvailability(String, AvailabilityMode) - Method in interface org.infinispan.topology.LocalTopologyManager
-
Updates the availability state of a cache (for the entire cluster).
- setCacheAvailability(String, AvailabilityMode) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- SetCacheAvailabilityAction - Class in org.infinispan.security.actions
-
SetCacheAvailabilityAction.
- SetCacheAvailabilityAction(AdvancedCache<?, ?>, AvailabilityMode) - Constructor for class org.infinispan.security.actions.SetCacheAvailabilityAction
- setCacheManager(EmbeddedCacheManager) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
- setCacheName(String) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
- setCacheName(String) - Method in class org.infinispan.spring.embedded.support.InfinispanNamedEmbeddedCacheFactoryBean
-
Sets the
name
of the
to be created.org.infinispan.Cache
- setCacheName(String) - Method in class org.infinispan.spring.remote.support.InfinispanNamedRemoteCacheFactoryBean
-
Sets the
name
of the
to be created.org.infinispan.Cache
- setCacheRebalancingEnabled(String, boolean) - Method in interface org.infinispan.topology.LocalTopologyManager
-
Enable or disable rebalancing for the specified cache.
- setCacheRebalancingEnabled(String, boolean) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- setCacheTopology(CacheTopology) - Method in interface org.infinispan.distribution.DistributionManager
-
Deprecated, for removal: This API element is subject to removal in a future version.Internal only.
- setCacheTopology(CacheTopology) - Method in class org.infinispan.distribution.impl.DistributionManagerImpl
- setCancellationFuture(ScheduledFuture<?>) - Method in class org.infinispan.client.hotrod.event.impl.ReconnectTask
- setCapacity(int) - Method in class org.infinispan.extendedstats.topK.StreamSummaryContainer
-
Sets the capacity of the top-key.
- setChanged(boolean) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
- setChanged(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
- setChanged(boolean) - Method in class org.infinispan.container.entries.ClearCacheEntry
- setChanged(boolean) - Method in class org.infinispan.container.entries.ForwardingCacheEntry
- setChanged(boolean) - Method in interface org.infinispan.container.entries.MVCCEntry
- setChanged(boolean) - Method in class org.infinispan.container.entries.NullCacheEntry
- setChanged(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
- setChannelHandlerContext(ChannelHandlerContext) - Method in class org.infinispan.rest.EventStream
- setClassAllowList(String) - Method in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
- setClassAllowList(String) - Method in class org.infinispan.spring.remote.ConfigurationPropertiesOverrides
- setClassLoader(ClassLoader) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
- setClassWhiteList(String) - Method in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
-
Deprecated, for removal: This API element is subject to removal in a future version.Use
AbstractRemoteCacheManagerFactory.setClassAllowList(String)
instead. Will be removed in 14.0. - setClearOnStop(boolean) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- setClientIntelligence(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setClustered(boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- setCombine(Combine) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
- setCommandRetried(boolean) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- setCommitted() - Method in interface org.infinispan.container.entries.MVCCEntry
-
Mark this context-entry as already committed to the
DataContainer
. - setCommitted() - Method in class org.infinispan.container.entries.ReadCommittedEntry
- SetCompletedTransactionFunction - Class in org.infinispan.server.hotrod.tx.table.functions
-
It marks the transaction as completed in
TxState
by setting its status toStatus.COMMITTED
orStatus.ROLLED_BACK
. - SetCompletedTransactionFunction(boolean) - Constructor for class org.infinispan.server.hotrod.tx.table.functions.SetCompletedTransactionFunction
- setCompletionFailed(boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareLocalTransaction
- setComponent(String) - Method in class org.infinispan.factories.threads.DefaultThreadFactory
- setConfiguration(JGroupsConfiguration) - Method in class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator
- setConfigurationEntityName(String) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
- setConfigurationEntityType(String) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
- setConfigurationEventType(ConfigurationChangedEvent.EventType) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
- setConfigurationFileLocation(Resource) - Method in class org.infinispan.spring.embedded.AbstractEmbeddedCacheManagerFactory
-
Sets the
of the configuration file which will be used to configure thelocation
theEmbeddedCacheManager
created by thisSpringEmbeddedCacheManager
FactoryBean
delegates to. - setConfigurationProperties(Properties) - Method in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
- setConfigurationPropertiesFileLocation(Resource) - Method in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
- setConfigurationTemplateMode(String) - Method in class org.infinispan.spring.embedded.support.InfinispanNamedEmbeddedCacheFactoryBean
- setConnectionPoolExhaustedAction(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setConnectionPoolMaxActive(int) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setConnectionPoolMaxPendingRequests(int) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setConnectionPoolMaxWait(long) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setConnectionPoolMinEvictableIdleTime() - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setConnectionPoolMinEvictableIdleTime(long) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setConnectionPoolMinIdle(int) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setConnectorIpFilterRule(String, Collection<IpSubnetFilterRule>) - Method in interface org.infinispan.server.core.ServerStateManager
- setConnectTimeout(int) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setContents(ContentSource) - Method in interface org.infinispan.rest.framework.impl.RestRequestBuilder
- setContext(AuthorizationMapperContext) - Method in interface org.infinispan.security.RolePermissionMapper
-
Sets the context for this
RolePermissionMapper
- setContext(PrincipalRoleMapperContext) - Method in interface org.infinispan.security.PrincipalRoleMapper
-
Sets the context for this
PrincipalRoleMapper
- setContextInitializers(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setConverter(CacheEventConverter<? super K, ? super V, ?>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- setCreated(boolean) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
- setCreated(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
- setCreated(boolean) - Method in class org.infinispan.container.entries.ClearCacheEntry
- setCreated(boolean) - Method in class org.infinispan.container.entries.ForwardingCacheEntry
- setCreated(boolean) - Method in class org.infinispan.container.entries.NullCacheEntry
- setCreated(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
- setCreated(boolean) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- setCreated(long) - Method in interface org.infinispan.container.entries.CacheEntry
- setCreated(long) - Method in class org.infinispan.container.entries.MortalCacheValue
- setCreated(long) - Method in class org.infinispan.container.entries.ReadCommittedEntry
- setCurrentState(boolean) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- setCurrentTopologyAsStable(boolean) - Method in class org.infinispan.topology.ClusterCacheStatus
- setDataLocation(String) - Method in class org.infinispan.persistence.sifs.configuration.DataConfiguration
- SetDecisionFunction - Class in org.infinispan.server.hotrod.tx.table.functions
-
It sets the transaction decision in
TxState
. - SetDecisionFunction(boolean) - Constructor for class org.infinispan.server.hotrod.tx.table.functions.SetDecisionFunction
- setDecoderResult(DecoderResult) - Method in class org.infinispan.rest.ServerSentEvent
- setDefaultExecutorFactoryPoolSize(int) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setDefaultExecutorFactoryThreadNamePrefix(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setDefaultExecutorFactoryThreadNameSuffix(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setDefaultHitCountAccuracy(int) - Method in class org.infinispan.query.remote.json.JsonQueryRequest
- setDefaultMaxInactiveInterval(Duration) - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository
-
Set the maximum inactive interval in seconds between requests before newly created sessions will be invalidated.
- setEnabled(boolean) - Method in class org.infinispan.extendedstats.topK.StreamSummaryContainer
-
Enables or disables the top-key collection
- setEnclosingProtocolServer(ProtocolServer<?>) - Method in class org.infinispan.rest.RestServer
- setEnclosingProtocolServer(ProtocolServer<?>) - Method in class org.infinispan.server.core.AbstractProtocolServer
- setEnclosingProtocolServer(ProtocolServer<?>) - Method in interface org.infinispan.server.core.ProtocolServer
-
Sets the enclosing
ProtocolServer
. - setEncoding(String) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- setEnlisted(boolean) - Method in class org.infinispan.transaction.synchronization.SyncLocalTransaction
- setEntityConverter(EntityConverter) - Method in class org.infinispan.search.mapper.impl.InfinispanMappingInitiator
- setEntityConverter(EntityConverter) - Method in class org.infinispan.search.mapper.mapping.SearchMappingBuilder
- setEntityLoader(PojoSelectionEntityLoader<?>) - Method in class org.infinispan.search.mapper.impl.InfinispanMappingInitiator
- setEntityLoader(PojoSelectionEntityLoader<?>) - Method in class org.infinispan.search.mapper.mapping.SearchMappingBuilder
- setEntries(Map<? extends K, ? extends V>) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- setEnum(long, Enum<?>) - Static method in class org.infinispan.commons.util.EnumUtil
- setEnums(long, Collection<E>) - Static method in class org.infinispan.commons.util.EnumUtil
- setEvent(E) - Method in class org.infinispan.notifications.cachelistener.EventWrapper
- setEvicted(boolean) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
- setEvicted(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
- setEvicted(boolean) - Method in class org.infinispan.container.entries.ClearCacheEntry
- setEvicted(boolean) - Method in class org.infinispan.container.entries.ForwardingCacheEntry
- setEvicted(boolean) - Method in class org.infinispan.container.entries.NullCacheEntry
- setEvicted(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
- setEvictionSize(long) - Method in class org.infinispan.cache.impl.CacheConfigurationMBean
- setException(Exception) - Method in class org.infinispan.remoting.responses.ExceptionResponse
- setExecutable(boolean) - Method in class org.infinispan.io.GridFile
-
Deprecated.
- setExecutable(boolean, boolean) - Method in class org.infinispan.io.GridFile
-
Deprecated.
- setExecutor(Executor) - Method in class org.infinispan.xsite.irac.IracExecutor
- setExpired(boolean) - Method in interface org.infinispan.container.entries.MVCCEntry
-
Marks this entry as being expired.
- setExpired(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
- setFeature(String, boolean) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
-
Method setFeature
- setFeature(String, boolean) - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
-
Use this call to change the general behaviour of the parser, such as namespace processing or doctype declaration handling.
- setField(Object, Field, Object) - Static method in class org.infinispan.commons.util.ReflectionUtil
- setFilter(CacheEventFilter<? super K, ? super V>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- setFilterAnnotations(Set<Class<? extends Annotation>>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- setFirstResult(int) - Method in class org.infinispan.query.impl.QueryDefinition
- setFlag(ReadCommittedEntry.Flags) - Method in class org.infinispan.container.entries.ReadCommittedEntry
-
Utility method that sets the value of the given flag to true.
- setFlags(Set<Flag>) - Method in interface org.infinispan.commands.FlagAffectedCommand
-
Deprecated.Since 9.0, please use
FlagAffectedCommand.setFlagsBitSet(long)
instead. - setFlagsBitSet(long) - Method in class org.infinispan.commands.AbstractFlagAffectedCommand
- setFlagsBitSet(long) - Method in interface org.infinispan.commands.FlagAffectedCommand
-
Set the flags, replacing any existing flags.
- setFlushMode(FlushMode) - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository
-
Sets the flush mode.
- setForceReturnValues(boolean) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setForceReturnValues(boolean) - Method in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
- setForceReturnValues(boolean) - Method in class org.infinispan.spring.remote.ConfigurationPropertiesOverrides
- setFromRemoteSite(boolean) - Method in class org.infinispan.transaction.impl.LocalTransaction
- setGlobalFactory(Json.Factory) - Static method in class org.infinispan.commons.dataconversion.internal.Json
-
Specify a global Json
Json.Factory
to be used by all threads that don't have a specific thread-local factory attached to them. - setHeaders(Map<String, String>) - Method in interface org.infinispan.rest.framework.impl.RestRequestBuilder
- setHitCountAccuracy(int) - Method in class org.infinispan.query.impl.QueryDefinition
- setId(long) - Method in class org.infinispan.transaction.xa.GlobalTransaction
- setIdentifier(UUID) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- setImplied(T) - Method in class org.infinispan.commons.configuration.attributes.Attribute
- setImportMetadata(AnnotationMetadata) - Method in class org.infinispan.spring.embedded.session.configuration.InfinispanEmbeddedHttpSessionConfiguration
- setImportMetadata(AnnotationMetadata) - Method in class org.infinispan.spring.remote.session.configuration.InfinispanRemoteHttpSessionConfiguration
- setIncludeCurrentState(boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- setIndexResolver(IndexResolver<Session>) - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository
-
Set the
IndexResolver
to use. - setInfinispanCacheContainer(CacheContainer) - Method in class org.infinispan.spring.embedded.InfinispanDefaultCacheFactoryBean
-
Sets the
to be used for creating ourorg.infinispan.manager.CacheContainer
instance.Cache
- setInfinispanEmbeddedCacheManager(EmbeddedCacheManager) - Method in class org.infinispan.spring.embedded.support.InfinispanNamedEmbeddedCacheFactoryBean
-
Sets the
to be used for creating ourorg.infinispan.manager.EmbeddedCacheManager
instance.Cache
- setInfinispanRemoteCacheManager(RemoteCacheManager) - Method in class org.infinispan.spring.remote.support.InfinispanNamedRemoteCacheFactoryBean
-
Sets the
to be used for creating ourorg.infinispan.client.hotrod.RemoteCacheManager
instance.Cache
- setInitialCacheTopologyId(String, int) - Method in interface org.infinispan.topology.ClusterTopologyManager
-
Sets the id of the initial topology in given cache.
- setInitialCacheTopologyId(String, int) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- setInitialTopologyId(int) - Method in class org.infinispan.topology.ClusterCacheStatus
- setInput(InputStream, String) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- setInput(InputStream, String) - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
-
Sets the input stream the parser is going to process.
- setInput(Reader) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- setInput(Reader) - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
-
Set the input source for parser to the given reader and resets the parser.
- setIntegration(SearchIntegration) - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
- setInternalCacheEntryFactory(InternalEntryFactory) - Method in class org.infinispan.persistence.remote.RemoteStore
- setInternalCacheValueConsumer() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- setInternalId(long) - Method in class org.infinispan.transaction.xa.GlobalTransaction
- setInternalMetadata(PrivateMetadata) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
- setInternalMetadata(PrivateMetadata) - Method in interface org.infinispan.container.entries.CacheEntry
- setInternalMetadata(PrivateMetadata) - Method in class org.infinispan.container.entries.ImmortalCacheValue
- setInternalMetadata(PrivateMetadata) - Method in interface org.infinispan.container.entries.InternalCacheValue
- setInternalMetadata(PrivateMetadata) - Method in class org.infinispan.container.entries.ReadCommittedEntry
- setInvalidationCallback(Runnable) - Method in class org.infinispan.client.hotrod.near.NearCacheService
- setIracMetadata(CacheEntry<?, ?>, int, IracMetadata, IracTombstoneManager, LogSupplier) - Static method in class org.infinispan.util.IracUtils
-
Stores the
IracMetadata
intoCacheEntry
. - setJavaSerialAllowList(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setJavaSerialWhitelist(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
-
Deprecated, for removal: This API element is subject to removal in a future version.Use
ConfigurationProperties.setJavaSerialAllowList(String)
instead. To be removed in 14.0. - setJmx(boolean) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setJmxDomain(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setJmxName(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setKeepAliveTime(long) - Method in class org.infinispan.executors.ManageableExecutorService
- setKey(K) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- setKeyAlias(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setKeyDataConversion(DataConversion) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- setKeySizeEstimate(int) - 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
- setKeySizeEstimate(int) - Method in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
-
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
- setKeySizeEstimate(int) - Method in class org.infinispan.spring.remote.ConfigurationPropertiesOverrides
-
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
- setKeyStoreCertificatePassword(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setKeyStoreFileName(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setKeyStorePassword(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setKeyStoreType(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setLastAccessedTime(Instant) - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository.InfinispanSession
- setLastModified(long) - Method in class org.infinispan.io.GridFile
-
Deprecated.
- setLastUsed(long) - Method in interface org.infinispan.container.entries.CacheEntry
- setLastUsed(long) - Method in class org.infinispan.container.entries.ReadCommittedEntry
- setLastUsed(long) - Method in class org.infinispan.container.entries.TransientCacheValue
- setLastUsed(long) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
- setLength(int) - Method in class org.infinispan.io.GridFile.Metadata
-
Deprecated.
- setLifespan(long) - Method in class org.infinispan.container.entries.MortalCacheEntry
- setLifespan(long) - Method in class org.infinispan.container.entries.MortalCacheValue
- setLifespan(long) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
- setLoaded(boolean) - Method in interface org.infinispan.container.entries.MVCCEntry
- setLoaded(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
- setLocal(boolean) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfo
-
Sets
true
if this transaction information is stored locally. - setLocalAddress(Address) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
- setLocalRepository(Path) - Method in class org.infinispan.commons.maven.MavenSettings
- setLocation(String) - Method in class org.infinispan.persistence.sifs.configuration.IndexConfiguration
- setLockOwner(Object) - Method in class org.infinispan.context.impl.AbstractTxInvocationContext
- setLockOwner(Object) - Method in class org.infinispan.context.impl.ClearInvocationContext
- setLockOwner(Object) - Method in class org.infinispan.context.impl.ImmutableContext
- setLockOwner(Object) - Method in class org.infinispan.context.impl.NonTxInvocationContext
- setLockOwner(Object) - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
- setLockOwner(Object) - Method in interface org.infinispan.context.InvocationContext
-
Sets the object to be used by lock owner.
- setLookedUpEntriesTopology(int) - Method in class org.infinispan.transaction.impl.RemoteTransaction
- setLowLevelTrace(boolean) - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
- SetMapper<E,
R> - Class in org.infinispan.util -
A set that maps another one to a new one of a possibly different type.
- SetMapper(Set<E>, Function<? super E, ? extends R>) - Constructor for class org.infinispan.util.SetMapper
- setMarshaller(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setMarshaller(String) - Method in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
- setMarshaller(String) - Method in class org.infinispan.spring.remote.ConfigurationPropertiesOverrides
- setMarshaller(Marshaller) - Method in interface org.infinispan.persistence.keymappers.MarshallingTwoWayKey2StringMapper
- setMarshaller(Marshaller) - Method in class org.infinispan.server.hotrod.HotRodServer
- setMarshaller(StreamingMarshaller) - Method in interface org.infinispan.persistence.keymappers.MarshallingTwoWayKey2StringMapper
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.0, use
MarshallingTwoWayKey2StringMapper.setMarshaller(Marshaller)
instead - setMarshaller(StreamingMarshaller) - Method in class org.infinispan.persistence.keymappers.WrappedByteArrayOrPrimitiveMapper
- setMaxIdle(long) - Method in class org.infinispan.container.entries.TransientCacheEntry
- setMaxIdle(long) - Method in class org.infinispan.container.entries.TransientCacheValue
- setMaxIdle(long) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
- setMaxIdle(long) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
- setMaximumPoolSize(int) - Method in class org.infinispan.executors.ManageableExecutorService
- setMaxInactiveInterval(Duration) - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository.InfinispanSession
- setMaxResults(int) - Method in class org.infinispan.query.impl.QueryDefinition
- setMaxRetries(int) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setMergeView(boolean) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
- setMetadata(Metadata) - Method in interface org.infinispan.commands.MetadataAwareCommand
-
Sets metadata for this command.
- setMetadata(Metadata) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
- setMetadata(Metadata) - Method in class org.infinispan.container.entries.ClearCacheEntry
- setMetadata(Metadata) - Method in class org.infinispan.container.entries.ForwardingCacheEntry
- setMetadata(Metadata) - Method in class org.infinispan.container.entries.ImmortalCacheEntry
- setMetadata(Metadata) - Method in interface org.infinispan.container.entries.metadata.MetadataAware
-
Set the metadata in the cache entry.
- setMetadata(Metadata) - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheEntry
- setMetadata(Metadata) - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue
- setMetadata(Metadata) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
- setMetadata(Metadata) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
- setMetadata(Metadata) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
- setMetadata(Metadata) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
- setMetadata(Metadata) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
- setMetadata(Metadata) - Method in class org.infinispan.container.entries.MortalCacheEntry
- setMetadata(Metadata) - Method in class org.infinispan.container.entries.NullCacheEntry
- setMetadata(Metadata) - Method in class org.infinispan.container.entries.ReadCommittedEntry
- setMetadata(Metadata) - Method in class org.infinispan.container.entries.TransientCacheEntry
- setMetadata(Metadata) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
- setMetadata(Metadata) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- setMethod(Method) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
- setMethod(Method) - Method in interface org.infinispan.rest.framework.impl.RestRequestBuilder
- setModifications(List<WriteCommand>) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
- setModificationTime(long) - Method in class org.infinispan.io.GridFile.Metadata
-
Deprecated.
- setName(String) - Method in class org.infinispan.remoting.transport.jgroups.NamedSocketFactory
- setNamedParameters(Map<String, Object>) - Method in class org.infinispan.query.impl.QueryDefinition
- setNamespaceMappingParser(NamespaceMappingParser) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
- setNearCacheMaxEntries(int) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setNearCacheMaxEntries(int) - Method in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
- setNearCacheMaxEntries(int) - Method in class org.infinispan.spring.remote.ConfigurationPropertiesOverrides
- setNearCacheMode(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setNearCacheMode(String) - Method in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
- setNearCacheMode(String) - Method in class org.infinispan.spring.remote.ConfigurationPropertiesOverrides
- setNearCacheNamePattern(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
-
Deprecated, for removal: This API element is subject to removal in a future version.
- setNearCacheNamePattern(String) - Method in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
- setNearCacheNamePattern(String) - Method in class org.infinispan.spring.remote.ConfigurationPropertiesOverrides
- setNewIracMetadata(Map<Integer, IracMetadata>) - Method in class org.infinispan.remoting.responses.PrepareResponse
- setNewMembers(List<Address>) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
- setNewTopologyId(int) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- setNewValue(V) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- setNext(long, long) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
-
Called to update the next pointer index when a collision occurs requiring a linked list within the entries themselves
- setNext(long, long) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
- setNextInterceptor(AsyncInterceptor) - Method in interface org.infinispan.interceptors.AsyncInterceptor
-
Sets up the interceptor.
- setNextInterceptor(AsyncInterceptor) - Method in class org.infinispan.interceptors.BaseAsyncInterceptor
-
Used internally to set up the interceptor.
- setNode(String) - Method in class org.infinispan.factories.threads.DefaultThreadFactory
- setObservation(Listener.Observation) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- setOldMembers(List<Address>) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
- setOldMetadata(Metadata) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- setOldValue(V) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- setOnlyPrimary(boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- setOrigin(Address) - Method in interface org.infinispan.commands.ReplicableCommand
-
Sets the sender's
Address
. - setOriginLocal(boolean) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- setOutcome(boolean) - Method in class org.infinispan.extendedstats.TransactionStatistics
-
Sets the transaction outcome.
- setOwnedSegments(IntSet) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
- setOwnedSegments(IntSet) - Method in interface org.infinispan.scattered.ScatteredVersionManager
-
Move the segment from
ScatteredVersionManager.SegmentState.NOT_OWNED
toScatteredVersionManager.SegmentState.OWNED
without transferring data. - setParameter(String, Object) - Method in interface org.infinispan.query.dsl.ParameterContext
-
Deprecated.Sets the value of a named parameter.
- setParameter(String, Object) - Method in interface org.infinispan.query.dsl.Query
-
Sets the value of a named parameter.
- setParameter(PreparedStatement, AbstractSchemaJdbcStore.ProtostreamFieldType, int, Json) - Method in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.SchemaTableOperations
-
This method assigns a parameter based on the type using the parameter type.
- setParameters(Map<String, Object>) - Method in interface org.infinispan.query.dsl.ParameterContext
-
Deprecated.Sets multiple named parameters at once.
- setParameters(Map<String, Object>) - Method in interface org.infinispan.query.dsl.Query
-
Sets multiple named parameters at once.
- setPath(String) - Method in interface org.infinispan.rest.framework.impl.RestRequestBuilder
- setPre(boolean) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- setPrepared(boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareLocalTransaction
- setPrepared(boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
- setPrepared(boolean) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryAwareTransaction
- SetPreparedFunction - Class in org.infinispan.server.hotrod.tx.table.functions
-
It sets the transaction as successful prepared.
- SetPreparedFunction() - Constructor for class org.infinispan.server.hotrod.tx.table.functions.SetPreparedFunction
- setPrivateMetadata(CacheEntry<?, ?>, int, PrivateMetadata, IracTombstoneManager, LogSupplier) - Static method in class org.infinispan.util.IracUtils
-
Same as
IracUtils.setIracMetadata(CacheEntry, int, IracMetadata, IracTombstoneManager, LogSupplier)
but it stores a "full"PrivateMetadata
instead ofIracMetadata
. - setProperties(Map<String, Object>) - Method in class org.infinispan.search.mapper.mapping.impl.IndexProperties
- setProperties(Map<String, Object>) - Method in class org.infinispan.search.mapper.mapping.SearchMappingBuilder
- setProperty(String, boolean) - Method in class org.infinispan.commons.util.TypedProperties
- setProperty(String, float) - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
- setProperty(String, float) - Method in interface org.infinispan.globalstate.ScopedPersistentState
-
Sets a float state property.
- setProperty(String, int) - Method in class org.infinispan.commons.util.TypedProperties
- setProperty(String, int) - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
- setProperty(String, int) - Method in interface org.infinispan.globalstate.ScopedPersistentState
-
Sets an integer state property.
- setProperty(String, long) - Method in class org.infinispan.commons.util.TypedProperties
- setProperty(String, Object) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- setProperty(String, Object) - Method in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
-
Set the value of a property.
- setProperty(String, Object) - 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
IndexingConfigurationBuilder.writer()
andIndexingConfigurationBuilder.reader()
to define indexing behavior. - setProperty(String, Object) - Method in class org.infinispan.search.mapper.mapping.impl.IndexProperties
- setProperty(String, Object) - Method in class org.infinispan.search.mapper.mapping.SearchMappingBuilder
- setProperty(String, String) - Method in class org.infinispan.commons.util.TypedProperties
- setProperty(String, String) - Method in class org.infinispan.globalstate.impl.ScopedPersistentStateImpl
- setProperty(String, String) - Method in interface org.infinispan.globalstate.ScopedPersistentState
-
Sets a state property.
- setProtocolVersion(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setProvidedIdentifierBridge(BeanReference<? extends IdentifierBridge<Object>>) - Method in class org.infinispan.search.mapper.mapping.SearchMappingBuilder
- setRead() - Method in interface org.infinispan.container.entries.MVCCEntry
-
Mark that this entry was loaded from the cache (as opposed to generated by the application using write-only command), mostly for purposes of the write skew check.
- setRead() - Method in class org.infinispan.container.entries.RepeatableReadEntry
- setReadable(boolean) - Method in class org.infinispan.io.GridFile
-
Deprecated.
- setReadable(boolean, boolean) - Method in class org.infinispan.io.GridFile
-
Deprecated.
- setReadConsistentHashAtEnd(ConsistentHash) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- setReadConsistentHashAtStart(ConsistentHash) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- setReadOnly() - Method in class org.infinispan.io.GridFile
-
Deprecated.
- setReadTimeout(long) - Method in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
- setReadTimeout(long) - Method in class org.infinispan.spring.remote.ConfigurationPropertiesOverrides
- setReadTimeout(long) - Method in class org.infinispan.spring.remote.provider.SpringRemoteCacheManager
- setRebalanced(boolean) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
- setRebalanceEnabled(boolean) - Method in class org.infinispan.topology.ClusterCacheStatus
- setRebalancingEnabled(boolean) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- setRebalancingEnabled(boolean) - Method in class org.infinispan.cache.impl.CacheImpl
- setRebalancingEnabled(boolean) - Method in interface org.infinispan.topology.ClusterTopologyManager
-
Globally enables or disables whether automatic rebalancing should occur.
- setRebalancingEnabled(boolean) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- setRebalancingEnabled(boolean) - Method in interface org.infinispan.topology.LocalTopologyManager
-
Enable or disable rebalancing in the entire cluster.
- setRebalancingEnabled(boolean) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- setRebalancingEnabled(String, boolean) - Method in interface org.infinispan.topology.ClusterTopologyManager
-
Enables or disables rebalancing for the specified cache
- setRebalancingEnabled(String, boolean) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- setRemote(boolean) - Method in class org.infinispan.transaction.xa.GlobalTransaction
- setRemoved(boolean) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
- setRemoved(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
- setRemoved(boolean) - Method in class org.infinispan.container.entries.ClearCacheEntry
- setRemoved(boolean) - Method in class org.infinispan.container.entries.ForwardingCacheEntry
- setRemoved(boolean) - Method in class org.infinispan.container.entries.NullCacheEntry
- setRemoved(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
- setRequestBalancingStrategy(String) - Method in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
- setRequestBalancingStrategy(String) - Method in class org.infinispan.spring.remote.ConfigurationPropertiesOverrides
- setRollbackOnly() - Method in class org.infinispan.commons.tx.TransactionImpl
-
Mark the transaction so that the only possible outcome is a rollback.
- setRollbackOnly() - Method in class org.infinispan.commons.tx.TransactionManagerImpl
- setRollbackOnly() - Method in class org.infinispan.server.hotrod.tx.PrepareCoordinator
-
Marks the transaction as rollback-only.
- setRollbackOnly() - Method in class org.infinispan.transaction.tm.EmbeddedUserTransaction
- setSaslMechanism(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setSaveMode(SaveMode) - Method in class org.infinispan.spring.common.session.AbstractInfinispanSessionRepository
-
Set the save mode.
- setSchema(ConfigurationSchemaVersion) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationReader
- setSchema(ConfigurationSchemaVersion) - Method in interface org.infinispan.commons.configuration.io.ConfigurationReader
- setSeqId(long) - Method in class org.infinispan.persistence.sifs.LogAppender
- setServerList(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setServerList(Collection<InetSocketAddress>) - Method in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
- setServerList(Collection<InetSocketAddress>) - Method in class org.infinispan.spring.remote.ConfigurationPropertiesOverrides
- setServerManagement(ServerManagement, boolean) - Method in class org.infinispan.server.core.AbstractProtocolServer
- setServerManagement(ServerManagement, boolean) - Method in interface org.infinispan.server.core.ProtocolServer
-
Sets the
ServerManagement
instance for this protocol server - setServers(Collection<SocketAddress>) - Method in interface org.infinispan.client.hotrod.FailoverRequestBalancingStrategy
-
Inform the strategy about the currently alive servers.
- setSiteName(String) - Method in class org.infinispan.xsite.commands.XSiteStateTransferFinishReceiveCommand
- setSiteName(String) - Method in class org.infinispan.xsite.commands.XSiteStateTransferStartReceiveCommand
- setSitesDown(Collection<String>) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
- setSitesUp(Collection<String>) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
- setSitesView(Collection<String>) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
- setSkipLookup(boolean) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
- setSkipLookup(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
- setSkipLookup(boolean) - Method in class org.infinispan.container.entries.ClearCacheEntry
- setSkipLookup(boolean) - Method in class org.infinispan.container.entries.ForwardingCacheEntry
- setSkipLookup(boolean) - Method in class org.infinispan.container.entries.NullCacheEntry
- setSkipLookup(boolean) - Method in class org.infinispan.container.entries.ReadCommittedEntry
- setSkipLookup(boolean) - Method in class org.infinispan.container.entries.RepeatableReadEntry
- setSkipSharedStore() - Method in interface org.infinispan.container.entries.MVCCEntry
- setSkipSharedStore() - Method in class org.infinispan.container.entries.ReadCommittedEntry
- setSniHostName(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setSocketFactory(SocketFactory) - Method in class org.infinispan.remoting.transport.jgroups.AbstractJGroupsChannelConfigurator
- setSocketFactory(SocketFactory) - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelConfigurator
- setSocketTimeout(int) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setSource(Object) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- setSSLProtocol(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setStackTrace(StackTraceElement[]) - Method in exception org.infinispan.commons.marshall.NotSerializableException
- setStaleStatsThreshold(long) - Method in interface org.infinispan.stats.ClusterContainerStats
- setStaleStatsThreshold(long) - Method in class org.infinispan.stats.impl.ClusterContainerStatsImpl
- setStandalone(Optional<Boolean>) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- setStartAutomatically(boolean) - Method in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
- setStateTransferFlag(Flag) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
- setStateTransferFlag(Flag) - Method in class org.infinispan.transaction.impl.LocalTransaction
- setStateTransferFlag(Flag) - Method in class org.infinispan.transaction.impl.RemoteTransaction
- setStateTransferMode(XSiteStateTransferMode) - Method in class org.infinispan.xsite.statetransfer.RemoteSiteStatus
- setStatisticEnabled(boolean) - Method in class org.infinispan.util.concurrent.ActionSequencer
- setStatistics(boolean) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setStatisticsEnabled(boolean) - Method in class org.infinispan.eviction.impl.ActivationManagerImpl
- setStatisticsEnabled(boolean) - Method in class org.infinispan.eviction.impl.PassivationManagerImpl
- setStatisticsEnabled(boolean) - Method in class org.infinispan.eviction.impl.PassivationManagerStub
- setStatisticsEnabled(boolean) - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
- setStatisticsEnabled(boolean) - Method in interface org.infinispan.jmx.JmxStatisticsExposer
-
Enables an interceptor's cache statistics If true, the interceptor will capture statistics and make them available through the mbean.
- setStatisticsEnabled(boolean) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
-
Deprecated, for removal: This API element is subject to removal in a future version.We already have an attribute, we shouldn't have an operation for the same thing.
- setStatisticsEnabled(boolean) - Method in class org.infinispan.stats.impl.ClusterContainerStatsImpl
- setStatisticsEnabled(boolean) - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
-
Deprecated.
- setStatisticsEnabled(boolean) - Method in class org.infinispan.stats.impl.StatsCollector
- setStatisticsEnabled(boolean) - Method in class org.infinispan.stats.impl.StatsImpl
- setStatisticsEnabled(boolean) - Method in interface org.infinispan.stats.Stats
-
Enables or disables statistics at runtime.
- setStatisticsEnabled(boolean) - Method in class org.infinispan.xsite.irac.DefaultIracManager
- setStatus(int) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfo
-
Sets the transaction's state.
- setStatus(Status, boolean, TimeService) - Method in class org.infinispan.server.hotrod.tx.table.TxState
- setSubgroupsMerged(List<List<Address>>) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
- setSubject(Subject) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
- setSubject(Subject) - Method in interface org.infinispan.rest.framework.RestRequest
- setSubject(Subject) - Method in class org.infinispan.rest.NettyRestRequest
- setSupplier(Supplier<Stream<Original>>) - Method in interface org.infinispan.stream.impl.TerminalOperation
-
Sets the local supplier for the stream.
- setSync(boolean) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
- setTarget(Object) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
- setTaskContext(TaskContext) - Method in interface org.infinispan.tasks.ServerTask
-
Sets the task context Store the value in your task implementation to be able to access caches and other resources in the task Note that, if
Task.getInstantiationMode()
isTaskInstantiationMode.SHARED
there will be single instance of each ServerTask on each server so, if you expect concurrent invocations of a task, theTaskContext
should be stored in aThreadLocal
static field in your task. - setTcpKeepAlive(boolean) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setTcpKeepAlive(boolean) - Method in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
- setTcpKeepAlive(boolean) - Method in class org.infinispan.spring.remote.ConfigurationPropertiesOverrides
- setTcpNoDelay(boolean) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setTcpNoDelay(boolean) - Method in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
- setTcpNoDelay(boolean) - Method in class org.infinispan.spring.remote.ConfigurationPropertiesOverrides
- setterMethod(Class<?>, Class<?>) - Static method in class org.infinispan.commons.util.BeanUtils
-
Returns a Method object corresponding to a setter that sets an instance of componentClass from target.
- setterName(Class<?>) - Static method in class org.infinispan.commons.util.BeanUtils
-
Returns a setter for a given class
- setterName(String) - Static method in class org.infinispan.commons.util.BeanUtils
-
Retrieves a setter name based on a field name passed in
- SetThreadContextClassLoaderAction - Class in org.infinispan.security.actions
-
SetThreadContextClassLoaderAction.
- SetThreadContextClassLoaderAction(Class<?>) - Constructor for class org.infinispan.security.actions.SetThreadContextClassLoaderAction
- SetThreadContextClassLoaderAction(ClassLoader) - Constructor for class org.infinispan.security.actions.SetThreadContextClassLoaderAction
- SetThreadNameAction - Class in org.infinispan.security.actions
-
SetThreadNameAction.
- SetThreadNameAction(String) - Constructor for class org.infinispan.security.actions.SetThreadNameAction
- setTimeout(long, TimeUnit) - Method in class org.infinispan.query.impl.QueryDefinition
- setTimeout(ScheduledExecutorService, long, TimeUnit) - Method in class org.infinispan.remoting.transport.AbstractRequest
-
Schedule a timeout task on the given executor, and complete the request with a
TimeoutException
when the task runs. - setTimeout(ScheduledExecutorService, long, TimeUnit) - Method in class org.infinispan.remoting.transport.jgroups.StaggeredRequest
- setTimer(TimerTracker) - Method in class org.infinispan.commons.stat.DefaultSimpleStat
- setTimer(TimerTracker) - Method in interface org.infinispan.commons.stat.SimpleStat
- setTimer(TimerTracker) - Method in class org.infinispan.commons.stat.SimpleStateWithTimer
- setTimeService(TimeService) - Method in class org.infinispan.util.concurrent.locks.impl.InfinispanLock
-
Tests purpose only!
- settingBooleanQueryMaxClauseCount(String, int) - Method in interface org.infinispan.query.logging.Log
- setToken(String) - Method in class org.infinispan.client.hotrod.security.TokenCallbackHandler
- setTopKValue(int) - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
- setTopologyId(int) - Method in class org.infinispan.commands.AbstractTopologyAffectedCommand
- setTopologyId(int) - Method in interface org.infinispan.commands.TopologyAffectedCommand
- setTopologyId(int) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
- setTopologyId(int) - Method in interface org.infinispan.scattered.ScatteredVersionManager
-
Set current topology id.
- setTracingPropagationEnabled(boolean) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setTransactionId(GlobalTransaction) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 12.0, will be removed in 15.0
- setTransactionMode(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setTransactionOutcome(boolean, GlobalTransaction, boolean) - Method in class org.infinispan.extendedstats.CacheStatisticManager
-
Sets the transaction outcome to commit or rollback, depending if the transaction has commit successfully or not respectively.
- setTransactionSuccessful(boolean) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- setTransactionTimeout(int) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setTransactionTimeout(int) - Method in class org.infinispan.commons.tx.TransactionManagerImpl
- setTransactionTimeout(int) - Method in class org.infinispan.transaction.tm.EmbeddedUserTransaction
- setTransactionTimeout(int) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
- setTransport(Transport) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- setTransportFactory(Class<TransportFactory>) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setTransportFactory(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setTransportFactory(String) - Method in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
-
Deprecated, for removal: This API element is subject to removal in a future version.
- setTransportFactory(String) - Method in class org.infinispan.spring.remote.ConfigurationPropertiesOverrides
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.0. This method has no effect
- setTrustStoreFileName(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setTrustStorePassword(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setTrustStorePath(String) - 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
- setTrustStoreType(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setType(Event.Type) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
- setUnionConsistentHash(ConsistentHash) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- setupConverters() - Method in class org.infinispan.server.core.dataconversion.xml.XStreamEngine
- setUpdatedEntryVersions(Map<Object, IncrementableEntryVersion>) - Method in class org.infinispan.transaction.impl.AbstractCacheTransaction
- setUpdatedEntryVersions(Map<Object, IncrementableEntryVersion>) - Method in interface org.infinispan.transaction.xa.CacheTransaction
- setURI(String) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setUseAuth(boolean) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setUseSSL(boolean) - Method in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- setValue(Object) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
- setValue(Object) - Method in class org.infinispan.container.entries.ImmortalCacheValue
- setValue(Object) - Method in class org.infinispan.container.entries.NullCacheEntry
- setValue(V) - Method in class org.infinispan.commons.util.AbstractMap.SimpleEntry
- setValue(V) - Method in class org.infinispan.commons.util.SimpleImmutableEntry
- setValue(V) - Method in interface org.infinispan.container.entries.CacheEntry
-
Sets the value of the entry, returning the previous value
- setValue(V) - Method in class org.infinispan.container.entries.ClearCacheEntry
- setValue(V) - Method in class org.infinispan.container.entries.ForwardingCacheEntry
- setValue(V) - Method in class org.infinispan.container.entries.ReadCommittedEntry
- setValue(V) - Method in class org.infinispan.container.entries.RepeatableReadEntry
- setValue(V) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- setValue(V) - Method in class org.infinispan.util.EntryWrapper
- setValueConsumer() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- setValueDataConversion(DataConversion) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- setValueIfAbsentReturnBoolean() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- setValueIfAbsentReturnPrevOrNull() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- setValueIfEqualsReturnBoolean(V, MetaParam.Writable...) - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- SetValueIfEqualsReturnBooleanExternalizer() - Constructor for class org.infinispan.marshall.core.MarshallableFunctionExternalizers.SetValueIfEqualsReturnBooleanExternalizer
- setValueIfPresentReturnBoolean() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- setValueIfPresentReturnPrevOrNull() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- setValueMetasConsumer(MetaParam.Writable...) - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- setValueMetasIfAbsentReturnBoolean(MetaParam.Writable...) - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- setValueMetasIfAbsentReturnPrevOrNull(MetaParam.Writable...) - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- setValueMetasIfPresentReturnBoolean(MetaParam.Writable...) - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- setValueMetasIfPresentReturnPrevOrNull(MetaParam.Writable...) - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- setValueMetasReturnPrevOrNull(MetaParam.Writable...) - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- setValueMetasReturnView(MetaParam.Writable...) - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- setValueReturnPrevOrNull() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- setValueReturnView() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- setValueSizeEstimate(int) - 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
- setValueSizeEstimate(int) - Method in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
-
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
- setValueSizeEstimate(int) - Method in class org.infinispan.spring.remote.ConfigurationPropertiesOverrides
-
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
- setValuesTransferTopology(int) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
- setValuesTransferTopology(int) - Method in interface org.infinispan.scattered.ScatteredVersionManager
- setVariables(Map<String, String>) - Method in interface org.infinispan.rest.framework.RestRequest
- setVariables(Map<String, String>) - Method in class org.infinispan.rest.NettyRestRequest
- setVersion(String) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- setVersion(EntryVersion) - Method in interface org.infinispan.container.entries.versioned.Versioned
-
Deprecated.Sets the version on this entry.
- setViewId(int) - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
- setWritable(boolean) - Method in class org.infinispan.io.GridFile
-
Deprecated.
- setWritable(boolean, boolean) - Method in class org.infinispan.io.GridFile
-
Deprecated.
- setWriteConsistentHashAtEnd(ConsistentHash) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- setWriteConsistentHashAtStart(ConsistentHash) - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- setWriteTimeout(long) - Method in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
- setWriteTimeout(long) - Method in class org.infinispan.spring.remote.ConfigurationPropertiesOverrides
- setWriteTimeout(long) - Method in class org.infinispan.spring.remote.provider.SpringRemoteCacheManager
- setXid(XidImpl) - Method in class org.infinispan.commons.tx.TransactionImpl
- setXid(XidImpl) - Method in class org.infinispan.transaction.xa.GlobalTransaction
- setXid(XidImpl) - Method in class org.infinispan.transaction.xa.LocalXaTransaction
- SFSToSIFSConfiguration - Class in org.infinispan.configuration.parsing
- SFSToSIFSConfiguration(AttributeSet, AsyncStoreConfiguration, IndexConfiguration, DataConfiguration) - Constructor for class org.infinispan.configuration.parsing.SFSToSIFSConfiguration
- SFSToSIFSConfigurationBuilder - Class in org.infinispan.configuration.parsing
- SFSToSIFSConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.configuration.parsing.SFSToSIFSConfigurationBuilder
- SFSToSIFSStore<K,
V> - Class in org.infinispan.configuration.parsing -
Store that is used to migrate data from ISPN 12.0 SingleFileStore to an ISPN 13.0 SoftIndexFileStore.
- SFSToSIFSStore() - Constructor for class org.infinispan.configuration.parsing.SFSToSIFSStore
- SHAREABLE - Enum constant in enum org.infinispan.persistence.spi.NonBlockingStore.Characteristic
-
If this store can be shared across multiple Infinispan nodes; for example, an external system such as a database.
- shared() - Element in annotation type org.infinispan.commons.persistence.Store
-
Deprecated.Whether the store can be shared amongst nodes in a distributed/replicated cache
- shared() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- shared() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
- shared(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
-
This setting should be set to true when multiple cache instances share the same cache store (e.g., multiple nodes in a cluster using a JDBC-based CacheStore pointing to the same, shared database.) Setting this to true avoids multiple cache instances writing the same modification multiple times.
- shared(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
- shared(boolean) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
-
This setting should be set to true when multiple cache instances share the same cache store (e.g., multiple nodes in a cluster using a JDBC-based CacheStore pointing to the same, shared database.) Setting this to true avoids multiple cache instances writing the same modification multiple times.
- SHARED - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- SHARED - Enum constant in enum org.infinispan.tasks.TaskInstantiationMode
-
Creates a single instance that is reused for every task execution
- SHARED - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- SHARED_PERSISTENT_LOCATION - Enum constant in enum org.infinispan.configuration.parsing.Element
- sharedPersistenceConfiguration() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
- sharedPersistentLocation() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
-
Returns the filesystem path where shared persistent state data which needs to survive container restarts should be stored.
- sharedPersistentLocation(String) - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
-
Defines the filesystem path where shared persistent state data which needs to survive container restarts should be stored.
- sharedPersistentLocation(String, String) - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
- shortened(String) - Static method in class org.infinispan.factories.KnownComponentNames
- shouldClose() - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelLookup
-
Deprecated.
- shouldConnect() - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelLookup
-
Deprecated.
- shouldDisconnect() - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelLookup
-
Deprecated.
- shouldInvoke(boolean) - Method in enum org.infinispan.notifications.Listener.Observation
- shouldInvoke(CacheEntryEvent<K, V>, boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
- shouldInvoke(Event<K, V>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
- shouldRevoke() - Method in interface org.infinispan.scattered.BiasManager.Revocation
- shouldStopSegments - Variable in class org.infinispan.container.impl.DefaultSegmentedDataContainer
- shouldWrite(long) - Method in interface org.infinispan.persistence.spi.FlagAffectedStore
- show(CommandInvocationId) - Static method in class org.infinispan.commands.CommandInvocationId
- showInDoubtTransactions() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
- shutdown() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- shutdown() - Method in class org.infinispan.cache.impl.CacheImpl
- shutdown() - Method in interface org.infinispan.Cache
-
Performs a controlled, clustered shutdown of the cache.
- shutdown() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
- shutdown() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
- shutdown() - Method in class org.infinispan.configuration.global.GlobalConfiguration
- shutdown() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- shutdown() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Shutdown configuration
- shutdown() - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
- shutdown() - Method in class org.infinispan.executors.LazyInitializingExecutorService
- shutdown() - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
- shutdown() - Method in class org.infinispan.security.impl.SecureCacheImpl
- shutdown() - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- shutdown() - Method in class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
- shutdown() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
- SHUTDOWN - Enum constant in enum org.infinispan.configuration.parsing.Element
- SHUTDOWN_HOOK - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- SHUTDOWN_TIMEOUT - Enum constant in enum org.infinispan.configuration.parsing.Attribute
-
Deprecated, for removal: This API element is subject to removal in a future version.
- shutdownAllCaches() - Method in class org.infinispan.manager.DefaultCacheManager
- shutdownCache() - Method in class org.infinispan.topology.ClusterCacheStatus
- ShutdownConfiguration - Class in org.infinispan.configuration.global
- ShutdownConfigurationBuilder - Class in org.infinispan.configuration.global
- shutdownGracefully() - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- shutdownGracefully(long, long, TimeUnit) - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- shutdownGracefullyAndWait() - Method in class org.infinispan.server.core.transport.NonRecursiveEventLoopGroup
- ShutdownHookBehavior - Enum in org.infinispan.configuration.global
-
Behavior of the JVM shutdown hook registered by the cache
- shutdownNow() - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
- shutdownNow() - Method in class org.infinispan.executors.LazyInitializingExecutorService
- shutdownNow() - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
- shutdownNow() - Method in class org.infinispan.executors.LimitedExecutor
-
Stops the executor and cancels any queued tasks.
- shutdownNow() - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- shutdownNow() - Method in class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
- shutdownNow() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
- SignedNumeric - Class in org.infinispan.commons.io
-
Variable length encoding for signed numbers, using the ZigZag technique
- signedVInt(ByteBuf) - Static method in class org.infinispan.server.hotrod.Intrinsics
- SIMPLE - Enum constant in enum org.infinispan.configuration.cache.VersioningScheme
- SIMPLE_CACHE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- SIMPLE_CACHE - Static variable in class org.infinispan.configuration.cache.Configuration
- SIMPLE_CLUSTERED_VERSION - Static variable in interface org.infinispan.commons.marshall.Ids
- SIMPLE_CLUSTERED_VERSION - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- SIMPLE_COLLECTION_KEY_FILTER - Static variable in interface org.infinispan.commons.marshall.Ids
- SIMPLE_CONNECTION - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
- SIMPLE_PUBLISHER_RESULT - Static variable in interface org.infinispan.commons.marshall.Ids
- simpleCache() - Method in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
- simpleCache() - Method in class org.infinispan.configuration.cache.Configuration
- simpleCache() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- simpleCache() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- simpleCache(boolean) - Method in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
- simpleCache(boolean) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- simpleCache(boolean) - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- SimpleCacheImpl<K,
V> - Class in org.infinispan.cache.impl -
Simple local cache without interceptor stack.
- SimpleCacheImpl(String) - Constructor for class org.infinispan.cache.impl.SimpleCacheImpl
- SimpleCacheImpl.CacheEntryChange<K,
V> - Class in org.infinispan.cache.impl - SimpleCacheImpl.CacheEntrySet - Class in org.infinispan.cache.impl
- SimpleCacheImpl.EntrySet - Class in org.infinispan.cache.impl
- SimpleCacheImpl.EntrySetBase<T extends Map.Entry<K,
V>> - Class in org.infinispan.cache.impl - SimpleCacheImpl.KeySet - Class in org.infinispan.cache.impl
- SimpleCacheImpl.ValueAndMetadata<V> - Class in org.infinispan.cache.impl
- SimpleCacheImpl.Values - Class in org.infinispan.cache.impl
- SimpleClusteredVersion - Class in org.infinispan.container.versioning
-
A simple versioning scheme that is cluster-aware
- SimpleClusteredVersion(int, long) - Constructor for class org.infinispan.container.versioning.SimpleClusteredVersion
- SimpleClusteredVersion.Externalizer - Class in org.infinispan.container.versioning
- SimpleClusteredVersion$___Marshaller_f7402494821fa8e2ee025bf7d4a4b60322db5a0eb2018b6aa5836c002c8e07b7 - Class in org.infinispan.container.versioning
-
WARNING: Generated code! Do not edit!
- SimpleClusteredVersion$___Marshaller_f7402494821fa8e2ee025bf7d4a4b60322db5a0eb2018b6aa5836c002c8e07b7() - Constructor for class org.infinispan.container.versioning.SimpleClusteredVersion$___Marshaller_f7402494821fa8e2ee025bf7d4a4b60322db5a0eb2018b6aa5836c002c8e07b7
- SimpleClusteredVersionGenerator - Class in org.infinispan.container.versioning
-
A version generator implementation for SimpleClusteredVersions
- SimpleClusteredVersionGenerator() - Constructor for class org.infinispan.container.versioning.SimpleClusteredVersionGenerator
- SimpleClusteredVersionGenerator.TopologyIdUpdater - Class in org.infinispan.container.versioning
- simpleConnection() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
- simpleConnection() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationChildBuilder
- simpleConnection() - Method in interface org.infinispan.persistence.jdbc.common.configuration.JdbcStoreConfigurationChildBuilder
-
Configures this JDBC Cache Store to use a single connection to the database
- SimpleConnectionFactoryConfiguration - Class in org.infinispan.persistence.jdbc.common.configuration
-
SimpleConnectionFactoryConfiguration.
- SimpleConnectionFactoryConfigurationBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,
S>> - Class in org.infinispan.persistence.jdbc.common.configuration -
SimpleConnectionFactoryBuilder.
- SimpleConnectionFactoryConfigurationBuilder(AbstractJdbcStoreConfigurationBuilder<?, S>) - Constructor for class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfigurationBuilder
- SimpleGroupPrincipal - Class in org.infinispan.server.core.security.simple
-
SimpleGroupPrincipal.
- SimpleGroupPrincipal(String) - Constructor for class org.infinispan.server.core.security.simple.SimpleGroupPrincipal
- SimpleGroupPrincipal.Externalizer - Class in org.infinispan.server.core.security.simple
- SimpleImmutableEntry<K,
V> - Class in org.infinispan.commons.util -
Where is Java 1.6?
- SimpleImmutableEntry(Map.Entry<K, V>) - Constructor for class org.infinispan.commons.util.SimpleImmutableEntry
- SimpleImmutableEntry(K, V) - Constructor for class org.infinispan.commons.util.SimpleImmutableEntry
- SimpleInstanceAttributeCopier<T> - Class in org.infinispan.commons.configuration.attributes
-
SimpleInstanceAttributeCopier.
- SimplePrincipal(String) - Constructor for class org.infinispan.security.impl.SubjectAdapter.SimplePrincipal
- SimpleRestResponse - Class in org.infinispan.rest.framework.impl
- SimpleRestResponse.Builder - Class in org.infinispan.rest.framework.impl
- SimpleServerAuthenticationProvider - Class in org.infinispan.server.core.security.simple
-
A server authentication handler which maintains a simple map of user names and passwords.
- SimpleServerAuthenticationProvider() - Constructor for class org.infinispan.server.core.security.simple.SimpleServerAuthenticationProvider
- SimpleStat - Interface in org.infinispan.commons.stat
-
A simple statistic recorder that computes the average, minimum and maximum value observed.
- SimpleStateWithTimer - Class in org.infinispan.commons.stat
-
A
SimpleStat
implementation that also updates aTimerTracker
object. - SimpleStateWithTimer() - Constructor for class org.infinispan.commons.stat.SimpleStateWithTimer
- SimpleSubjectUserInfo - Class in org.infinispan.server.core.security.simple
-
SimpleSubjectUserInfo.
- SimpleSubjectUserInfo(String, Subject) - Constructor for class org.infinispan.server.core.security.simple.SimpleSubjectUserInfo
- SimpleSubjectUserInfo(Subject) - Constructor for class org.infinispan.server.core.security.simple.SimpleSubjectUserInfo
- SimpleSubjectUserInfo.Externalizer - Class in org.infinispan.server.core.security.simple
- SimpleUserPrincipal - Class in org.infinispan.server.core.security.simple
-
SimpleUserPrincipal.
- SimpleUserPrincipal(String) - Constructor for class org.infinispan.server.core.security.simple.SimpleUserPrincipal
- since() - Element in annotation type org.infinispan.configuration.parsing.Namespace
-
The first version of the schema where this is supported.
- since(int, int) - Method in interface org.infinispan.commons.configuration.io.ConfigurationSchemaVersion
- since(int, int) - Method in class org.infinispan.configuration.parsing.Schema
- SINGLE_FILE_STORE - Enum constant in enum org.infinispan.configuration.parsing.Element
- SINGLE_HOMED_SERVER_ADDRESS - Static variable in class org.infinispan.server.core.ExternalizerIds
- singleChar() - Method in enum org.infinispan.scattered.ScatteredVersionManager.SegmentState
- SingleFileStore<K,
V> - Class in org.infinispan.persistence.file -
A filesystem-based implementation of a
NonBlockingStore
. - SingleFileStore() - Constructor for class org.infinispan.persistence.file.SingleFileStore
- SingleFileStoreConfiguration - Class in org.infinispan.configuration.cache
-
Defines the configuration for the single file cache store.
- SingleFileStoreConfiguration(AttributeSet, AsyncStoreConfiguration) - Constructor for class org.infinispan.configuration.cache.SingleFileStoreConfiguration
- SingleFileStoreConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Single file cache store configuration builder.
- SingleFileStoreConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
- SingleFileStoreConfigurationBuilder(PersistenceConfigurationBuilder, AttributeSet) - Constructor for class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
- SingleHomedServerAddress - Class in org.infinispan.server.hotrod
-
A Hot Rod server address
- SingleHomedServerAddress(String, int) - Constructor for class org.infinispan.server.hotrod.SingleHomedServerAddress
- SingleKeyNonTxInvocationContext - Class in org.infinispan.context.impl
- SingleKeyNonTxInvocationContext(Address) - Constructor for class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
- singleNodeSubmission() - Method in interface org.infinispan.manager.ClusterExecutor
-
When a command is submitted it will only be submitted to one node of the available nodes, there is no strict requirements as to which node is chosen and is implementation specific.
- singleNodeSubmission(int) - Method in interface org.infinispan.manager.ClusterExecutor
-
When a command is submitted it will only be submitted to one node of the available nodes, there is no strict requirements as to which node is chosen and is implementation specific.
- singleNodeSubmissionExecutor(Predicate<? super Address>, EmbeddedCacheManager, Transport, long, TimeUnit, Executor, ScheduledExecutorService, int) - Static method in class org.infinispan.manager.impl.ClusterExecutors
- SingleResponseCollector - Class in org.infinispan.remoting.transport.impl
-
Response collector for a single response.
- SingleResponseCollector() - Constructor for class org.infinispan.remoting.transport.impl.SingleResponseCollector
- singleSegment(int, Publisher<? extends E>) - Static method in class org.infinispan.persistence.support.SingleSegmentPublisher
- singleSegment(Publisher<? extends E>) - Static method in class org.infinispan.persistence.support.SingleSegmentPublisher
- SingleSegmentKeyPartitioner - Class in org.infinispan.distribution.ch.impl
-
KeyPartitioner that always returns 0 for a given segment.
- SingleSegmentPublisher<E> - Class in org.infinispan.persistence.support
- SingleSiteRequest<T> - Class in org.infinispan.remoting.transport.jgroups
-
Request implementation that waits for a response from a single target site.
- SingleTargetRequest<T> - Class in org.infinispan.remoting.transport.impl
-
Request implementation that waits for a response from a single target node.
- SingleTargetRequest(ResponseCollector<T>, long, RequestRepository, RequestTracker) - Constructor for class org.infinispan.remoting.transport.impl.SingleTargetRequest
- SINGLETON - Enum constant in enum org.infinispan.configuration.parsing.Attribute
-
Deprecated, for removal: This API element is subject to removal in a future version.
- SingletonExternalizer<T> - Class in org.infinispan.commons.marshall
- SingletonExternalizer(Integer, T) - Constructor for class org.infinispan.commons.marshall.SingletonExternalizer
- SingletonMapResponseCollector - Class in org.infinispan.remoting.transport.impl
- site() - Method in class org.infinispan.configuration.cache.BackupConfiguration
-
Returns the name of the site where this cache backups its data.
- site() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
- site() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
- site() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- site() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Cross-site replication configuration
- site(String) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
- SITE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- SITE - Enum constant in enum org.infinispan.configuration.parsing.Element
- SITE - Enum constant in enum org.infinispan.distribution.topologyaware.TopologyLevel
- SITE - Static variable in class org.infinispan.configuration.cache.BackupConfiguration
- SITE_CONNECTED - Enum constant in enum org.infinispan.xsite.events.XSiteEventType
-
Sent from site A to site B, notifies site B that a new connection to A is available.
- SITE_EVENT - Static variable in class org.infinispan.xsite.commands.remote.Ids
- SITE_ID - Static variable in class org.infinispan.configuration.global.TransportConfiguration
- SITE_TAG_NAME - Static variable in interface org.infinispan.metrics.Constants
- SiteAddress - Class in org.infinispan.remoting.transport
-
Implementation
Address
that contains the site name. - SiteAddress(String) - Constructor for class org.infinispan.remoting.transport.SiteAddress
- SiteConfiguration - Class in org.infinispan.configuration.global
-
Deprecated, for removal: This API element is subject to removal in a future version.since 11.0. Use
Transport.localSiteName()
- SiteConfigurationBuilder - Class in org.infinispan.configuration.global
-
Deprecated, for removal: This API element is subject to removal in a future version.since 11.0. The local site name is fetched via
Transport.localSiteName()
- SiteEntry<V> - Class in org.infinispan.xsite.spi
-
It stores the entry value and
Metadata
for a specific site. - SiteEntry(String, V, Metadata) - Constructor for class org.infinispan.xsite.spi.SiteEntry
- siteId() - Method in class org.infinispan.configuration.global.TransportConfiguration
- siteId(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
-
The id of the site where this node runs.
- siteOffline() - Method in interface org.infinispan.xsite.notification.SiteStatusListener
- siteOnline() - Method in interface org.infinispan.xsite.notification.SiteStatusListener
- siteOperationFailed(String, String) - Method in interface org.infinispan.rest.logging.Log
- sites() - Method in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
- sites() - Method in class org.infinispan.configuration.cache.Configuration
- sites() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- sites() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- sites() - Method in class org.infinispan.configuration.global.GlobalConfiguration
- sites() - Method in class org.infinispan.xsite.metrics.DefaultXSiteMetricsCollector
- sites() - Method in class org.infinispan.xsite.metrics.NoOpXSiteMetricsCollector
- sites() - Method in interface org.infinispan.xsite.metrics.XSiteMetricsCollector
- SITES - Enum constant in enum org.infinispan.configuration.parsing.Element
- SITES_VIEW_CHANGED - Enum constant in enum org.infinispan.notifications.cachemanagerlistener.event.Event.Type
- SitesConfiguration - Class in org.infinispan.configuration.cache
- SitesConfiguration(AttributeSet, List<BackupConfiguration>, BackupForConfiguration) - Constructor for class org.infinispan.configuration.cache.SitesConfiguration
- SitesConfigurationBuilder - Class in org.infinispan.configuration.cache
- SitesConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.SitesConfigurationBuilder
- SiteState - Enum in org.infinispan.xsite.status
-
The site state.
- SiteStatus - Interface in org.infinispan.xsite.status
-
A site status.
- SiteStatusListener - Interface in org.infinispan.xsite.notification
-
A simple interface that is invoked by
OfflineStatus
when a particular site changes its status to online/offline. - sitesUnreachable(String) - Method in class org.infinispan.remoting.transport.jgroups.SingleSiteRequest
- SitesViewChangedEvent - Interface in org.infinispan.notifications.cachemanagerlistener.event
-
This event is passed in to any method annotated with
SiteViewChanged
. - SiteUnreachableXSiteResponse<T> - Class in org.infinispan.remoting.transport.impl
-
A
XSiteResponse
which is competed with aSuspectException
. - SiteUnreachableXSiteResponse(XSiteBackup, TimeService) - Constructor for class org.infinispan.remoting.transport.impl.SiteUnreachableXSiteResponse
- SiteViewChanged - Annotation Type in org.infinispan.notifications.cachemanagerlistener.annotation
-
This annotation should be used on methods that need to be notified when the cross-site view changes (sites connects or disconnects).
- size - Variable in class org.infinispan.commons.util.ArrayMap
- size() - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
- size() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- size() - Method in class org.infinispan.cache.impl.CacheImpl
- size() - Method in class org.infinispan.cache.impl.DecoratedCache
- size() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySetBase
- size() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.KeySet
- size() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- size() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.Values
- size() - Method in interface org.infinispan.Cache
-
Returns a count of all elements in this cache and cache loader across the entire cluster.
- size() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- size() - Method in class org.infinispan.client.hotrod.impl.ServerStatisticsImpl
- size() - Method in interface org.infinispan.client.hotrod.near.NearCache
- size() - Method in class org.infinispan.client.hotrod.near.NearCacheService
- size() - Method in class org.infinispan.commons.io.ExposedByteArrayOutputStream
-
Deprecated.Overriden only to avoid unneeded synchronization
- size() - Method in class org.infinispan.commons.io.LazyByteArrayOutputStream
-
Overriden only to avoid unneeded synchronization
- size() - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
- size() - Method in class org.infinispan.commons.util.AbstractDelegatingMap
- size() - Method in class org.infinispan.commons.util.ArrayMap
- size() - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
- size() - Method in class org.infinispan.commons.util.FastCopyHashMap.EntrySet
- size() - Method in class org.infinispan.commons.util.FastCopyHashMap.KeySet
- size() - Method in class org.infinispan.commons.util.FastCopyHashMap
- size() - Method in class org.infinispan.commons.util.FastCopyHashMap.Values
- size() - Method in class org.infinispan.commons.util.ForwardingList
- size() - Method in class org.infinispan.commons.util.ImmutableHopscotchHashSet
- size() - Method in class org.infinispan.commons.util.ImmutableIntSet
-
Deprecated.
- size() - Method in class org.infinispan.commons.util.ImmutableListCopy.ImmutableSubList
- size() - Method in class org.infinispan.commons.util.ImmutableListCopy
- size() - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- size() - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- size() - Method in class org.infinispan.commons.util.WeakValueHashMap
- size() - 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()
orMemoryConfiguration.maxSize()
to obtain either the maximum number of entries or the maximum size of the data container. - size() - 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 either
MemoryConfigurationBuilder.maxSize()
orMemoryConfigurationBuilder.maxCount()
. - size() - Method in class org.infinispan.configuration.cache.MemoryStorageConfiguration
-
Deprecated.
- size() - Method in interface org.infinispan.container.DataContainer
- size() - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- size() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- size() - Method in class org.infinispan.container.versioning.irac.DefaultIracTombstoneManager
- size() - Method in interface org.infinispan.container.versioning.irac.IracTombstoneManager
- size() - Method in class org.infinispan.container.versioning.irac.NoOpIracTombstoneManager
- size() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
-
Returns the size of the read only set.
- size() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
-
Returns the size of the read only map.
- size() - Method in class org.infinispan.functional.impl.MetaParams
- size() - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
-
Returns the number of interceptors in the chain.
- size() - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
- size() - Method in class org.infinispan.InternalCacheSet
- size() - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
-
Deprecated.Overriden only to avoid unneeded synchronization
- size() - Method in class org.infinispan.io.ImmutableMarshalledValueByteStream
-
Deprecated.
- size() - Method in class org.infinispan.io.MarshalledValueByteStream
-
Deprecated.
- size() - Method in class org.infinispan.io.ReadableGridFileChannel
-
Deprecated.
- size() - Method in interface org.infinispan.multimap.api.BasicMultimapCache
-
Returns the number of key-value pairs in this multimap cache.
- size() - Method in class org.infinispan.multimap.impl.Bucket
- size() - Method in class org.infinispan.multimap.impl.EmbeddedMultimapCache
- size() - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader
-
Deprecated.Returns the number of elements in the store.
- size() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfiguration
- size() - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- size() - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- size() - Method in class org.infinispan.rest.ByteBufContentSource
- size() - Method in interface org.infinispan.rest.framework.ContentSource
- size() - Method in class org.infinispan.security.impl.SecureCacheImpl
- size() - Method in class org.infinispan.transaction.impl.ModificationList
- size() - Method in class org.infinispan.util.CollectionMapper
- size() - Method in interface org.infinispan.util.concurrent.locks.impl.LockContainer
- size() - Method in class org.infinispan.util.concurrent.locks.impl.PerKeyLockContainer
- size() - Method in class org.infinispan.util.concurrent.locks.impl.StripedLockContainer
- size(long) - 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(long)
orMemoryConfiguration.maxSize(String)
to dynamically configure the maximum number of entries or the maximum size of the data container. - size(long) - 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.maxSize(String)
to define the size in bytes orMemoryConfigurationBuilder.maxCount(long)
to define the number of entries. - size(long) - Method in class org.infinispan.configuration.cache.MemoryStorageConfiguration
-
Deprecated.
- size(String) - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfigurationBuilder
-
Configures the size statement to be used when determining the size of the store.
- size(Connection) - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
- size(Connection) - Method in interface org.infinispan.persistence.jdbc.common.TableOperations
- size(Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- size(Predicate<? super StoreConfiguration>, IntSet) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- size(IntSet) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- size(IntSet) - Method in interface org.infinispan.container.impl.InternalDataContainer
-
Returns how many entries are present in the data container that map to the given segments without counting entries that are currently expired.
- size(IntSet) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- size(IntSet) - Method in class org.infinispan.persistence.async.AsyncNonBlockingStore
- size(IntSet) - Method in class org.infinispan.persistence.file.SingleFileStore
- size(IntSet) - Method in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
- size(IntSet) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- size(IntSet) - Method in class org.infinispan.persistence.remote.RemoteStore
- size(IntSet) - Method in class org.infinispan.persistence.rocksdb.RocksDBStore
- size(IntSet) - Method in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
- size(IntSet) - Method in interface org.infinispan.persistence.spi.NonBlockingStore
-
Returns the amount of entries that map to the given segments in the store.
- size(IntSet) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
-
Deprecated.Returns the number of elements in the store that map to the given segments that aren't expired.
- size(IntSet) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- size(IntSet) - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
- size(IntSet) - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
- SIZE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- SIZE - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
- SIZE - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
- SIZE - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- SIZE - Static variable in class org.infinispan.configuration.cache.MemoryStorageConfiguration
-
Deprecated.
- SIZE - Static variable in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfiguration
- SIZE_MULTIMAP - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- SIZE_MULTIMAP_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- SIZE_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- SIZE_UNAVAILABLE_FUTURE - Static variable in interface org.infinispan.persistence.spi.NonBlockingStore
-
Shortcut to return -1L when the size or approximate size is unavailable.
- sizeAsync() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- sizeAsync() - Method in class org.infinispan.cache.impl.CacheImpl
- sizeAsync() - Method in class org.infinispan.cache.impl.DecoratedCache
- sizeAsync() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- sizeAsync() - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- sizeAsync() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- sizeAsync() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheSupport
- sizeAsync() - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
Map.size()
. - sizeAsync() - Method in class org.infinispan.security.impl.SecureCacheImpl
- sizeCalculationInterrupted(InterruptedException) - Method in interface org.infinispan.persistence.sifs.Log
- SizeCalculatorFactory - Class in org.infinispan.factories
-
Factory for creating size calculator used to estimate size of objects
- SizeCalculatorFactory() - Constructor for class org.infinispan.factories.SizeCalculatorFactory
- sizeCannotHaveParameters(String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- sizeEstimate(Object) - Method in interface org.infinispan.commons.marshall.StreamAwareMarshaller
-
An method that provides an estimate of the buffer size that will be required once the object has been marshalled.
- sizeIncludingExpired() - Method in interface org.infinispan.container.DataContainer
- sizeIncludingExpired() - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- sizeIncludingExpired() - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
- sizeIncludingExpired() - Method in class org.infinispan.container.impl.DefaultDataContainer
- sizeIncludingExpired() - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
- sizeIncludingExpired() - Method in class org.infinispan.container.offheap.OffHeapDataContainer
- sizeIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- sizeIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
- sizeIncludingExpired(IntSet) - Method in interface org.infinispan.container.impl.InternalDataContainer
-
Returns how many entries are present in the data container that map to the given segments including any entries that may be expired
- sizeIncludingExpired(IntSet) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- sizePublisher(IntSet, long) - Method in interface org.infinispan.reactive.publisher.impl.LocalPublisherManager
- sizePublisher(IntSet, long) - Method in class org.infinispan.reactive.publisher.impl.LocalPublisherManagerImpl
- sizePublisher(IntSet, InvocationContext, long) - Method in interface org.infinispan.reactive.publisher.impl.ClusterPublisherManager
- sizePublisher(IntSet, InvocationContext, long) - Method in class org.infinispan.reactive.publisher.impl.ClusterPublisherManagerImpl
- sizePublisher(IntSet, InvocationContext, long) - Method in class org.infinispan.reactive.publisher.impl.LocalClusterPublisherManagerImpl
- sizeUnsignedInt(int) - Static method in class org.infinispan.commons.io.UnsignedNumeric
- skip() - Method in interface org.infinispan.search.mapper.mapping.EntityConverter.ConvertedEntity
- skip(long) - Method in interface org.infinispan.CacheStream
- skip(long) - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- skip(long) - Method in interface org.infinispan.DoubleCacheStream
- skip(long) - Method in interface org.infinispan.IntCacheStream
- skip(long) - Method in class org.infinispan.io.GridInputStream
-
Deprecated.
- skip(long) - Method in class org.infinispan.io.UnclosableObjectInputStream
-
Deprecated.
- skip(long) - Method in interface org.infinispan.LongCacheStream
- skip(long) - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
- skip(long) - Method in class org.infinispan.stream.impl.DistributedCacheStream
- skip(long) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- skip(long) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- skip(long) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- skip(long) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- skip(long) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- skip(long) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- skip(long) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- skip(long) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- SKIP - Enum constant in enum org.infinispan.functional.Param.LockingMode
- SKIP - Enum constant in enum org.infinispan.functional.Param.PersistenceMode
- SKIP - Enum constant in enum org.infinispan.functional.Param.StatisticsMode
-
Statistics from this command are not recorded
- SKIP_CACHE_LOAD - Enum constant in enum org.infinispan.client.hotrod.Flag
-
Skips loading an entry from any configured
CacheLoader
s. - SKIP_CACHE_LOAD - Enum constant in enum org.infinispan.context.Flag
-
Skips loading an entry from any configured
CacheLoader
s. - SKIP_CACHE_LOAD - Static variable in class org.infinispan.context.impl.FlagBitSets
- SKIP_CACHE_STORE - Enum constant in enum org.infinispan.context.Flag
-
Skips storing an entry to any configured
CacheLoader
s. - SKIP_CACHE_STORE - Static variable in class org.infinispan.context.impl.FlagBitSets
- SKIP_INDEX_CLEANUP - Enum constant in enum org.infinispan.context.Flag
-
Any time a new indexed entry is inserted, a delete statement is issued on the indexes to remove previous values.
- SKIP_INDEX_CLEANUP - Static variable in class org.infinispan.context.impl.FlagBitSets
- SKIP_INDEXING - Enum constant in enum org.infinispan.client.hotrod.Flag
-
Used by the Query module only, it will prevent the indexes to be updated as a result of the current operations.
- SKIP_INDEXING - Enum constant in enum org.infinispan.context.Flag
-
Used by the Query module only, it will prevent the indexes to be updated as a result of the current operations.
- SKIP_INDEXING - Static variable in class org.infinispan.context.impl.FlagBitSets
- SKIP_LISTENER_NOTIFICATION - Enum constant in enum org.infinispan.client.hotrod.Flag
-
It will skip client listeners to be notified.
- SKIP_LISTENER_NOTIFICATION - Enum constant in enum org.infinispan.context.Flag
-
This flag skips listener notifications as a result of a cache operation.
- SKIP_LISTENER_NOTIFICATION - Static variable in class org.infinispan.context.impl.FlagBitSets
- SKIP_LOAD - Enum constant in enum org.infinispan.functional.Param.PersistenceMode
- SKIP_LOCKING - Enum constant in enum org.infinispan.context.Flag
-
Bypasses lock acquisition for this invocation altogether.
- SKIP_LOCKING - Static variable in class org.infinispan.context.impl.FlagBitSets
- SKIP_LOOKUP - Enum constant in enum org.infinispan.container.entries.ReadCommittedEntry.Flags
- SKIP_OWNERSHIP_CHECK - Enum constant in enum org.infinispan.context.Flag
-
Ignore current consistent hash and read from data container/commit the change no matter what (if the flag is set).
- SKIP_OWNERSHIP_CHECK - Static variable in class org.infinispan.context.impl.FlagBitSets
- SKIP_OWNERSHIP_FLAGS - Static variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
- SKIP_PERSIST - Enum constant in enum org.infinispan.functional.Param.PersistenceMode
- SKIP_REMOTE_LOOKUP - Enum constant in enum org.infinispan.context.Flag
-
When used with distributed cache mode, will prevent retrieving a remote value either when executing a
Map.get(Object)
orMap.containsKey(Object)
, or to return the overwritten value forBasicCache.put(Object, Object)
orBasicCache.remove(Object)
. - SKIP_REMOTE_LOOKUP - Static variable in class org.infinispan.context.impl.FlagBitSets
- SKIP_SHARED_CACHE_STORE - Enum constant in enum org.infinispan.context.Flag
-
If this flag is enabled, if a cache store is shared, then storage to the store is skipped.
- SKIP_SHARED_CACHE_STORE - Static variable in class org.infinispan.context.impl.FlagBitSets
- SKIP_SHARED_STORE - Enum constant in enum org.infinispan.container.entries.ReadCommittedEntry.Flags
- SKIP_SIZE_OPTIMIZATION - Enum constant in enum org.infinispan.context.Flag
-
Flag that can be used to skip any size optimizations - forcing iteration of entries to count.
- SKIP_SIZE_OPTIMIZATION - Static variable in class org.infinispan.context.impl.FlagBitSets
- SKIP_STATISTICS - Enum constant in enum org.infinispan.context.Flag
-
This flag skips statistics updates as a result of a cache operation.
- SKIP_STATISTICS - Static variable in class org.infinispan.context.impl.FlagBitSets
- SKIP_XSITE_BACKUP - Enum constant in enum org.infinispan.context.Flag
-
If cross-site replication is enabled, this would skip the replication to any remote site.
- SKIP_XSITE_BACKUP - Static variable in class org.infinispan.context.impl.FlagBitSets
- skipBytes(int) - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- skipBytes(int) - Method in class org.infinispan.io.UnclosableObjectInputStream
-
Deprecated.
- skipBytes(int) - Method in class org.infinispan.marshall.core.AbstractBytesObjectInput
- SkipCacheLoader - Enum constant in enum org.infinispan.server.hotrod.ProtocolFlag
- SkipIndexing - Enum constant in enum org.infinispan.server.hotrod.ProtocolFlag
- SkipListenerNotification - Enum constant in enum org.infinispan.server.hotrod.ProtocolFlag
- skipLookup() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
- skipLookup() - Method in interface org.infinispan.container.entries.CacheEntry
- skipLookup() - Method in class org.infinispan.container.entries.ClearCacheEntry
- skipLookup() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
- skipLookup() - Method in class org.infinispan.container.entries.NullCacheEntry
- skipLookup() - Method in class org.infinispan.container.entries.ReadCommittedEntry
- skipLookup() - Method in class org.infinispan.container.entries.RepeatableReadEntry
- skipPassivationOnStop(boolean) - Method in interface org.infinispan.eviction.impl.PassivationManager
-
Skips the passivation when the cache is stopped.
- skipPassivationOnStop(boolean) - Method in class org.infinispan.eviction.impl.PassivationManagerImpl
- skipPassivationOnStop(boolean) - Method in class org.infinispan.eviction.impl.PassivationManagerStub
- skippingMarshallerWrapping(String) - Method in interface org.infinispan.server.hotrod.logging.Log
- skipS(char) - Method in class org.infinispan.commons.configuration.io.xml.MXParser
- skipSubTree() - Method in class org.infinispan.commons.configuration.io.xml.MXParser
-
Skip sub tree that is currently parser positioned on.
- SmallIntSet - Class in org.infinispan.commons.util
-
Deprecated, for removal: This API element is subject to removal in a future version.since 9.3 This class will no longer be public. Please use
IntSets
methods such asIntSets.mutableEmptySet()
,IntSets.mutableCopyFrom(Set)
- SmallIntSet() - Constructor for class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- SmallIntSet(int) - Constructor for class org.infinispan.commons.util.SmallIntSet
-
Deprecated.Create a new
IntSet
and pre-allocate space for elements0..initialRange-1
. - SmallIntSet(Set<Integer>) - Constructor for class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- SNAKE_CASE - Enum constant in enum org.infinispan.commons.configuration.io.NamingStrategy
- SNAPPY - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.CompressionType
- snapshot(R) - Static method in class org.infinispan.functional.impl.EntryViews
-
For convenience, a lambda might decide to return the entry view it received as parameter, because that makes easy to return both value and meta parameters back to the client.
- SNI - Enum constant in enum org.infinispan.server.hotrod.configuration.Element
- SNI_HOST_NAME - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- SNI_HOSTNAME - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- SniConfiguration - Class in org.infinispan.server.core.configuration
- SniConfigurationBuilder - Class in org.infinispan.server.core.configuration
- sniConfigurations() - Method in class org.infinispan.server.core.configuration.EncryptionConfiguration
- sniDomainsConfiguration() - Method in class org.infinispan.server.core.configuration.SslConfiguration
- sniHostName() - Method in class org.infinispan.client.hotrod.configuration.ClusterConfiguration
- sniHostName() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
- sniHostName() - Method in class org.infinispan.persistence.remote.configuration.SslConfiguration
- sniHostName(String) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
-
Specifies the TLS SNI hostname for the connection
- sniHostName(String) - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
-
Specifies the TLS SNI hostname for the connection
- sniHostName(String) - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
-
Returns SNI domain configuration.
- sniHostName(String) - Method in interface org.infinispan.server.core.configuration.SslConfigurationChildBuilder
- sniHostName(String) - Method in class org.infinispan.server.core.configuration.SslEngineConfigurationBuilder
- SO_TIMEOUT - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- SOCKET_BINDING - Enum constant in enum org.infinispan.server.hotrod.configuration.Attribute
- SOCKET_BINDING - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- SOCKET_FACTORY - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- SOCKET_TIMEOUT - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- socketBinding() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- socketBinding() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- socketBinding(String) - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
- socketBinding(String) - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- socketBinding(String) - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
-
Indicates the name of socket binding which will be used
- socketChannelClass() - Method in interface org.infinispan.client.hotrod.TransportFactory
-
Returns the Netty
SocketChannel
class to use in the transport. - socketTimeout() - Method in class org.infinispan.client.hotrod.configuration.Configuration
- socketTimeout() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
- socketTimeout(int) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
- socketTimeout(int) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- socketTimeout(int) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
-
This property defines the maximum socket read timeout in milliseconds before giving up waiting for bytes from the server.
- socketTimeout(long) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- socketTimeout(long) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- socketTimeout(long) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
-
This property defines the maximum socket read timeout in milliseconds before giving up waiting for bytes from the server.
- SoftIndexFileStoreConfiguration - Class in org.infinispan.persistence.sifs.configuration
- SoftIndexFileStoreConfiguration(AttributeSet, AsyncStoreConfiguration, IndexConfiguration, DataConfiguration) - Constructor for class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfiguration
- SoftIndexFileStoreConfigurationBuilder - Class in org.infinispan.persistence.sifs.configuration
- SoftIndexFileStoreConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
- SoftIndexFileStoreConfigurationBuilder(PersistenceConfigurationBuilder, AttributeSet, AttributeSet) - Constructor for class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
- SOLARIS - Enum constant in enum org.infinispan.commons.util.OS
- sort() - Method in class org.infinispan.search.mapper.scope.impl.SearchScopeImpl
- sort() - Method in interface org.infinispan.search.mapper.scope.SearchScope
-
Initiate the building of a search sort.
- sorted() - Method in interface org.infinispan.CacheStream
- sorted() - Method in interface org.infinispan.DoubleCacheStream
- sorted() - Method in interface org.infinispan.IntCacheStream
- sorted() - Method in interface org.infinispan.LongCacheStream
- sorted() - Method in class org.infinispan.stream.impl.DistributedCacheStream
- sorted() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- sorted() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- sorted() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- sorted() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- sorted() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- sorted() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- sorted() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- sorted() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- sorted(Comparator<? super R>) - Method in interface org.infinispan.CacheStream
- sorted(Comparator<? super R>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
- sorted(Comparator<? super R>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- sorted(Comparator<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- sorted(SerializableComparator<? super R>) - Method in interface org.infinispan.CacheStream
-
Same as
CacheStream.sorted(Comparator)
except that the Comparator must also implementSerializable
- SortField - Interface in org.infinispan.objectfilter
-
Sort specification for a field.
- SortOrder - Enum in org.infinispan.query.dsl
-
Deprecated.since 10.1. See deprecation note on
QueryBuilder
. - SP - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- SPIN_DURATION - Enum constant in enum org.infinispan.configuration.parsing.Attribute
-
Deprecated, for removal: This API element is subject to removal in a future version.
- spliterator - Variable in class org.infinispan.commons.util.SpliteratorMapper
- spliterator() - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
- spliterator() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntrySet
- spliterator() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySet
- spliterator() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.KeySet
- spliterator() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.Values
- spliterator() - Method in interface org.infinispan.CacheStream
- spliterator() - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
- spliterator() - Method in interface org.infinispan.commons.util.CloseableIteratorCollection
- spliterator() - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
- spliterator() - Method in interface org.infinispan.commons.util.CloseableIteratorSet
- spliterator() - Method in class org.infinispan.commons.util.CloseableIteratorSetAdapter
- spliterator() - Method in interface org.infinispan.container.DataContainer
- spliterator() - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- spliterator() - Method in class org.infinispan.container.impl.DefaultDataContainer
- spliterator() - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
- spliterator() - Method in class org.infinispan.container.offheap.OffHeapDataContainer
- spliterator() - Method in class org.infinispan.functional.impl.MetaParams
- spliterator() - Method in class org.infinispan.InternalCacheSet
- spliterator() - Method in interface org.infinispan.LockedStream
-
This method is not supported when using a
LockedStream
- spliterator() - Method in class org.infinispan.stream.impl.DistributedCacheStream
- spliterator() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- spliterator() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- spliterator() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- spliterator() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- spliterator() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- spliterator() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- spliterator() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- spliterator() - Method in class org.infinispan.stream.impl.LockedStreamImpl
- spliterator() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- spliterator() - Method in class org.infinispan.util.CacheSetMapper
- spliterator() - Method in class org.infinispan.util.CollectionMapper
- spliterator() - Method in class org.infinispan.util.WriteableCacheCollectionMapper
- spliterator(Spliterator<T>) - Static method in class org.infinispan.commons.util.Closeables
-
Creates a closeable spliterator from the given spliterator that does nothing when close is called.
- spliterator(BaseStream<R, Stream<R>>) - Static method in class org.infinispan.commons.util.Closeables
-
Creates a closeable spliterator that when closed will close the underlying stream as well
- spliterator(CloseableIterator<? extends E>, long, int) - Static method in class org.infinispan.commons.util.Closeables
-
Takes a provided closeable iterator and wraps it appropriately so it can be used as a closeable spliterator that will close the iterator when the spliterator is closed.
- spliterator(IntSet) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- spliterator(IntSet) - Method in class org.infinispan.container.impl.DefaultDataContainer
- spliterator(IntSet) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
- spliterator(IntSet) - Method in interface org.infinispan.container.impl.InternalDataContainer
-
Same as
DataContainer.spliterator()
except that only entries that map to the provided segments are returned via this spliterator. - spliterator(IntSet) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- spliterator(IntSet) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
- spliteratorIncludingExpired() - Method in interface org.infinispan.container.DataContainer
-
Same as
DataContainer.spliterator()
except that is also returns expired entries. - spliteratorIncludingExpired() - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- spliteratorIncludingExpired() - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
- spliteratorIncludingExpired() - Method in class org.infinispan.container.impl.DefaultDataContainer
- spliteratorIncludingExpired() - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
- spliteratorIncludingExpired() - Method in class org.infinispan.container.impl.L1SegmentedDataContainer
- spliteratorIncludingExpired() - Method in class org.infinispan.container.offheap.OffHeapDataContainer
- spliteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- spliteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.BoundedSegmentedDataContainer
- spliteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.DefaultDataContainer
- spliteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
- spliteratorIncludingExpired(IntSet) - Method in interface org.infinispan.container.impl.InternalDataContainer
-
Same as
DataContainer.spliteratorIncludingExpired()
except that only entries that map to the provided segments are returned via this spliterator. - spliteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.impl.L1SegmentedDataContainer
- spliteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- spliteratorIncludingExpired(IntSet) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
- SpliteratorMapper<E,
S> - Class in org.infinispan.commons.util -
A spliterator that has been mapped from another spliterator.
- SpliteratorMapper(Spliterator<E>, Function<? super E, ? extends S>) - Constructor for class org.infinispan.commons.util.SpliteratorMapper
- SPRING_JAVA_SERIAL_ALLOWLIST - Static variable in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
- SPRING_LOWER_BOUND - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- SPRING_NULL_VALUE - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
-
Deprecated, for removal: This API element is subject to removal in a future version.
- SPRING_SESSION - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- SPRING_SESSION_ATTRIBUTE - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- SPRING_SESSION_REMAP - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- SpringCache - Class in org.infinispan.spring.common.provider
-
A
implementation that delegates to aCache
instance supplied at construction time.org.infinispan.Cache
- SpringCache(BasicCache) - Constructor for class org.infinispan.spring.common.provider.SpringCache
- SpringCache(BasicCache, long, long) - Constructor for class org.infinispan.spring.common.provider.SpringCache
- SpringEmbeddedCacheManager - Class in org.infinispan.spring.embedded.provider
-
A
implementation that is backed by anCacheManager
instance.Infinispan EmbeddedCacheManager
- SpringEmbeddedCacheManager(EmbeddedCacheManager) - Constructor for class org.infinispan.spring.embedded.provider.SpringEmbeddedCacheManager
- SpringEmbeddedCacheManagerFactoryBean - Class in org.infinispan.spring.embedded.provider
-
A
for creating anFactoryBean
instance.SpringEmbeddedCacheManager
- SpringEmbeddedCacheManagerFactoryBean() - Constructor for class org.infinispan.spring.embedded.provider.SpringEmbeddedCacheManagerFactoryBean
- SpringEmbeddedModule - Class in org.infinispan.spring.embedded
-
Add support for Spring-specific classes like
NullValue
in embedded caches. - SpringEmbeddedModule() - Constructor for class org.infinispan.spring.embedded.SpringEmbeddedModule
- springEventsPublisher - Variable in class org.infinispan.spring.common.session.AbstractApplicationPublisherBridge
- SpringRemoteCacheManager - Class in org.infinispan.spring.remote.provider
-
A
implementation that is backed by anCacheManager
instance.Infinispan RemoteCacheManager
- SpringRemoteCacheManager(RemoteCacheManager) - Constructor for class org.infinispan.spring.remote.provider.SpringRemoteCacheManager
- SpringRemoteCacheManager(RemoteCacheManager, long, long) - Constructor for class org.infinispan.spring.remote.provider.SpringRemoteCacheManager
- SpringRemoteCacheManagerFactoryBean - Class in org.infinispan.spring.remote.provider
-
A
for creating anFactoryBean
instance.SpringRemoteCacheManager
- SpringRemoteCacheManagerFactoryBean() - Constructor for class org.infinispan.spring.remote.provider.SpringRemoteCacheManagerFactoryBean
- SQL_SERVER - Enum constant in enum org.infinispan.persistence.jdbc.common.DatabaseType
- sqlFailureClosingConnection(Connection, SQLException) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- sqlFailureDeletingBatch(Iterable<Object>, Exception) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- sqlFailureIntegratingState(SQLException) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- sqlFailureMetaRetrieval(SQLException) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- sqlFailureReadingKey(Object, Object, SQLException) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- sqlFailureRemovingKeys(SQLException) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- sqlFailureRetrievingConnection(SQLException) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- sqlFailureSize(SQLException) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- sqlFailureStoringKey(Object, SQLException) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- sqlFailureTxCommit(SQLException) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- sqlFailureTxRollback(SQLException) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- sqlFailureUnexpected(SQLException) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- sqlFailureWritingBatch(Throwable) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- SQLITE - Enum constant in enum org.infinispan.persistence.jdbc.common.DatabaseType
- SqlManager - Interface in org.infinispan.persistence.jdbc.common
- sqlMetadataNotPresent(String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- SqlStoreConfigurationParser - Class in org.infinispan.persistence.sql.configuration
- SqlStoreConfigurationParser() - Constructor for class org.infinispan.persistence.sql.configuration.SqlStoreConfigurationParser
- ssl - Variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- ssl - Variable in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- ssl() - Method in class org.infinispan.client.hotrod.configuration.AbstractSecurityConfigurationChildBuilder
- ssl() - Method in class org.infinispan.client.hotrod.configuration.SecurityConfiguration
- ssl() - Method in class org.infinispan.client.hotrod.configuration.SecurityConfigurationBuilder
- ssl() - Method in class org.infinispan.persistence.remote.configuration.AbstractSecurityConfigurationChildBuilder
- ssl() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfiguration
- ssl() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfigurationBuilder
- ssl() - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
- ssl() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- ssl() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- ssl() - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
-
Configures SSL
- SSL_CIPHERS - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- SSL_CONTEXT - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- SSL_HOSTNAME_VALIDATION - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- SSL_PROTOCOL - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- SSL_PROVIDER - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- SslConfiguration - Class in org.infinispan.client.hotrod.configuration
-
SslConfiguration.
- SslConfiguration - Class in org.infinispan.persistence.remote.configuration
-
SslConfiguration.
- SslConfiguration - Class in org.infinispan.server.core.configuration
-
SslConfiguration.
- SslConfigurationBuilder - Class in org.infinispan.client.hotrod.configuration
-
SSLConfigurationBuilder.
- SslConfigurationBuilder - Class in org.infinispan.persistence.remote.configuration
-
SSLConfigurationBuilder.
- SslConfigurationBuilder<T extends ProtocolServerConfiguration,
S extends ProtocolServerConfigurationChildBuilder<T, S>> - Class in org.infinispan.server.core.configuration -
SSLConfigurationBuilder.
- SslConfigurationBuilder(SecurityConfigurationBuilder) - Constructor for class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
- SslConfigurationBuilder(ProtocolServerConfigurationChildBuilder<T, S>) - Constructor for class org.infinispan.server.core.configuration.SslConfigurationBuilder
- SslConfigurationChildBuilder - Interface in org.infinispan.server.core.configuration
-
ProtocolServerConfigurationChildBuilder.
- sslContext() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
- sslContext() - Method in class org.infinispan.persistence.remote.configuration.SslConfiguration
- sslContext() - Method in class org.infinispan.server.core.configuration.SslConfiguration
- sslContext() - Method in class org.infinispan.server.core.configuration.SslEngineConfiguration
- sslContext(Supplier<SSLContext>) - Method in class org.infinispan.server.core.configuration.EncryptionConfigurationBuilder
- sslContext(Supplier<SSLContext>) - Method in class org.infinispan.server.core.configuration.SniConfigurationBuilder
- sslContext(Supplier<SSLContext>) - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
-
Sets the
SSLContext
to use for setting up SSL connections. - sslContext(Supplier<SSLContext>) - Method in class org.infinispan.server.core.configuration.SslEngineConfigurationBuilder
-
Sets the
SSLContext
to use for setting up SSL connections. - sslContext(SSLContext) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
-
Specifies a pre-built
SSLContext
- sslContext(SSLContext) - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
- sslContext(SSLContext) - Method in class org.infinispan.server.core.configuration.EncryptionConfigurationBuilder
- sslContext(SSLContext) - Method in class org.infinispan.server.core.configuration.SniConfigurationBuilder
- sslContext(SSLContext) - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
-
Sets the
SSLContext
to use for setting up SSL connections. - sslContext(SSLContext) - Method in class org.infinispan.server.core.configuration.SslEngineConfigurationBuilder
-
Sets the
SSLContext
to use for setting up SSL connections. - SslContextFactory - Class in org.infinispan.commons.util
-
SslContextFactory.
- SslContextFactory() - Constructor for class org.infinispan.commons.util.SslContextFactory
- SslEngineConfiguration - Class in org.infinispan.server.core.configuration
-
SslEngineConfiguration
- SslEngineConfigurationBuilder - Class in org.infinispan.server.core.configuration
-
SSLConfigurationBuilder.
- sslProtocol(String) - Method in class org.infinispan.commons.util.SslContextFactory
- SslUtils - Class in org.infinispan.server.core.utils
-
SSL utils mainly for Netty.
- SslUtils() - Constructor for class org.infinispan.server.core.utils.SslUtils
- stableTopologyCompletion(String) - Method in interface org.infinispan.topology.LocalTopologyManager
-
Returns a
CompletionStage
that completes when the cache with the namecacheName
has a stable topology. - stableTopologyCompletion(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- stack() - Method in class org.infinispan.configuration.global.TransportConfiguration
- stack(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
- STACK - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- STACK - Enum constant in enum org.infinispan.configuration.parsing.Element
- STACK - Static variable in class org.infinispan.configuration.global.TransportConfiguration
- STACK_FILE - Enum constant in enum org.infinispan.configuration.parsing.Element
- StackBuilder<T> - Interface in org.infinispan.configuration.global
- StackConfiguration - Class in org.infinispan.configuration.global
- StackConfigurationBuilder - Class in org.infinispan.configuration.global
- StackFileConfiguration - Class in org.infinispan.configuration.global
- StackFileConfigurationBuilder - Class in org.infinispan.configuration.global
- stackFiles() - Method in class org.infinispan.configuration.global.JGroupsConfiguration
- stacks() - Method in class org.infinispan.configuration.global.JGroupsConfiguration
- STACKS - Enum constant in enum org.infinispan.configuration.parsing.Element
- StaggeredRequest<T> - Class in org.infinispan.remoting.transport.jgroups
- staleStatsThreshold - Variable in class org.infinispan.stats.impl.ClusterContainerStatsImpl
- STANDARD_ANALYZER_NAME - Static variable in class org.infinispan.search.mapper.mapping.impl.DefaultAnalysisConfigurer
- StandardConversions - Class in org.infinispan.commons.dataconversion
-
Utilities to convert between text/plain, octet-stream, java-objects and url-encoded contents.
- StandardConversions() - Constructor for class org.infinispan.commons.dataconversion.StandardConversions
- start() - Method in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
- start() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- start() - Method in class org.infinispan.cache.impl.CacheImpl
- start() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- start() - Method in class org.infinispan.client.hotrod.event.impl.EventDispatcher
- start() - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- start() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- start() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
- start() - Method in class org.infinispan.commands.CommandsFactoryImpl
- start() - Method in interface org.infinispan.commons.api.Lifecycle
-
Invoked on component start
- start() - Method in interface org.infinispan.commons.marshall.Marshaller
-
Perform any initialization required before the marshaller is used.
- start() - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
-
Deprecated.
- start() - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
- start() - Method in class org.infinispan.container.offheap.OffHeapDataContainer
- start() - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
- start() - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
- start() - Method in class org.infinispan.container.versioning.irac.DefaultIracTombstoneManager
- start() - Method in class org.infinispan.container.versioning.irac.DefaultIracVersionGenerator
- start() - Method in class org.infinispan.container.versioning.irac.NoOpIracVersionGenerator
- start() - Method in class org.infinispan.container.versioning.NumericVersionGenerator
- start() - Method in class org.infinispan.container.versioning.SimpleClusteredVersionGenerator
- start() - Method in class org.infinispan.context.impl.TransactionalInvocationContextFactory
- start() - Method in class org.infinispan.distribution.impl.L1ManagerImpl
- start() - Method in class org.infinispan.eviction.impl.ActivationManagerImpl
- start() - Method in class org.infinispan.eviction.impl.PassivationManagerImpl
- start() - Method in class org.infinispan.expiration.impl.ClusterExpirationManager
- start() - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
- start() - Method in class org.infinispan.expiration.impl.TxClusterExpirationManager
- start() - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
- start() - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
- start() - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.This starts the components in the registry, connecting to channels, starting service threads, etc.
- start() - Method in class org.infinispan.factories.ComponentRegistry
- start() - Method in class org.infinispan.globalstate.impl.GlobalStateManagerImpl
- start() - Method in class org.infinispan.interceptors.BaseCustomAsyncInterceptor
- start() - Method in class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller
- start() - Method in class org.infinispan.jboss.marshalling.core.JBossMarshaller
- start() - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
-
Looks up the MBean server and initializes domain and group.
- start() - Method in class org.infinispan.jmx.CacheJmxRegistration
- start() - Method in class org.infinispan.manager.DefaultCacheManager
- start() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
- start() - Method in class org.infinispan.marshall.core.GlobalMarshaller
- start() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- start() - Method in class org.infinispan.notifications.cachelistener.cluster.impl.BatchingClusterEventManagerImpl
- start() - Method in interface org.infinispan.notifications.cachelistener.filter.FilterIndexingServiceProvider
-
Start the provider.
- start() - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
- start() - Method in class org.infinispan.persistence.cluster.ClusterLoader
-
Deprecated.
- start() - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- start() - Method in class org.infinispan.persistence.support.DelegatingCacheLoader
- start() - Method in class org.infinispan.persistence.support.DelegatingCacheWriter
- start() - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- start() - Method in class org.infinispan.reactive.publisher.impl.ClusterPublisherManagerImpl
- start() - Method in class org.infinispan.reactive.publisher.impl.LocalClusterPublisherManagerImpl
- start() - Method in class org.infinispan.reactive.publisher.impl.LocalPublisherManagerImpl
- start() - Method in class org.infinispan.reactive.publisher.impl.PartitionAwareClusterPublisherManager
- start() - Method in class org.infinispan.reactive.publisher.impl.PublisherHandler
- start() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- start() - Method in enum org.infinispan.remoting.transport.impl.EmptyRaftManager
- start() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsMetricsManagerImpl
- start() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- start() - Method in interface org.infinispan.remoting.transport.Transport
- start() - Method in class org.infinispan.scattered.impl.BiasManagerImpl
- start() - Method in class org.infinispan.scattered.impl.ScatteredPreloadManager
- start() - Method in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
- start() - Method in class org.infinispan.scattered.impl.ScatteredStateProviderImpl
- start() - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
- start() - Method in class org.infinispan.security.impl.SecureCacheImpl
- start() - Method in class org.infinispan.server.core.transport.NettyTransport
- start() - Method in interface org.infinispan.server.core.transport.Transport
- start() - Method in class org.infinispan.server.hotrod.tx.table.GlobalTxTable
- start() - Method in class org.infinispan.spring.remote.provider.SpringRemoteCacheManager
-
Start the
that backs thisorg.infinispan.client.hotrod.RemoteCacheManager
SpringRemoteCacheManager
. - start() - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl
- start() - Method in class org.infinispan.stats.impl.ClusterContainerStatsImpl
- start() - Method in class org.infinispan.stats.impl.StatsCollector
- start() - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- start() - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- start() - Method in class org.infinispan.transaction.impl.TransactionCoordinator
- start() - Method in class org.infinispan.transaction.impl.TransactionTable
- start() - Method in class org.infinispan.transaction.xa.TransactionFactory
- start() - Method in class org.infinispan.upgrade.RollingUpgradeManager
- start() - Method in class org.infinispan.util.concurrent.CommandAckCollector
- start() - Method in class org.infinispan.xsite.events.XSiteEventsManagerImpl
- start() - Method in class org.infinispan.xsite.irac.DefaultIracManager
- start() - Method in class org.infinispan.xsite.statetransfer.XSiteStateProviderImpl
- start() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
- start() - Method in class org.infinispan.xsite.status.DefaultTakeOfflineManager
- start(C, EmbeddedCacheManager) - Method in class org.infinispan.server.core.AbstractProtocolServer
- start(C, EmbeddedCacheManager) - Method in interface org.infinispan.server.core.ProtocolServer
-
Starts the server backed by the given cache manager, with the corresponding configuration.
- start(Executor) - Method in class org.infinispan.persistence.sifs.LogAppender
- start(Xid, int) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
- start(AdvancedCache, BitSet, String, List<byte[]>, MediaType, int, boolean) - Method in class org.infinispan.server.hotrod.iteration.DefaultIterationManager
- start(AdvancedCache, BitSet, String, List<byte[]>, MediaType, int, boolean) - Method in interface org.infinispan.server.hotrod.iteration.IterationManager
- start(InternalRemoteCache<K, V>) - Method in class org.infinispan.client.hotrod.near.NearCacheService
- start(ChannelFactory, Configuration, ClientListenerNotifier) - Method in class org.infinispan.client.hotrod.counter.impl.RemoteCounterManager
- start(ConnectionFactoryConfiguration, ClassLoader) - Method in class org.infinispan.persistence.jdbc.common.connectionfactory.ConnectionFactory
-
Starts the connection factory.
- start(InitializationContext) - Method in class org.infinispan.configuration.parsing.SFSToSIFSStore
- start(InitializationContext) - Method in class org.infinispan.persistence.async.AsyncNonBlockingStore
- start(InitializationContext) - Method in class org.infinispan.persistence.file.SingleFileStore
- start(InitializationContext) - Method in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
- start(InitializationContext) - Method in class org.infinispan.persistence.remote.RemoteStore
- start(InitializationContext) - Method in class org.infinispan.persistence.rocksdb.RocksDBStore
- start(InitializationContext) - Method in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
- start(InitializationContext) - Method in interface org.infinispan.persistence.spi.NonBlockingStore
-
The first method to invoke so that the store can be configured and additional steps, such as connecting through a socket or opening file descriptors, are performed.
- start(InitializationContext) - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
- start(InitializationContext) - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
- start(T) - Method in class org.infinispan.factories.impl.ComponentAccessor
- Start - Annotation Type in org.infinispan.factories.annotations
-
Method level annotation that indicates a (no-param) method to be called on a component registered in the component registry when the registry starts.
- START - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- START_DOCUMENT - Enum constant in enum org.infinispan.commons.configuration.io.ConfigurationReader.ElementType
- START_DOCUMENT - Static variable in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
-
Signalize that parser is at the very beginning of the document and nothing was read yet.
- START_ELEMENT - Enum constant in enum org.infinispan.commons.configuration.io.ConfigurationReader.ElementType
- START_TAG - Static variable in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
-
Returned from getEventType(), next(), nextToken() when a start tag was read.
- START_TRANSPORT - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- startAllowed() - Method in enum org.infinispan.lifecycle.ComponentStatus
- startAsync() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
- startAtomic() - Method in class org.infinispan.batch.AutoBatchSupport
- startAutomatically - Variable in class org.infinispan.spring.remote.AbstractRemoteCacheManagerFactory
- startAutomaticStateTransferTo(ByteString, boolean) - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateTransferManager
- startAutomaticStateTransferTo(ByteString, boolean) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
-
Starts the automatic cross-site state transfer if available and if required.
- startAutomaticStateTransferTo(ByteString, boolean) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
- startBatch() - Method in class org.infinispan.batch.BatchContainer
-
Starts a batch
- startBatch() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- startBatch() - Method in class org.infinispan.cache.impl.CacheImpl
- startBatch() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- startBatch() - Method in interface org.infinispan.commons.api.BatchingCache
-
Starts a batch.
- startBatch() - Method in class org.infinispan.security.impl.SecureCacheImpl
- startBatch(boolean) - Method in class org.infinispan.batch.BatchContainer
- startCache() - Method in class org.infinispan.manager.DefaultCacheManager
- startCache(String) - Method in class org.infinispan.manager.DefaultCacheManager
- startCaches() - Method in class org.infinispan.server.core.AbstractProtocolServer
- startCaches() - Method in class org.infinispan.server.hotrod.HotRodServer
- startCaches(String...) - Method in class org.infinispan.manager.DefaultCacheManager
- startCaches(String...) - Method in interface org.infinispan.manager.EmbeddedCacheManager
-
Starts a set of caches in parallel.
- startCaches(String...) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
- startCleanupTombstone() - Method in class org.infinispan.container.versioning.irac.DefaultIracTombstoneManager
- startClientListener(byte[]) - Method in class org.infinispan.client.hotrod.event.impl.ClientListenerNotifier
- startedIteration(String) - Method in interface org.infinispan.client.hotrod.logging.Log
- startExtendedStatisticInterceptor() - Method in interface org.infinispan.extendedstats.logging.Log
- startFlush() - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
- startIndex() - Method in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
- startingAvailability() - Method in enum org.infinispan.partitionhandling.PartitionHandling
- startingUp() - Method in enum org.infinispan.lifecycle.ComponentStatus
- startInternal() - Method in class org.infinispan.rest.RestServer
- startInternal() - Method in class org.infinispan.server.core.AbstractProtocolServer
- startInternal() - Method in class org.infinispan.server.hotrod.HotRodServer
- startInternal() - Method in class org.infinispan.server.memcached.MemcachedServer
- startInternalCaches() - Method in class org.infinispan.registry.impl.InternalCacheRegistryImpl
- startJGroupsChannelIfNeeded() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
-
When overwriting this method, it allows third-party libraries to create a new behavior like: After
JChannel
has been created and before it is connected. - startKeysTransfer(IntSet, Address) - Method in class org.infinispan.scattered.impl.ScatteredStateProviderImpl
- startKeysTransfer(IntSet, Address) - Method in interface org.infinispan.scattered.ScatteredStateProvider
-
Start transferring keys and remote metadata for the given segments to the origin.
- startKeyTransfer(IntSet) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
- startKeyTransfer(IntSet) - Method in interface org.infinispan.scattered.ScatteredVersionManager
-
Move the segments from
ScatteredVersionManager.SegmentState.BLOCKED
toScatteredVersionManager.SegmentState.KEY_TRANSFER
state. - startObjectInput(InputStream, boolean) - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
-
Deprecated.Create and open a new ObjectInput for the given input stream.
- startObjectInput(InputStream, boolean) - Method in class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller
- startObjectInput(InputStream, boolean) - Method in class org.infinispan.marshall.core.GlobalMarshaller
- startObjectOutput(OutputStream, boolean, int) - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
-
Deprecated.Create and open an ObjectOutput instance for the given output stream.
- startObjectOutput(OutputStream, boolean, int) - Method in class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller
- startObjectOutput(OutputStream, boolean, int) - Method in class org.infinispan.marshall.core.GlobalMarshaller
- startOffset(long) - Method in interface org.infinispan.query.dsl.PaginationContext
-
Deprecated.
- startOffset(long) - Method in interface org.infinispan.query.dsl.Query
- startPublisher() - Method in class org.infinispan.commons.reactive.AbstractAsyncPublisherHandler
- startPushState(String) - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateTransferManager
- startPushState(String) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
-
It notifies all nodes from local site to start transfer the state to the remote site.
- startPushState(String) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
- startQueuedRebalance() - Method in class org.infinispan.topology.ClusterCacheStatus
- startRevokingRemoteBias(Object, Address) - Method in interface org.infinispan.scattered.BiasManager
-
Check if there are any nodes that have local bias, and starting replacing them with the provided address.
- startRevokingRemoteBias(Object, Address) - Method in class org.infinispan.scattered.impl.BiasManagerImpl
- startStateTransfer(String) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateConsumer
-
It notifies the start of state transfer from other site.
- startStateTransfer(String) - Method in class org.infinispan.xsite.statetransfer.XSiteStateConsumerImpl
- startStateTransfer(String, Address, int) - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateProvider
- startStateTransfer(String, Address, int) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateProvider
-
It notifies this node to start sending state to the remote site.
- startStateTransfer(String, Address, int) - Method in class org.infinispan.xsite.statetransfer.XSiteStateProviderImpl
- startStateTransfer(Collection<Address>) - Method in class org.infinispan.xsite.statetransfer.RemoteSiteStatus
- startStreamSummaryInterceptor() - Method in interface org.infinispan.extendedstats.logging.Log
- startTransaction() - Method in class org.infinispan.server.hotrod.tx.PrepareCoordinator
-
Starts a transaction.
- startTransport() - Method in class org.infinispan.server.core.AbstractProtocolServer
- startTransport() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- startTransport() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- startTransport() - Method in class org.infinispan.server.hotrod.HotRodServer
- startTransport(boolean) - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
- startTransport(boolean) - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- startTransport(boolean) - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
-
Indicates whether transport implementation should or should not be started.
- STARTUP_MODE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- STARTUP_MODE - Static variable in class org.infinispan.configuration.cache.IndexingConfiguration
- startupMode() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
- startupMode(IndexStartupMode) - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
- startupMode(IndexStartupMode) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
- startupMode(IndexStartupMode) - Method in interface org.infinispan.configuration.cache.IndexingConfigurationChildBuilder
- startXidMapping() - Method in class org.infinispan.transaction.xa.XaTransactionTable
- state - Variable in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- STATE_CAPACITY_FACTOR - Static variable in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
- STATE_CAPACITY_FACTORS - Static variable in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
- STATE_CHUNK - Static variable in interface org.infinispan.commons.marshall.Ids
- STATE_CONSISTENT_HASH - Static variable in class org.infinispan.distribution.ch.impl.ConsistentHashPersistenceConstants
- STATE_HASH_FUNCTION - Static variable in class org.infinispan.distribution.ch.impl.ConsistentHashPersistenceConstants
- STATE_MEMBER - Static variable in class org.infinispan.distribution.ch.impl.ConsistentHashPersistenceConstants
- STATE_MEMBER_NO_ENTRIES - Static variable in class org.infinispan.distribution.ch.impl.ConsistentHashPersistenceConstants
- STATE_MEMBERS - Static variable in class org.infinispan.distribution.ch.impl.ConsistentHashPersistenceConstants
- STATE_MEMBERS_NO_ENTRIES - Static variable in class org.infinispan.distribution.ch.impl.ConsistentHashPersistenceConstants
- STATE_NUM_SEGMENTS - Static variable in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
- STATE_REQUEST - Enum constant in enum org.infinispan.xsite.events.XSiteEventType
-
Sent from site A to site B, notifies site B that it can send state (automatic cross-site state transfer must be enabled).
- STATE_TRANSFER - Enum constant in enum org.infinispan.configuration.parsing.Element
- STATE_TRANSFER_CONTROL - Static variable in class org.infinispan.xsite.commands.remote.Ids
- STATE_TRANSFER_EXECUTOR - Enum constant in enum org.infinispan.configuration.parsing.Attribute
-
Deprecated, for removal: This API element is subject to removal in a future version.
- STATE_TRANSFER_PROGRESS - Enum constant in enum org.infinispan.context.Flag
-
Signals that a state transfer is in course.
- STATE_TRANSFER_PROGRESS - Static variable in class org.infinispan.context.impl.FlagBitSets
- STATE_TRANSFER_STATE - Static variable in class org.infinispan.xsite.commands.remote.Ids
- StatefulCacheListener(Cache<?, ?>) - Constructor for class org.infinispan.rest.resources.CacheResourceV2.StatefulCacheListener
- StatelessCacheListener(Cache<?, ?>) - Constructor for class org.infinispan.rest.resources.CacheResourceV2.StatelessCacheListener
- statement - Variable in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations.FlowableConnection
- stateTransfer() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
- stateTransfer() - Method in class org.infinispan.configuration.cache.BackupConfiguration
- stateTransfer() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
- stateTransfer() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
- stateTransfer() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
-
Configure the
stateTransfer
sub element for distributed and replicated caches. - stateTransfer() - Method in interface org.infinispan.configuration.cache.ClusteringConfigurationChildBuilder
-
Configures how state is transferred when a new cache joins the cluster.
- StateTransferComponentFactory - Class in org.infinispan.factories
-
Constructs
StateTransferManager
,StateConsumer
andStateProvider
instances. - StateTransferComponentFactory() - Constructor for class org.infinispan.factories.StateTransferComponentFactory
- StateTransferConfiguration - Class in org.infinispan.configuration.cache
-
Configures how state is retrieved when a new cache joins the cluster.
- StateTransferConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Configures how state is transferred when a cache joins or leaves the cluster.
- stateTransferExecutor(String) - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 10.1, no longer used.
- stateTransferLock - Variable in class org.infinispan.stream.impl.AbstractCacheStream
- stateTransferMode() - Method in class org.infinispan.xsite.response.AutoStateTransferResponse
- stateTransferMode() - Method in class org.infinispan.xsite.statetransfer.RemoteSiteStatus
- stateTransferMode(String) - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateTransferManager
- stateTransferMode(String) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
- stateTransferMode(String) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
- StateTransferStatus - Enum in org.infinispan.xsite.statetransfer
-
Cross-site state transfer status.
- stateTransferThreadPool() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
- stateTransferThreadPool() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 10.1, no longer used.
- stateTransferThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 10.1, no longer used.
- stateTransferThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- stateTransferThreadPool() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Configuration for the state-transfer thread pool
- stateTransferThreadPool() - Method in class org.infinispan.configuration.global.ThreadsConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 10.1, no longer used.
- stateTransferThreadPool() - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 10.1, no longer used.
- stateTransferThreadPoolName() - Method in class org.infinispan.configuration.global.GlobalConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 10.1, no longer used.
- stateTransferThreadPoolName(String) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 10.1, no longer used.
- StaticContentResource - Class in org.infinispan.rest.resources
-
REST resource to serve static content.
- StaticContentResource(InvocationHelper, Path, String) - Constructor for class org.infinispan.rest.resources.StaticContentResource
- StaticContentResource(InvocationHelper, Path, String, StaticContentResource.ResourceResolver) - Constructor for class org.infinispan.rest.resources.StaticContentResource
- StaticContentResource.ResourceResolver - Interface in org.infinispan.rest.resources
- staticResources() - Method in class org.infinispan.rest.configuration.RestServerConfiguration
- staticResources(Path) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- statistics() - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
- statistics() - Method in class org.infinispan.client.hotrod.configuration.Configuration
- statistics() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- statistics() - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
-
Configures client-side statistics.
- statistics() - Method in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
- statistics() - Method in class org.infinispan.configuration.cache.Configuration
- statistics() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- statistics() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- statistics() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
- statistics() - Method in class org.infinispan.configuration.global.GlobalConfiguration
- statistics(boolean) - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
- statistics(Boolean) - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 10.1.3. Use
CacheContainerConfigurationBuilder.statistics(boolean)
instead. - STATISTICS - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- STATISTICS - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- STATISTICS_AVAILABLE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- StatisticsConfiguration - Class in org.infinispan.client.hotrod.configuration
- StatisticsConfiguration - Class in org.infinispan.configuration.cache
-
Determines whether cache statistics are gathered.
- StatisticsConfigurationBuilder - Class in org.infinispan.client.hotrod.configuration
-
Configures client-side statistics
- StatisticsConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Determines whether cache statistics are gathered.
- statisticsNotEnabled(String) - Method in interface org.infinispan.rest.logging.Log
- StatisticsSnapshot - Class in org.infinispan.extendedstats.container
-
A Statistic Snapshot;
- StatisticsSnapshot(double[]) - Constructor for class org.infinispan.extendedstats.container.StatisticsSnapshot
- stats - Variable in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Builder
- stats - Variable in class org.infinispan.extendedstats.container.BaseExtendedStatisticsContainer
- stats() - Method in interface org.infinispan.client.hotrod.RemoteCache
-
Deprecated, for removal: This API element is subject to removal in a future version.use
RemoteCache.serverStatistics()
instead - Stats - Interface in org.infinispan.stats
-
Stats.
- STATS - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- STATS_ENVELOPE - Static variable in interface org.infinispan.commons.marshall.Ids
- STATS_MODE_ID - Static variable in class org.infinispan.functional.ParamIds
- STATS_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- STATS_TASK - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- StatsChannelHandler - Class in org.infinispan.server.core.transport
-
Input/Output ChannelHandler to keep statistics
- StatsChannelHandler(NettyTransport) - Constructor for class org.infinispan.server.core.transport.StatsChannelHandler
- StatsCollectingCache<K,
V> - Class in org.infinispan.cache.impl -
Wraps existing
AdvancedCache
to collect statistics - StatsCollectingCache(String) - Constructor for class org.infinispan.cache.impl.StatsCollectingCache
- StatsCollector - Class in org.infinispan.stats.impl
- StatsCollector() - Constructor for class org.infinispan.stats.impl.StatsCollector
- StatsCollector.Factory - Class in org.infinispan.stats.impl
- StatsEnvelope<T> - Class in org.infinispan.functional.impl
-
Responses for functional commands that allow to record statistics.
- StatsEnvelope.Externalizer - Class in org.infinispan.functional.impl
- StatsImpl - Class in org.infinispan.stats.impl
-
StatsImpl.
- StatsRequest - Enum constant in enum org.infinispan.server.memcached.MemcachedOperation
- statsResponse(HotRodHeader, HotRodServer, Channel, Stats, NettyTransport, ClusterCacheStats) - Method in class org.infinispan.server.hotrod.Encoder4x
- statsResponse(HotRodHeader, HotRodServer, Channel, Stats, NettyTransport, ClusterCacheStats) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- statsUpdateTimestamp - Variable in class org.infinispan.stats.impl.ClusterContainerStatsImpl
- status() - Method in class org.infinispan.xsite.status.DefaultTakeOfflineManager
- status() - Method in class org.infinispan.xsite.status.NoOpTakeOfflineManager
- status() - Method in interface org.infinispan.xsite.status.TakeOfflineManager
-
It returns a
Map
with the sites name and their state (Online or Offline). - status(int) - Method in interface org.infinispan.rest.framework.impl.RestResponseBuilder
- status(int) - Method in class org.infinispan.rest.framework.impl.SimpleRestResponse.Builder
- status(int) - Method in class org.infinispan.rest.NettyRestResponse.Builder
- status(HttpResponseStatus) - Method in class org.infinispan.rest.NettyRestResponse.Builder
- Status - Enum in org.infinispan.server.hotrod.tx.table
-
Internal server status for the client's transactions.
- STATUS_CANCELED - Static variable in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
- STATUS_ERROR - Static variable in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
- STATUS_OK - Static variable in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
- STATUS_SENDING - Static variable in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
- stop() - Method in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
- stop() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- stop() - Method in class org.infinispan.cache.impl.CacheImpl
- stop() - Method in class org.infinispan.cache.impl.DecoratedCache
- stop() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- stop() - Method in interface org.infinispan.Cache
-
Stops a cache.
- stop() - Method in class org.infinispan.client.hotrod.counter.impl.NotificationManager
- stop() - Method in class org.infinispan.client.hotrod.counter.impl.RemoteCounterManager
- stop() - Method in class org.infinispan.client.hotrod.event.impl.ClientListenerNotifier
- stop() - Method in class org.infinispan.client.hotrod.event.impl.EventDispatcher
- stop() - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- stop() - Method in class org.infinispan.client.hotrod.impl.InvalidatedNearRemoteCache
- stop() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- stop() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
-
Stop the remote cache manager, disconnecting all existing connections.
- stop() - Method in interface org.infinispan.commons.api.Lifecycle
-
Invoked on component stop
- stop() - Method in interface org.infinispan.commons.marshall.Marshaller
-
Stop the marshaller.
- stop() - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
-
Deprecated.Stop the marshaller.
- stop() - Method in class org.infinispan.container.impl.DefaultSegmentedDataContainer
- stop() - Method in class org.infinispan.container.impl.L1SegmentedDataContainer
- stop() - Method in class org.infinispan.container.offheap.OffHeapDataContainer
- stop() - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
- stop() - Method in class org.infinispan.container.versioning.irac.DefaultIracTombstoneManager
- stop() - Method in class org.infinispan.container.versioning.irac.DefaultIracVersionGenerator
- stop() - Method in class org.infinispan.container.versioning.irac.NoOpIracVersionGenerator
- stop() - Method in class org.infinispan.distribution.impl.L1ManagerImpl
- stop() - Method in class org.infinispan.eviction.impl.ActivationManagerImpl
- stop() - Method in class org.infinispan.eviction.impl.PassivationManagerImpl
- stop() - Method in class org.infinispan.expiration.impl.ExpirationManagerImpl
- stop() - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
- stop() - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.Stops the component and sets its status to
ComponentStatus.TERMINATED
once it is done. - stop() - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
-
Stop the registry and all the components that have been started.
- stop() - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
- stop() - Method in class org.infinispan.globalstate.impl.GlobalStateManagerImpl
- stop() - Method in class org.infinispan.interceptors.BaseCustomAsyncInterceptor
- stop() - Method in class org.infinispan.jboss.marshalling.commons.AbstractJBossMarshaller
- stop() - Method in class org.infinispan.jboss.marshalling.core.JBossMarshaller
- stop() - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
-
Unregisters the MBeans that were registered on start.
- stop() - Method in class org.infinispan.jmx.CacheJmxRegistration
- stop() - Method in class org.infinispan.manager.DefaultCacheManager
- stop() - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
- stop() - Method in class org.infinispan.marshall.core.GlobalMarshaller
- stop() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- stop() - Method in interface org.infinispan.notifications.cachelistener.filter.FilterIndexingServiceProvider
-
Stop the provider.
- stop() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
-
Removes all listeners from the notifier
- stop() - Method in class org.infinispan.persistence.async.AsyncNonBlockingStore
- stop() - Method in class org.infinispan.persistence.cluster.ClusterLoader
-
Deprecated.
- stop() - Method in class org.infinispan.persistence.file.SingleFileStore
- stop() - Method in class org.infinispan.persistence.jdbc.common.connectionfactory.ConnectionFactory
-
Closes the connection factory, including all allocated connections etc.
- stop() - Method in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
- stop() - Method in class org.infinispan.persistence.remote.RemoteStore
- stop() - Method in class org.infinispan.persistence.rocksdb.RocksDBStore
- stop() - Method in class org.infinispan.persistence.sifs.FileProvider
- stop() - Method in class org.infinispan.persistence.sifs.LogAppender
- stop() - Method in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
- stop() - Method in interface org.infinispan.persistence.spi.NonBlockingStore
-
This method is invoked when the cache is being shutdown.
- stop() - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- stop() - Method in class org.infinispan.persistence.support.DelegatingCacheLoader
- stop() - Method in class org.infinispan.persistence.support.DelegatingCacheWriter
- stop() - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
- stop() - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- stop() - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
- stop() - Method in class org.infinispan.reactive.publisher.impl.ClusterPublisherManagerImpl
- stop() - Method in class org.infinispan.reactive.publisher.impl.LocalPublisherManagerImpl
- stop() - Method in class org.infinispan.reactive.publisher.impl.PublisherHandler
- stop() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- stop() - Method in enum org.infinispan.remoting.transport.impl.EmptyRaftManager
- stop() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsMetricsManagerImpl
- stop() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- stop() - Method in interface org.infinispan.remoting.transport.Transport
- stop() - Method in class org.infinispan.rest.RestServer
- stop() - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
- stop() - Method in class org.infinispan.security.impl.SecureCacheImpl
- stop() - Method in class org.infinispan.server.core.AbstractProtocolServer
- stop() - Method in interface org.infinispan.server.core.ProtocolServer
-
Stops the server.
- stop() - Method in class org.infinispan.server.core.transport.NettyTransport
- stop() - Method in interface org.infinispan.server.core.transport.Transport
- stop() - Method in class org.infinispan.server.hotrod.counter.listener.ClientCounterManagerNotificationManager
- stop() - Method in class org.infinispan.server.hotrod.HotRodServer
- stop() - Method in class org.infinispan.server.hotrod.tx.table.GlobalTxTable
- stop() - Method in class org.infinispan.server.memcached.MemcachedServer
- stop() - Method in class org.infinispan.spring.embedded.provider.SpringEmbeddedCacheManager
-
Stop the
thisEmbeddedCacheManager
CacheManager
delegates to. - stop() - Method in class org.infinispan.spring.remote.provider.SpringRemoteCacheManager
-
Stop the
that backs thisorg.infinispan.client.hotrod.RemoteCacheManager
SpringRemoteCacheManager
. - stop() - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- stop() - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- stop() - Method in class org.infinispan.util.concurrent.ConditionFuture
- stop() - Method in class org.infinispan.xsite.events.XSiteEventsManagerImpl
- stop(RemoteCache<K, V>) - Method in class org.infinispan.client.hotrod.near.NearCacheService
- stop(T) - Method in class org.infinispan.factories.impl.ComponentAccessor
- Stop - Annotation Type in org.infinispan.factories.annotations
-
Method level annotation that indicates a (no-param) method to be called on a component registered in the component registry when the registry stops.
- STOP_TIMEOUT - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- stopAllowed() - Method in enum org.infinispan.lifecycle.ComponentStatus
- stopApplyingState(int) - Method in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
- stopAsync() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
- stopCleanupTask() - Method in class org.infinispan.container.versioning.irac.DefaultIracTombstoneManager
- STOPPING - Enum constant in enum org.infinispan.lifecycle.ComponentStatus
-
The
stop()
method has been called but has not yet completed. - STOPPING - Enum constant in enum org.infinispan.topology.ClusterTopologyManager.ClusterManagerStatus
- stopStreamSummaryInterceptor() - Method in interface org.infinispan.extendedstats.logging.Log
- storage() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
- storage() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
- storage() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
- storage() - Method in class org.infinispan.counter.api.CounterConfiguration
- storage() - Method in class org.infinispan.counter.configuration.AbstractCounterConfiguration
- storage(IndexStorage) - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
- storage(IndexStorage) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
- storage(IndexStorage) - Method in interface org.infinispan.configuration.cache.IndexingConfigurationChildBuilder
- storage(StorageType) - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
- storage(Storage) - Method in class org.infinispan.counter.api.CounterConfiguration.Builder
-
Sets the storage mode of the counter.
- storage(Storage) - Method in class org.infinispan.counter.configuration.StrongCounterConfigurationBuilder
- storage(Storage) - Method in interface org.infinispan.counter.configuration.CounterConfigurationBuilder
-
Sets the counter's storage mode.
- Storage - Enum in org.infinispan.counter.api
-
The storage mode of a counter.
- STORAGE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- STORAGE - Enum constant in enum org.infinispan.counter.configuration.Attribute
- STORAGE - Static variable in class org.infinispan.configuration.cache.IndexingConfiguration
- STORAGE - Static variable in class org.infinispan.configuration.cache.MemoryConfiguration
- STORAGE_TYPE - Static variable in class org.infinispan.configuration.cache.MemoryStorageConfiguration
-
Deprecated.
- Storage$___Marshaller_ed04a8616efd062a7c88e9e578efa97c99224ac3211dd20ca76376455f84a9ae - Class in org.infinispan.counter.api
- Storage$___Marshaller_ed04a8616efd062a7c88e9e578efa97c99224ac3211dd20ca76376455f84a9ae() - Constructor for class org.infinispan.counter.api.Storage$___Marshaller_ed04a8616efd062a7c88e9e578efa97c99224ac3211dd20ca76376455f84a9ae
- StorageConfigurationManager - Class in org.infinispan.encoding.impl
-
Key/value storage information (storage media type and wrapping).
- StorageConfigurationManager() - Constructor for class org.infinispan.encoding.impl.StorageConfigurationManager
- storageType() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.Use
MemoryConfiguration.storage()
instead. - storageType() - 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.storage()
instead. - storageType() - Method in class org.infinispan.configuration.cache.MemoryStorageConfiguration
-
Deprecated.
- storageType(StorageType) - 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.storage(StorageType)
instead. - StorageType - Enum in org.infinispan.configuration.cache
-
Enumeration defining the various storage types for the data container.
- Store - Class in org.infinispan.persistence.modifications
-
Modification representing
CacheWriter.write(MarshallableEntry)
. - Store - Annotation Type in org.infinispan.commons.persistence
-
Deprecated, for removal: This API element is subject to removal in a future version.since 11.0. To be removed in 14.0 ISPN-11866. Stores should utilise
NonBlockingStore.Characteristic
s to specify a store's capabilities. - Store(Object, MarshallableEntry) - Constructor for class org.infinispan.persistence.modifications.Store
- STORE - Enum constant in enum org.infinispan.configuration.parsing.Element
- STORE - Enum constant in enum org.infinispan.persistence.modifications.Modification.Type
- STORE_AS_BINARY - Enum constant in enum org.infinispan.configuration.parsing.Element
- STORE_KEYS_AS_BINARY - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- STORE_MIGRATOR - Enum constant in enum org.infinispan.configuration.parsing.Element
- STORE_VALUES_AS_BINARY - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- storeChanged(PersistenceStatus) - Method in class org.infinispan.eviction.impl.ActivationManagerImpl
- storeChanged(PersistenceStatus) - Method in class org.infinispan.persistence.cluster.ClusterLoader
-
Deprecated.
- StoreConfiguration - Interface in org.infinispan.configuration.cache
-
StoreConfiguration contains generic configuration elements available to all the stores.
- StoreConfigurationBuilder<T extends StoreConfiguration,
S extends StoreConfigurationBuilder<T, S>> - Interface in org.infinispan.configuration.cache -
LoaderConfigurationBuilder is an interface which should be implemented by all cache loader builders
- StoreConfigurationChildBuilder<S> - Interface in org.infinispan.configuration.cache
- STORED - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- storeFromConfiguration(StoreConfiguration) - Static method in class org.infinispan.persistence.internal.PersistenceUtil
- storeIracMetadata(Object, CompletionStage<IracMetadata>) - Method in class org.infinispan.context.impl.LocalTxInvocationContext
-
Stores the
IracMetadata
associated withkey
. - storeIracMetadata(Object, CompletionStage<IracMetadata>) - Method in class org.infinispan.transaction.impl.LocalTransaction
-
Stores the
IracMetadata
associated withkey
. - storeRequest(int, MarshallableEntry<K, V>) - Method in class org.infinispan.persistence.sifs.LogAppender
- stores() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
- stores() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
- STORES - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
-
Number of entries stored in the cache by the server that receives the request since the cache started running.
- storeTombstone(int, Object, IracMetadata) - Method in class org.infinispan.container.versioning.irac.DefaultIracTombstoneManager
- storeTombstone(int, Object, IracMetadata) - Method in interface org.infinispan.container.versioning.irac.IracTombstoneManager
-
Stores a tombstone for a removed key.
- storeTombstone(int, Object, IracMetadata) - Method in class org.infinispan.container.versioning.irac.NoOpIracTombstoneManager
- storeTombstoneIfAbsent(int, Object, IracMetadata) - Method in interface org.infinispan.container.versioning.irac.IracTombstoneManager
-
Same as
IracTombstoneManager.storeTombstone(int, Object, IracMetadata)
but it doesn't overwrite an existing tombstone. - storeTombstoneIfAbsent(IracTombstoneInfo) - Method in class org.infinispan.container.versioning.irac.DefaultIracTombstoneManager
- storeTombstoneIfAbsent(IracTombstoneInfo) - Method in interface org.infinispan.container.versioning.irac.IracTombstoneManager
-
Same as
IracTombstoneManager.storeTombstoneIfAbsent(int, Object, IracMetadata)
but with aIracTombstoneInfo
instance. - storeTombstoneIfAbsent(IracTombstoneInfo) - Method in class org.infinispan.container.versioning.irac.NoOpIracTombstoneManager
- StoreUnavailableException - Exception in org.infinispan.persistence.spi
-
An exception thrown by the
PersistenceManager
if one or more stores are unavailable when a cache operation is attempted. - StoreUnavailableException() - Constructor for exception org.infinispan.persistence.spi.StoreUnavailableException
- StoreUnavailableException(String) - Constructor for exception org.infinispan.persistence.spi.StoreUnavailableException
- StoreUnavailableException(String, Throwable) - Constructor for exception org.infinispan.persistence.spi.StoreUnavailableException
- StoreUnavailableException(Throwable) - Constructor for exception org.infinispan.persistence.spi.StoreUnavailableException
- strategy() - Method in class org.infinispan.configuration.cache.BackupConfiguration
-
How does the backup happen: sync or async.
- strategy() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
- strategy(BackupConfiguration.BackupStrategy) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
-
Sets the strategy used for backing up data: sync or async.
- STRATEGY - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- STRATEGY - Static variable in class org.infinispan.configuration.cache.BackupConfiguration
- stream() - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
- stream() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.CacheEntrySet
- stream() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySet
- stream() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.KeySet
- stream() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.Values
- stream() - Method in interface org.infinispan.CacheCollection
- stream() - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
- stream() - Method in interface org.infinispan.commons.util.CloseableIteratorCollection
- stream() - Method in interface org.infinispan.commons.util.IntSet
- stream() - Method in class org.infinispan.InternalCacheSet
- stream() - Method in class org.infinispan.util.CacheSetMapper
- stream() - Method in class org.infinispan.util.CollectionMapper
- stream() - Method in class org.infinispan.util.WriteableCacheCollectionMapper
- stream(Object) - Static method in class org.infinispan.scripting.utils.JSArrays
- stream(CloseableIterator<E>, boolean, long, int) - Static method in class org.infinispan.commons.util.Closeables
-
Creates a stream that when closed will also close the underlying iterator
- stream(CloseableSpliterator<E>, boolean) - Static method in class org.infinispan.commons.util.Closeables
-
Creates a stream that when closed will also close the underlying spliterator
- STREAM_ITERATOR_RESPONSE - Static variable in interface org.infinispan.commons.marshall.Ids
- STREAM_MAP_OPS - Static variable in interface org.infinispan.commons.marshall.Ids
- STREAM_MARSHALLING - Static variable in interface org.infinispan.commons.marshall.Ids
- StreamAwareMarshaller - Interface in org.infinispan.commons.marshall
-
A minimal interface that facilitates the marshalling/unmarshalling of objects from the provided
InputStream
/OutputStream
. - streaming() - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- streaming() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- streaming() - Method in interface org.infinispan.client.hotrod.RemoteCache
-
Returns a cache where values are manipulated using
InputStream
andOutputStream
- StreamingMarshaller - Interface in org.infinispan.commons.marshall
-
Deprecated, for removal: This API element is subject to removal in a future version.for internal use only
- StreamingRemoteCache<K> - Interface in org.infinispan.client.hotrod
-
StreamingRemoteCache implements streaming versions of most
RemoteCache
methods - StreamingRemoteCacheImpl<K> - Class in org.infinispan.client.hotrod.impl
-
Implementation of
StreamingRemoteCache
- StreamingRemoteCacheImpl(InternalRemoteCache<K, ?>) - Constructor for class org.infinispan.client.hotrod.impl.StreamingRemoteCacheImpl
- StreamMarshalling - Class in org.infinispan.stream
-
Static factory class containing methods that will provide marshallable instances for very common use cases.
- StreamMarshalling.StreamMarshallingExternalizer - Class in org.infinispan.stream
- StreamMarshallingExternalizer() - Constructor for class org.infinispan.stream.StreamMarshalling.StreamMarshallingExternalizer
- Streams - Class in org.infinispan.util.stream
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 10.0. This will be removed in next major version.
- Streams() - Constructor for class org.infinispan.util.stream.Streams
-
Deprecated.
- StreamSummaryContainer - Class in org.infinispan.extendedstats.topK
-
This contains all the stream lib top keys.
- StreamSummaryContainer(String, String) - Constructor for class org.infinispan.extendedstats.topK.StreamSummaryContainer
- StreamSummaryContainer.Stat - Enum in org.infinispan.extendedstats.topK
- strength() - Method in class org.infinispan.server.hotrod.configuration.SaslConfiguration
- Strength - Enum in org.infinispan.server.hotrod.configuration
- STRENGTH - Enum constant in enum org.infinispan.server.hotrod.configuration.Attribute
- STRENGTH - Static variable in class org.infinispan.server.hotrod.configuration.SaslConfiguration
- string(ByteBuf) - Static method in class org.infinispan.server.hotrod.Intrinsics
- string(String) - Method in class org.infinispan.commons.dataconversion.internal.Json.DefaultFactory
- string(String) - Method in interface org.infinispan.commons.dataconversion.internal.Json.Factory
-
Construct and return a JSON string.
- STRING - Enum constant in enum org.infinispan.persistence.sql.AbstractSchemaJdbcStore.ProtostreamFieldType
- STRING_ARRAY - Static variable in interface org.infinispan.commons.configuration.attributes.AttributeSerializer
- STRING_COLLECTION - Static variable in interface org.infinispan.commons.configuration.attributes.AttributeSerializer
- STRING_KEYED_JDBC_STORE - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
- STRING_KEYED_TABLE - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
- stringArray(int) - Static method in class org.infinispan.commons.util.Util
- StringBuilderWriter - Class in org.infinispan.commons.io
- StringBuilderWriter() - Constructor for class org.infinispan.commons.io.StringBuilderWriter
- StringBuilderWriter(int) - Constructor for class org.infinispan.commons.io.StringBuilderWriter
- StringBuilderWriter(StringBuilder) - Constructor for class org.infinispan.commons.io.StringBuilderWriter
- StringConfiguration - Class in org.infinispan.commons.configuration
-
A simple wrapper for a configuration represented as a String.
- StringConfiguration(String) - Constructor for class org.infinispan.commons.configuration.StringConfiguration
- StringMarshaller - Class in org.infinispan.commons.marshall
- StringMarshaller(Charset) - Constructor for class org.infinispan.commons.marshall.StringMarshaller
- StringPropertyReplacer - Class in org.infinispan.commons.util
-
A utility class for replacing properties in strings.
- StringPropertyReplacer() - Constructor for class org.infinispan.commons.util.StringPropertyReplacer
- StripedCounters<T> - Class in org.infinispan.commons.util.concurrent
-
Duplicates a set of counters in a set of stripes, so that multiple threads can increment those counters without too much contention.
- StripedCounters(Supplier<T>) - Constructor for class org.infinispan.commons.util.concurrent.StripedCounters
- StripedHashFunction<T> - Class in org.infinispan.util
-
An hash function for stripping.
- StripedHashFunction(int) - Constructor for class org.infinispan.util.StripedHashFunction
- StripedLock - Class in org.infinispan.container.offheap
-
Holder for stamped locks that provides ability to retrieve them by offset and hashCode Note that locks protect entries
- StripedLock(int) - Constructor for class org.infinispan.container.offheap.StripedLock
- StripedLockContainer - Class in org.infinispan.util.concurrent.locks.impl
-
A lock container used with lock stripping.
- StripedLockContainer(int) - Constructor for class org.infinispan.util.concurrent.locks.impl.StripedLockContainer
- stripeForCurrentThread() - Method in class org.infinispan.commons.util.concurrent.StripedCounters
- STRIPING - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- STRONG_COUNTER - Enum constant in enum org.infinispan.counter.configuration.Element
- STRONG_COUNTER_KEY - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- StrongCounter - Interface in org.infinispan.counter.api
-
The strong consistent counter interface.
- StrongCounterConfiguration - Class in org.infinispan.counter.configuration
-
StrongCounter
configuration. - StrongCounterConfigurationBuilder - Class in org.infinispan.counter.configuration
-
StrongCounter
configuration builder. - StrongCounterConfigurationBuilder(CounterManagerConfigurationBuilder) - Constructor for class org.infinispan.counter.configuration.StrongCounterConfigurationBuilder
- subject - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
- subject() - Method in class org.infinispan.tasks.TaskContext
- subject(Subject) - Method in class org.infinispan.tasks.TaskContext
-
The subject to impersonate when running this task.
- SUBJECT - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- SUBJECT - Static variable in class org.infinispan.server.core.security.SubjectSaslServer
- SubjectACL - Class in org.infinispan.security.impl
-
SubjectACL.
- SubjectACL(Set<String>, int) - Constructor for class org.infinispan.security.impl.SubjectACL
- SubjectAdapter - Class in org.infinispan.security.impl
- SubjectAdapter() - Constructor for class org.infinispan.security.impl.SubjectAdapter
- SubjectAdapter.SimplePrincipal - Class in org.infinispan.security.impl
- SubjectAdapter$___Marshaller_75e0224333a6eeeafc364cef114fe68e65410956aa87814e98e0722f4d8a588d - Class in org.infinispan.security.impl
-
WARNING: Generated code! Do not edit!
- SubjectAdapter$___Marshaller_75e0224333a6eeeafc364cef114fe68e65410956aa87814e98e0722f4d8a588d() - Constructor for class org.infinispan.security.impl.SubjectAdapter$___Marshaller_75e0224333a6eeeafc364cef114fe68e65410956aa87814e98e0722f4d8a588d
- SubjectSaslServer - Class in org.infinispan.server.core.security
-
A
SaslServer
which, when complete, can return a negotiated property namedSubjectSaslServer.SUBJECT
which contains a populatedSubject
representing the authenticated user. - SubjectSaslServer(SaslServer, List<Principal>, AuthorizingCallbackHandler) - Constructor for class org.infinispan.server.core.security.SubjectSaslServer
- SubjectUserInfo - Interface in org.infinispan.server.core.security
- subList(int, int) - Method in class org.infinispan.commons.util.ForwardingList
- subList(int, int) - Method in class org.infinispan.commons.util.ImmutableListCopy.ImmutableSubList
- subList(int, int) - Method in class org.infinispan.commons.util.ImmutableListCopy
- submit(Runnable) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
- submit(Runnable) - Method in class org.infinispan.executors.LazyInitializingExecutorService
- submit(Runnable) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
- submit(Runnable) - Method in interface org.infinispan.manager.ClusterExecutor
-
Submits the runnable to the desired nodes and returns a CompletableFuture that will be completed when all desired nodes complete the given command
- submit(Runnable) - Method in class org.infinispan.server.core.transport.NonRecursiveEventLoopGroup
- submit(Runnable) - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- submit(Runnable, Void) - Method in class org.infinispan.executors.ExecutorAllCompletionService
- submit(Runnable, T) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
- submit(Runnable, T) - Method in class org.infinispan.executors.LazyInitializingExecutorService
- submit(Runnable, T) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
- submit(Runnable, T) - Method in class org.infinispan.executors.SemaphoreCompletionService
- submit(Runnable, T) - Method in class org.infinispan.server.core.transport.NonRecursiveEventLoopGroup
- submit(Runnable, T) - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- submit(Callable<Void>) - Method in class org.infinispan.executors.ExecutorAllCompletionService
- submit(Callable<T>) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
- submit(Callable<T>) - Method in class org.infinispan.executors.LazyInitializingExecutorService
- submit(Callable<T>) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
- submit(Callable<T>) - Method in class org.infinispan.executors.SemaphoreCompletionService
- submit(Callable<T>) - Method in class org.infinispan.server.core.transport.NonRecursiveEventLoopGroup
- submit(Callable<T>) - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- submit(SerializableRunnable) - Method in interface org.infinispan.manager.ClusterExecutor
-
The same as
ClusterExecutor.submit(Runnable)
, except the Runnable must also implement Serializable. - submitConsumer(Function<? super EmbeddedCacheManager, ? extends V>, TriConsumer<? super Address, ? super V, ? super Throwable>) - Method in interface org.infinispan.manager.ClusterExecutor
-
Submits the given command to the desired nodes and allows for handling of results as they return.
- submitConsumer(SerializableFunction<? super EmbeddedCacheManager, ? extends V>, TriConsumer<? super Address, ? super V, ? super Throwable>) - Method in interface org.infinispan.manager.ClusterExecutor
-
The same as
ClusterExecutor.submitConsumer(Function, TriConsumer)
, except the Callable must also implement Serializable. - subscribe(ChannelHandlerContext) - Method in class org.infinispan.rest.stream.CacheChunkedStream
- subscribe(ChannelHandlerContext) - Method in class org.infinispan.rest.stream.CacheEntryStreamProcessor
- subscribe(ChannelHandlerContext) - Method in class org.infinispan.rest.stream.CacheKeyStreamProcessor
- subscribe(Subscriber<? super E>) - Method in class org.infinispan.persistence.support.SingleSegmentPublisher
- subscribe(Subscriber<? super Type>) - Method in class org.infinispan.persistence.support.SegmentPublisherWrapper
- subscribeActual(Subscriber<? super T>) - Method in class org.infinispan.reactive.FlowableCreate
- subscribeBlockingCollector(Publisher<T>, Collector<? super T, A, R>, Object) - Method in interface org.infinispan.util.concurrent.BlockingManager
-
Subscribes to the provided publisher on the invoking thread.
- subscribeBlockingCollector(Publisher<T>, Collector<? super T, A, R>, Object) - Method in class org.infinispan.util.concurrent.BlockingManagerImpl
- subscribeBlockingConsumer(Publisher<E>, Consumer<E>, Object) - Method in interface org.infinispan.util.concurrent.BlockingManager
-
Subscribes to the provided publisher on the invoking thread.
- subscribeBlockingConsumer(Publisher<E>, Consumer<E>, Object) - Method in class org.infinispan.util.concurrent.BlockingManagerImpl
- Success - Enum constant in enum org.infinispan.server.hotrod.OperationStatus
- SUCCESS - Enum constant in enum org.infinispan.client.hotrod.impl.VersionedOperationResponse.RspCode
- SUCCESSFUL_EMPTY_RESPONSE - Static variable in class org.infinispan.remoting.responses.SuccessfulResponse
- SUCCESSFUL_RESPONSE - Static variable in interface org.infinispan.commons.marshall.Ids
- SUCCESSFUL_WRITE_TX_PERCENTAGE - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- SuccessfulResponse<T> - Class in org.infinispan.remoting.responses
-
A successful response
- SuccessfulResponse(T) - Constructor for class org.infinispan.remoting.responses.SuccessfulResponse
- SuccessfulResponse.Externalizer - Class in org.infinispan.remoting.responses
- SuccessObjStorage - Enum constant in enum org.infinispan.server.hotrod.OperationStatus
- successResponse(HotRodHeader, HotRodServer, Channel, CacheEntry<byte[], byte[]>) - Method in class org.infinispan.server.hotrod.Encoder4x
- successResponse(HotRodHeader, HotRodServer, Channel, CacheEntry<byte[], byte[]>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- SuccessWithPrevious - Enum constant in enum org.infinispan.server.hotrod.OperationStatus
- SuccessWithPreviousObjStorage - Enum constant in enum org.infinispan.server.hotrod.OperationStatus
- sum() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- sum() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- sum() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- sum() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- sum() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- sum() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- sum(String) - Static method in interface org.infinispan.query.dsl.Expression
-
Deprecated.
- summaryStatistics() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- summaryStatistics() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- summaryStatistics() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- summaryStatistics() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- summaryStatistics() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- summaryStatistics() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- sumOwned() - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
- sumPrimaryOwned() - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
- SUPERUSER - Static variable in class org.infinispan.security.impl.Authorizer
- SuppliedExternalizer<T> - Class in org.infinispan.commons.marshall
- SuppliedExternalizer(Integer, Class<T>, Supplier<T>) - Constructor for class org.infinispan.commons.marshall.SuppliedExternalizer
- supplier - Variable in class org.infinispan.commons.reactive.AbstractAsyncPublisherHandler
- supplier() - Method in class org.infinispan.commons.dataconversion.internal.JsonArrayCollector
- supplier() - Method in class org.infinispan.commons.util.ArrayCollector
- supplier(Supplier<? extends LocalConfigurationStorage>) - Method in class org.infinispan.configuration.global.GlobalStorageConfigurationBuilder
- supplierBuilder(String, Class<T>) - Static method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
- supply(Supplier<V>, Object) - Method in interface org.infinispan.util.concurrent.BlockingManager.BlockingExecutor
-
Executes the given supplier on the blocking executor.
- supplyBlocking(Supplier<V>, Object) - Method in interface org.infinispan.util.concurrent.BlockingManager
-
Replacement for
CompletionStage.supplyAsync()
that invokes theSupplier
in a blocking thread (if the current thread is non-blocking) or in the current thread (if the current thread is blocking). - supplyBlocking(Supplier<V>, Object) - Method in class org.infinispan.util.concurrent.BlockingManagerImpl
- supportedTypes - Variable in class org.infinispan.commons.dataconversion.OneToManyTranscoder
- supports(MediaType) - Method in interface org.infinispan.commons.dataconversion.Transcoder
- supportsConversion(MediaType, MediaType) - Method in class org.infinispan.commons.dataconversion.DefaultTranscoder
- supportsConversion(MediaType, MediaType) - Method in class org.infinispan.commons.dataconversion.OneToManyTranscoder
- supportsConversion(MediaType, MediaType) - Method in interface org.infinispan.commons.dataconversion.Transcoder
- supportsConversion(MediaType, MediaType) - Method in class org.infinispan.encoding.impl.TwoStepTranscoder
- supportsDuplicates() - Method in interface org.infinispan.multimap.api.BasicMultimapCache
-
Multimap can support duplicates on the same key k → ['a', 'a', 'b'] or not k → ['a', 'b'] depending on configuration.
- supportsDuplicates() - Method in class org.infinispan.multimap.impl.EmbeddedMultimapCache
- supportsFilter(IndexedFilter<?, ?, ?>) - Method in interface org.infinispan.notifications.cachelistener.filter.FilterIndexingServiceProvider
-
Reports whether this provider supports the given filter type.
- SurvivesRestarts - Annotation Type in org.infinispan.factories.annotations
-
This annotation is used for components that will be registered in the
ComponentRegistry
, that are meant to be retained in the component registry even after the component registry is stopped. - SuspectException - Exception in org.infinispan.remoting.transport.jgroups
-
Thrown when a member is suspected during remote method invocation
- SuspectException() - Constructor for exception org.infinispan.remoting.transport.jgroups.SuspectException
- SuspectException(String) - Constructor for exception org.infinispan.remoting.transport.jgroups.SuspectException
- SuspectException(String, Throwable) - Constructor for exception org.infinispan.remoting.transport.jgroups.SuspectException
- SuspectException(String, Address) - Constructor for exception org.infinispan.remoting.transport.jgroups.SuspectException
- SuspectException(String, Address, Throwable) - Constructor for exception org.infinispan.remoting.transport.jgroups.SuspectException
- suspend() - Method in class org.infinispan.commons.tx.TransactionManagerImpl
- SUSPENDED - Enum constant in enum org.infinispan.topology.RebalancingStatus
- suspendIfNeeded() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- suspendIfNeeded() - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
- suspendIfNeeded() - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
- svm - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl
- svm - Variable in class org.infinispan.scattered.impl.ScatteredStateProviderImpl
- swapPrimaryOwnersWithBackups(DefaultConsistentHashFactory.Builder) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
- switchCluster(ClusterInfo) - Method in class org.infinispan.client.hotrod.impl.TopologyInfo
-
Switch to another cluster and update the topologies of all caches with its initial server list.
- switchedBackToMainCluster() - Method in interface org.infinispan.client.hotrod.logging.Log
- switchedToCluster(String) - Method in interface org.infinispan.client.hotrod.logging.Log
- switchToCluster(String) - Method in interface org.infinispan.client.hotrod.jmx.RemoteCacheManagerMXBean
-
Switch remote cache manager to a different cluster, previously declared via configuration.
- switchToCluster(String) - Method in interface org.infinispan.client.hotrod.RemoteCacheContainer
-
Switch remote cache manager to a different cluster, previously declared via configuration.
- switchToCluster(String) - Method in class org.infinispan.client.hotrod.RemoteCacheManager
- switchToDefaultCluster() - Method in interface org.infinispan.client.hotrod.jmx.RemoteCacheManagerMXBean
-
Switch remote cache manager to a the default cluster, previously declared via configuration.
- switchToDefaultCluster() - Method in interface org.infinispan.client.hotrod.RemoteCacheContainer
-
Switch remote cache manager to a the default cluster, previously declared via configuration.
- switchToDefaultCluster() - Method in class org.infinispan.client.hotrod.RemoteCacheManager
- SYBASE - Enum constant in enum org.infinispan.persistence.jdbc.common.DatabaseType
- sync - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
- sync - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
- sync() - Method in interface org.infinispan.counter.api.StrongCounter
-
It returns a synchronous strong counter for this instance.
- sync() - Method in interface org.infinispan.counter.api.WeakCounter
-
It returns a synchronous weak counter for this instance.
- sync() - Element in annotation type org.infinispan.notifications.Listener
-
Specifies whether callbacks on any class annotated with this annotation happens synchronously or asynchronously.
- SYNC - Enum constant in enum org.infinispan.configuration.cache.BackupConfiguration.BackupStrategy
- SYNC - Enum constant in enum org.infinispan.configuration.parsing.CacheParser.Mode
- SYNC - Enum constant in enum org.infinispan.configuration.parsing.Element
- SYNC - Enum constant in enum org.infinispan.expiration.TouchMode
-
Delay read operations until the other owners confirm updating the timestamp of the entry
- SYNC - Enum constant in enum org.infinispan.functional.Param.ReplicationMode
-
Command is completed when all owners are updated.
- SYNC_COMMIT_TIME - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- SYNC_CONSISTENT_HASH_FACTORY - Static variable in interface org.infinispan.commons.marshall.Ids
- SYNC_GET_TIME - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- SYNC_PREPARE_TIME - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- SYNC_REPLICATED_CONSISTENT_HASH_FACTORY - Static variable in interface org.infinispan.commons.marshall.Ids
- SYNC_ROLLBACK_TIME - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- SYNC_WRITES - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- SYNC_WRITES - Static variable in class org.infinispan.persistence.sifs.configuration.DataConfiguration
- syncBackupsStream() - Method in class org.infinispan.configuration.cache.SitesConfiguration
- SyncConsistentHashFactory - Class in org.infinispan.distribution.ch.impl
-
ConsistentHashFactory
implementation that guarantees that multiple caches with the same members will have the same consistent hash (unlikeDefaultConsistentHashFactory
). - SyncConsistentHashFactory() - Constructor for class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory
- SyncConsistentHashFactory.Externalizer - Class in org.infinispan.distribution.ch.impl
- SynchronizationAdapter - Class in org.infinispan.transaction.synchronization
-
Synchronization
implementation for integrating with the TM. - SynchronizationAdapter(LocalTransaction, TransactionTable) - Constructor for class org.infinispan.transaction.synchronization.SynchronizationAdapter
- synchronizeData(String) - Method in class org.infinispan.upgrade.RollingUpgradeManager
- synchronizeData(String, int, int) - Method in class org.infinispan.upgrade.RollingUpgradeManager
- synchronizeData(Cache<Object, Object>) - Method in class org.infinispan.persistence.remote.upgrade.HotRodTargetMigrator
- synchronizeData(Cache<Object, Object>) - Method in interface org.infinispan.upgrade.TargetMigrator
-
Performs the synchronization of data between source and target
- synchronizeData(Cache<Object, Object>, int, int) - Method in class org.infinispan.persistence.remote.upgrade.HotRodTargetMigrator
- synchronizeData(Cache<Object, Object>, int, int) - Method in interface org.infinispan.upgrade.TargetMigrator
-
Performs the synchronization of data between source and target
- synchronizedEntries(long) - Method in interface org.infinispan.rest.logging.Log
- SynchronizedRestarter - Class in org.infinispan.util.concurrent
-
A class that handles restarts of components via multiple threads.
- SynchronizedRestarter() - Constructor for class org.infinispan.util.concurrent.SynchronizedRestarter
- SYNCHRONOUS - Enum constant in enum org.infinispan.remoting.rpc.ResponseMode
- SYNCHRONOUS_IGNORE_LEAVERS - Enum constant in enum org.infinispan.remoting.rpc.ResponseMode
-
Most commands should use this mode to prevent SuspectExceptions when we are doing a broadcast (or anycast that translates to JGroups broadcast).
- SyncInvocationStage - Class in org.infinispan.interceptors
- SyncInvocationStage() - Constructor for class org.infinispan.interceptors.SyncInvocationStage
- SyncInvocationStage(Object) - Constructor for class org.infinispan.interceptors.SyncInvocationStage
- SyncLocalTransaction - Class in org.infinispan.transaction.synchronization
-
LocalTransaction
implementation to be used withSynchronizationAdapter
. - SyncLocalTransaction(Transaction, GlobalTransaction, boolean, int, long) - Constructor for class org.infinispan.transaction.synchronization.SyncLocalTransaction
- SyncProviderState - Class in org.infinispan.xsite.statetransfer
-
A
XSiteStateProviderState
for synchronous cross-site replication state transfer. - SyncReplicatedConsistentHashFactory - Class in org.infinispan.distribution.ch.impl
-
SyncConsistentHashFactory
adapted for replicated caches, so that the primary owner of a key is the same in replicated and distributed caches. - SyncReplicatedConsistentHashFactory() - Constructor for class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory
- SyncReplicatedConsistentHashFactory.Externalizer - Class in org.infinispan.distribution.ch.impl
- SyncStrongCounter - Class in org.infinispan.counter
-
Deprecated, for removal: This API element is subject to removal in a future version.since 9.2. Use
StrongCounter.sync()
instead. It will be removed in 10.0 - SyncStrongCounter - Interface in org.infinispan.counter.api
-
A synchronous
StrongCounter
. - SyncStrongCounter(StrongCounter) - Constructor for class org.infinispan.counter.SyncStrongCounter
-
Deprecated.
- SyncStrongCounterAdapter - Class in org.infinispan.counter.impl
-
A
StrongCounter
decorator that waits for the operation to complete. - SyncStrongCounterAdapter(StrongCounter) - Constructor for class org.infinispan.counter.impl.SyncStrongCounterAdapter
- SyncWeakCounter - Class in org.infinispan.counter
-
Deprecated, for removal: This API element is subject to removal in a future version.since 9.2. Use
WeakCounter.sync()
instead. It will be removed in 10.0 - SyncWeakCounter - Interface in org.infinispan.counter.api
-
A synchronous
WeakCounter
. - SyncWeakCounter(WeakCounter) - Constructor for class org.infinispan.counter.SyncWeakCounter
-
Deprecated.
- SyncWeakCounterAdapter - Class in org.infinispan.counter.impl
-
A
WeakCounter
decorator that waits for the operation to complete. - SyncWeakCounterAdapter(WeakCounter) - Constructor for class org.infinispan.counter.impl.SyncWeakCounterAdapter
- syncWrites() - Method in class org.infinispan.persistence.sifs.configuration.DataConfiguration
- syncWrites() - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfiguration
- syncWrites(boolean) - Method in class org.infinispan.persistence.sifs.configuration.DataConfigurationBuilder
- syncWrites(boolean) - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
-
Sets whether writes shoud wait to be fsynced to disk.
T
- tab() - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- table() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfiguration
- table() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
-
Allows configuration of table-specific parameters such as column names and types
- TABLE_JDBC_STORE - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
- TABLE_NAME - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
- TABLE_NAME_PREFIX - Static variable in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- TableJdbcStore<K,
V> - Class in org.infinispan.persistence.sql - TableJdbcStore() - Constructor for class org.infinispan.persistence.sql.TableJdbcStore
- TableJdbcStore.TableTableOperations - Class in org.infinispan.persistence.sql
- TableJdbcStoreConfiguration - Class in org.infinispan.persistence.sql.configuration
- TableJdbcStoreConfiguration(AttributeSet, AsyncStoreConfiguration, ConnectionFactoryConfiguration, SchemaJdbcConfiguration) - Constructor for class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfiguration
- TableJdbcStoreConfigurationBuilder - Class in org.infinispan.persistence.sql.configuration
-
TableJdbcStoreConfigurationBuilder.
- TableJdbcStoreConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfigurationBuilder
- TableJdbcStoreConfigurationSerializer - Class in org.infinispan.persistence.sql.configuration
-
TableJdbcStoreConfigurationSerializer.
- TableJdbcStoreConfigurationSerializer() - Constructor for class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfigurationSerializer
- tableManipulationAttributeNotSet(String, String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- TableManipulationConfiguration - Class in org.infinispan.persistence.jdbc.configuration
- TableManipulationConfigurationBuilder<B extends AbstractJdbcStoreConfigurationBuilder<?,
B>, S extends TableManipulationConfigurationBuilder<B, S>> - Class in org.infinispan.persistence.jdbc.configuration -
TableManipulationConfigurationBuilder.
- tableName() - Method in class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfiguration
- tableName(String) - Method in class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfigurationBuilder
-
Configures the table name to use for this store
- tableNameMissing() - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- tableNamePrefix() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- tableNamePrefix(String) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
-
Sets the prefix for the name of the table where the data will be stored.
- tableNotInCorrectFormat(String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- tableOperations - Variable in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
- TableOperations<K,
V> - Interface in org.infinispan.persistence.jdbc.common - TableTableOperations(AbstractSchemaJdbcStore.ProtoSchemaOptions<K, V, TableJdbcStoreConfiguration>, AbstractSchemaJdbcStore.Parameter[]) - Constructor for class org.infinispan.persistence.sql.TableJdbcStore.TableTableOperations
- Tag(String) - Constructor for class org.infinispan.commons.configuration.io.AbstractConfigurationWriter.Tag
- Tag(String, boolean, boolean, boolean) - Constructor for class org.infinispan.commons.configuration.io.AbstractConfigurationWriter.Tag
- tagStack - Variable in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- take() - Method in class org.infinispan.executors.ExecutorAllCompletionService
- take() - Method in class org.infinispan.executors.SemaphoreCompletionService
- TAKE_BACKUP_OFFLINE_AFTER_FAILURES - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- TAKE_BACKUP_OFFLINE_MIN_WAIT - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- TAKE_OFFLINE - Enum constant in enum org.infinispan.configuration.parsing.Element
- TAKEN_OFFLINE - Enum constant in enum org.infinispan.xsite.status.TakeSiteOfflineResponse
- takeOffline() - Method in class org.infinispan.configuration.cache.BackupConfiguration
- takeOffline() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
- TakeOfflineConfiguration - Class in org.infinispan.configuration.cache
- TakeOfflineConfiguration(AttributeSet) - Constructor for class org.infinispan.configuration.cache.TakeOfflineConfiguration
- TakeOfflineConfigurationBuilder - Class in org.infinispan.configuration.cache
- TakeOfflineConfigurationBuilder(ConfigurationBuilder, BackupConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
- TakeOfflineManager - Interface in org.infinispan.xsite.status
-
It keeps tracks of cross-site requests to take sites offline when certain failures conditions happen.
- takeSiteOffline(String) - Method in class org.infinispan.xsite.status.DefaultTakeOfflineManager
- takeSiteOffline(String) - Method in class org.infinispan.xsite.status.NoOpTakeOfflineManager
- takeSiteOffline(String) - Method in interface org.infinispan.xsite.status.TakeOfflineManager
-
It changes the site
siteName
to offline. - TakeSiteOfflineResponse - Enum in org.infinispan.xsite.status
-
The return value of
TakeOfflineManager.takeSiteOffline(String)
. - TANDALONE - Static variable in class org.infinispan.commons.configuration.io.xml.MXParser
- target - Variable in class org.infinispan.notifications.impl.AbstractListenerImpl.AbstractInvocationBuilder
- TARGET_NODE - Static variable in interface org.infinispan.metrics.Constants
- targetComplete() - Method in class org.infinispan.commons.reactive.AbstractAsyncPublisherHandler
-
Method to invoke when a given target is found to have been completed and the next target should be used
- TargetMigrator - Interface in org.infinispan.upgrade
-
Performs migration operations on the target server or cluster of servers
- targetNotFound(Address) - Method in class org.infinispan.remoting.transport.impl.SingleResponseCollector
- targetNotFound(Address) - Method in class org.infinispan.remoting.transport.impl.SingletonMapResponseCollector
- targetNotFound(Address) - Method in class org.infinispan.remoting.transport.ValidSingleResponseCollector
- targets - Variable in class org.infinispan.notifications.cachelistener.cluster.impl.BatchingClusterEventManagerImpl.UnicastEventContext
- targetType() - Method in interface org.infinispan.search.mapper.mapping.EntityConverter
- Task - Interface in org.infinispan.tasks
- TaskContext - Class in org.infinispan.tasks
-
TaskContext.
- TaskContext() - Constructor for class org.infinispan.tasks.TaskContext
- TaskContext(TaskContext) - Constructor for class org.infinispan.tasks.TaskContext
- TaskExecutionMode - Enum in org.infinispan.tasks
- TaskInstantiationMode - Enum in org.infinispan.tasks
- taskProcessor - Variable in class org.infinispan.server.hotrod.HotRodDecoder
- TaskRequestProcessor - Class in org.infinispan.server.hotrod
- TASKS - Enum constant in enum org.infinispan.server.core.BackupManager.Resources.Type
- TasksResource - Class in org.infinispan.rest.resources
- TasksResource(InvocationHelper) - Constructor for class org.infinispan.rest.resources.TasksResource
- TCP(Properties) - Static method in class org.infinispan.remoting.transport.jgroups.BuiltinJGroupsChannelConfigurator
- TCP_KEEP_ALIVE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- TCP_KEEPALIVE - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- TCP_NO_DELAY - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- TCP_NO_DELAY - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- TCP_NODELAY - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- TCP_STACK_NAME - Static variable in class org.infinispan.remoting.transport.jgroups.BuiltinJGroupsChannelConfigurator
- tcpKeepAlive() - Method in class org.infinispan.client.hotrod.configuration.Configuration
- tcpKeepAlive() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- tcpKeepAlive(boolean) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
- tcpKeepAlive(boolean) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- tcpKeepAlive(boolean) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
-
Affects TCP KEEPALIVE on the TCP stack.
- tcpKeepAlive(boolean) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- tcpKeepAlive(boolean) - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
- tcpKeepAlive(boolean) - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- tcpKeepAlive(boolean) - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
-
Affects TCP KEEPALIVE on the TCP stack.
- tcpNoDelay() - Method in class org.infinispan.client.hotrod.configuration.Configuration
- tcpNoDelay() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
- tcpNoDelay() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- tcpNoDelay(boolean) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
- tcpNoDelay(boolean) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- tcpNoDelay(boolean) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
-
Affects TCP NODELAY on the TCP stack.
- tcpNoDelay(boolean) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- tcpNoDelay(boolean) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- tcpNoDelay(boolean) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
-
Affects TCP NODELAY on the TCP stack.
- tcpNoDelay(boolean) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- tcpNoDelay(boolean) - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
- tcpNoDelay(boolean) - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- tcpNoDelay(boolean) - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
-
Affects TCP NODELAY on the TCP stack.
- TEBIBYTES - Enum constant in enum org.infinispan.commons.util.MemoryUnit
-
Deprecated.
- telemetryService(boolean) - Method in class org.infinispan.client.hotrod.telemetry.impl.TelemetryServiceFactory
- TelemetryService - Interface in org.infinispan.client.hotrod.telemetry.impl
- TelemetryService - Interface in org.infinispan.server.core.telemetry
- TelemetryService.NoTelemetry - Class in org.infinispan.server.core.telemetry
- TelemetryServiceFactory - Class in org.infinispan.client.hotrod.telemetry.impl
- TelemetryServiceFactory - Class in org.infinispan.server.core.telemetry
- TelemetryServiceFactory() - Constructor for class org.infinispan.server.core.telemetry.TelemetryServiceFactory
- TelemetryServiceImpl - Class in org.infinispan.client.hotrod.telemetry.impl
- TelemetryServiceImpl() - Constructor for class org.infinispan.client.hotrod.telemetry.impl.TelemetryServiceImpl
- template() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- template(boolean) - Method in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
- template(boolean) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- template(boolean) - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- TEMPLATE_NAME - Static variable in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
- TEMPLATE_SCOPE - Static variable in class org.infinispan.globalstate.impl.GlobalConfigurationManagerImpl
- TemplateCreateTask - Class in org.infinispan.server.core.admin.embeddedserver
-
* Admin operation to create a template * Parameters: * * name the name of the template to create * configuration the XML configuration to use * flags any flags, e.g.
- TemplateCreateTask() - Constructor for class org.infinispan.server.core.admin.embeddedserver.TemplateCreateTask
- templateName() - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
- templateName(String) - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfigurationBuilder
-
Specifies the name of a template to be used to create the cache if it doesn't already exist on the server.
- templateName(DefaultTemplate) - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfigurationBuilder
-
Specifies one of the default templates to be used to create the cache if it doesn't already exist on the server.
- TemplateNamesTask - Class in org.infinispan.server.core.admin.embeddedserver
-
Admin operation to obtain a list of caches
- TemplateNamesTask() - Constructor for class org.infinispan.server.core.admin.embeddedserver.TemplateNamesTask
- TemplateRemoveTask - Class in org.infinispan.server.core.admin.embeddedserver
-
* Admin operation to remove a template * Parameters: * * name the name of the template to remove * flags any flags, e.g.
- TemplateRemoveTask() - Constructor for class org.infinispan.server.core.admin.embeddedserver.TemplateRemoveTask
- TEMPLATES - Enum constant in enum org.infinispan.server.core.BackupManager.Resources.Type
- TEMPORARY_LOCATION - Enum constant in enum org.infinispan.configuration.parsing.Element
- TemporaryGlobalStatePathConfiguration - Class in org.infinispan.configuration.global
- TemporaryGlobalStatePathConfiguration(AttributeSet, String) - Constructor for class org.infinispan.configuration.global.TemporaryGlobalStatePathConfiguration
- TemporaryGlobalStatePathConfigurationBuilder - Class in org.infinispan.configuration.global
- temporaryLocation() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
-
Returns the filesystem path where temporary state should be stored.
- temporaryLocation(String) - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
-
Defines the filesystem path where temporary state should be stored.
- temporaryLocation(String, String) - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
- temporaryLocationConfiguration() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
- TemporaryTable - Class in org.infinispan.persistence.sifs
-
Table holding the entry positions in log before these are persisted to the index.
- TemporaryTable(int) - Constructor for class org.infinispan.persistence.sifs.TemporaryTable
- TemporaryTable.LockedEntry - Class in org.infinispan.persistence.sifs
- tenantIdentifier() - Method in class org.infinispan.search.mapper.session.impl.InfinispanSearchSession
- TERABYTES - Enum constant in enum org.infinispan.commons.util.MemoryUnit
-
Deprecated.
- TERMINAL_OPERATIONS - Static variable in interface org.infinispan.commons.marshall.Ids
- TerminalOperation<Original,
R> - Interface in org.infinispan.stream.impl -
Interface describing an operation that is a terminal one that doesn't track keys.
- terminate() - Method in class org.infinispan.extendedstats.LocalTransactionStatistics
- terminate() - Method in class org.infinispan.extendedstats.RemoteTransactionStatistics
- terminate() - Method in class org.infinispan.extendedstats.TransactionStatistics
-
Signals this transaction as completed and updates the statistics to the final values ready to be merged in the cache statistics.
- TERMINATED - Enum constant in enum org.infinispan.lifecycle.ComponentStatus
-
The
stop()
method has completed and the component has terminated. - terminateTransaction() - Method in class org.infinispan.extendedstats.TransactionStatistics
-
Signals this transaction as completed and updates the statistics to the final values ready to be merged in the cache statistics.
- terminateTransaction(GlobalTransaction, boolean, boolean) - Method in class org.infinispan.extendedstats.CacheStatisticManager
-
Signals the ending of a transaction.
- terminationFuture() - Method in class org.infinispan.server.core.utils.DelegatingEventLoopGroup
- test(K) - Method in class org.infinispan.distribution.group.impl.GroupFilter
- test(CacheEntry<K, ?>) - Method in class org.infinispan.distribution.group.impl.CacheEntryGroupPredicate
- test(ScopedState) - Method in class org.infinispan.globalstate.ScopeFilter
- test(CacheXid) - Method in class org.infinispan.server.hotrod.tx.table.functions.XidPredicate
- test(T, U, V) - Method in interface org.infinispan.util.function.TriPredicate
-
Evaluates this predicate on the given arguments.
- TEST_WHILE_IDLE - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- testListenerClassValidity(Class<?>) - Static method in class org.infinispan.notifications.impl.AbstractListenerImpl
-
Tests if a class is properly annotated as a CacheListener and returns the Listener annotation.
- testListenerMethodValidity(Method, Class<?>, String) - Static method in class org.infinispan.notifications.impl.AbstractListenerImpl
-
Tests that a method is a valid listener method, that is that it has a single argument that is assignable to allowedParameter.
- testWhileIdle(boolean) - 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. This method has no effect
- text - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- TEXT - Enum constant in enum org.infinispan.commons.configuration.io.ConfigurationReader.ElementType
- TEXT - Static variable in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
-
Character data was read and will is available by calling getText().
- TEXT_CSS - Static variable in class org.infinispan.commons.dataconversion.MediaType
- TEXT_CSS_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- TEXT_CSV - Static variable in class org.infinispan.commons.dataconversion.MediaType
- TEXT_CSV_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- TEXT_EVENT_STREAM - Static variable in class org.infinispan.commons.dataconversion.MediaType
- TEXT_EVENT_STREAM_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- TEXT_HTML - Static variable in class org.infinispan.commons.dataconversion.MediaType
- TEXT_HTML_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- TEXT_PLAIN - Static variable in class org.infinispan.commons.dataconversion.MediaType
- TEXT_PLAIN_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- TextProtocolUtil - Class in org.infinispan.server.memcached
-
Memcached text protocol utilities.
- thenAccept(InvocationContext, C, InvocationSuccessAction<C>) - Method in class org.infinispan.interceptors.InvocationStage
-
After the current stage completes successfully, invoke
action
. - thenAccept(InvocationContext, C, InvocationSuccessAction<C>) - Method in class org.infinispan.interceptors.SyncInvocationStage
- thenAccept(InvocationContext, VisitableCommand, InvocationSuccessAction) - Method in class org.infinispan.interceptors.ExceptionSyncInvocationStage
- thenAcceptMakeStage(InvocationContext, C, InvocationSuccessAction<C>) - Method in class org.infinispan.interceptors.InvocationStage
-
After the current stage completes successfully, invoke
action
. - thenAcceptMakeStage(InvocationContext, C, InvocationSuccessAction<C>) - Method in class org.infinispan.interceptors.SyncInvocationStage
- thenApply(InvocationContext, C, InvocationSuccessFunction<C>) - Method in class org.infinispan.interceptors.InvocationStage
-
After the current stage completes successfully, invoke
function
and return its result. - thenApply(InvocationContext, C, InvocationSuccessFunction<C>) - Method in class org.infinispan.interceptors.SyncInvocationStage
- thenApply(InvocationContext, VisitableCommand, InvocationSuccessFunction) - Method in class org.infinispan.interceptors.ExceptionSyncInvocationStage
- thenApplyBlocking(CompletionStage<? extends I>, Function<? super I, ? extends O>, Object) - Method in interface org.infinispan.util.concurrent.BlockingManager
-
Replacement for
CompletionStage.thenApplyAsync()
that invokes theFunction
in a blocking thread (if the current thread is non-blocking) or in the current thread (if the current thread is blocking and the stage is completed). - thenApplyBlocking(CompletionStage<? extends I>, Function<? super I, ? extends O>, Object) - Method in class org.infinispan.util.concurrent.BlockingManagerImpl
- thenApplyMakeStage(InvocationContext, C, InvocationSuccessFunction<C>) - Method in class org.infinispan.interceptors.InvocationStage
-
After the current stage completes successfully, invoke
function
and return its result. - thenApplyMakeStage(InvocationContext, C, InvocationSuccessFunction<C>) - Method in class org.infinispan.interceptors.SyncInvocationStage
-
After the current stage completes successfully, invoke
function
and return its result. - thenComposeBlocking(CompletionStage<? extends I>, Function<? super I, ? extends CompletionStage<O>>, Object) - Method in interface org.infinispan.util.concurrent.BlockingManager
-
Replacement for
CompletionStage.thenComposeAsync()
that invokes theFunction
in a blocking thread (if the current thread is non-blocking) or in the current thread (if the current thread is blocking and the stage is completed). - thenComposeBlocking(CompletionStage<? extends I>, Function<? super I, ? extends CompletionStage<O>>, Object) - Method in class org.infinispan.util.concurrent.BlockingManagerImpl
- thenReturn(InvocationContext, VisitableCommand, Object) - Method in class org.infinispan.interceptors.ExceptionSyncInvocationStage
- thenReturn(InvocationContext, VisitableCommand, Object) - Method in class org.infinispan.interceptors.InvocationStage
-
Overrides the return value of this
InvocationStage
if it is completed successfully. - thenReturn(InvocationContext, VisitableCommand, Object) - Method in class org.infinispan.interceptors.SyncInvocationStage
- thenRunBlocking(CompletionStage<? extends I>, Runnable, Object) - Method in interface org.infinispan.util.concurrent.BlockingManager
-
Replacement for
CompletionStage.thenRunAsync(Runnable)
that invokes theRunnable
in a blocking thread (if the current thread is non-blocking) or in the current thread (if the current thread is blocking and the stage is completed). - thenRunBlocking(CompletionStage<? extends I>, Runnable, Object) - Method in class org.infinispan.util.concurrent.BlockingManagerImpl
- THREAD_FACTORIES - Enum constant in enum org.infinispan.configuration.parsing.Element
- THREAD_FACTORY - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- THREAD_FACTORY - Enum constant in enum org.infinispan.configuration.parsing.Element
- THREAD_NAME_PATTERN - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- THREAD_POLICY - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- THREAD_POOL_SIZE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- THREAD_POOL_SIZE - Static variable in class org.infinispan.configuration.cache.AsyncStoreConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.
- THREAD_POOLS - Enum constant in enum org.infinispan.configuration.parsing.Element
- ThreadCreator - Class in org.infinispan.commons.jdkspecific
- ThreadCreator() - Constructor for class org.infinispan.commons.jdkspecific.ThreadCreator
- threadDump() - Static method in class org.infinispan.commons.util.Util
- threadFactories() - Method in class org.infinispan.configuration.global.ThreadsConfiguration
- threadFactory() - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
- threadFactory() - Method in class org.infinispan.configuration.global.CachedThreadPoolConfigurationBuilder
- threadFactory() - Method in class org.infinispan.configuration.global.ScheduledThreadPoolConfigurationBuilder
- threadFactory() - Method in class org.infinispan.configuration.global.ThreadPoolConfiguration
- threadFactory(String) - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
- threadFactory(String) - Method in class org.infinispan.configuration.global.CachedThreadPoolConfigurationBuilder
- threadFactory(String) - Method in class org.infinispan.configuration.global.ScheduledThreadPoolConfigurationBuilder
- threadFactory(ThreadFactory) - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
- ThreadFactoryConfigurationBuilder - Class in org.infinispan.configuration.global
- threadGroup() - Method in class org.infinispan.factories.threads.DefaultThreadFactory
- ThreadGroups - Interface in org.infinispan.commons
- ThreadGroups.ISPNBlockingThreadGroup - Class in org.infinispan.commons
- ThreadGroups.ISPNNonBlockingThreadGroup - Class in org.infinispan.commons
- threadLocalRandomUUID() - Static method in class org.infinispan.commons.util.Util
-
Uses a
ThreadLocalRandom
to generate a UUID. - ThreadNameInfo - Class in org.infinispan.factories.threads
- threadNamePattern() - Method in class org.infinispan.configuration.global.ThreadFactoryConfigurationBuilder
- threadNamePattern() - Method in class org.infinispan.factories.threads.DefaultThreadFactory
- threadNamePattern(String) - Method in class org.infinispan.configuration.global.ThreadFactoryConfigurationBuilder
- ThreadPoolBuilderAdapter - Interface in org.infinispan.configuration.global
- ThreadPoolConfiguration - Class in org.infinispan.configuration.global
- ThreadPoolConfiguration(String, ThreadFactory, ThreadPoolExecutorFactory) - Constructor for class org.infinispan.configuration.global.ThreadPoolConfiguration
- ThreadPoolConfigurationBuilder - Class in org.infinispan.configuration.global
- ThreadPoolConfigurationBuilder(GlobalConfigurationBuilder) - Constructor for class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
- ThreadPoolExecutorFactory<T extends ExecutorService> - Interface in org.infinispan.commons.executors
- threadPoolFactory() - Method in class org.infinispan.configuration.global.ThreadPoolConfiguration
- threadPoolFactory(ThreadPoolExecutorFactory) - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
- threadPoolProvider() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
- threadPoolSize() - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.since 11.0 with no replacement as the thread pool is no longer used
- threadPoolSize(int) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.since 11.0 with no replacement as the thread pool is no longer used
- threadPoolSize(int) - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
- threads() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
- threads() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- THREADS - Enum constant in enum org.infinispan.configuration.parsing.Element
- ThreadsConfiguration - Class in org.infinispan.configuration.global
- ThreadsConfigurationBuilder - Class in org.infinispan.configuration.global
- THRESHOLD - Static variable in class org.infinispan.affinity.impl.KeyAffinityServiceImpl
- THROUGHPUT - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- throwableArray(int) - Static method in class org.infinispan.commons.util.Util
- throwableDuringPublisher(Throwable) - Method in interface org.infinispan.client.hotrod.logging.Log
- ThrowableExternalizer - Class in org.infinispan.marshall.exts
- ThrowableExternalizer() - Constructor for class org.infinispan.marshall.exts.ThrowableExternalizer
- time() - Method in class org.infinispan.client.hotrod.impl.ClientStatistics
- time() - Method in class org.infinispan.commons.time.DefaultTimeService
- time() - Method in interface org.infinispan.commons.time.TimeService
- TIME_BETWEEN_EVICTION_RUNS - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- TIME_SINCE_START - Static variable in interface org.infinispan.client.hotrod.ServerStatistics
-
Number of seconds since Hot Rod started.
- TIME_TO_LIVE_HEADER - Enum constant in enum org.infinispan.rest.ResponseHeader
- timeBetweenEvictionRuns(long) - 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. This method has no effect
- TIMED_OUT - Enum constant in enum org.infinispan.util.concurrent.locks.LockState
-
The time out occurred while the lock owner waits on the queue.
- timeDuration(long, long, TimeUnit) - Method in class org.infinispan.commons.time.DefaultTimeService
- timeDuration(long, long, TimeUnit) - Method in interface org.infinispan.commons.time.TimeService
- timeDuration(long, TimeUnit) - Method in class org.infinispan.commons.time.DefaultTimeService
- timeDuration(long, TimeUnit) - Method in interface org.infinispan.commons.time.TimeService
-
It is equivalent to
timeDuration(startTime, time(), outputTimeUnit)
. - TimeGaugeMetricInfo<T> - Class in org.infinispan.commons.stat
-
Same as
GaugeMetricInfo
but the tracked value is a time or duration. - TimeGaugeMetricInfo(String, String, Map<String, String>, Function<T, Number>, TimeUnit) - Constructor for class org.infinispan.commons.stat.TimeGaugeMetricInfo
- timeout - Variable in class org.infinispan.server.hotrod.command.tx.ForwardCommitCommand
- timeout - Variable in class org.infinispan.stream.impl.AbstractCacheStream
- timeout() - Method in class org.infinispan.client.hotrod.configuration.TransactionConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.
- timeout() - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
-
This is the maximum amount of time - in milliseconds - to wait for state from neighboring caches, before throwing an exception and aborting startup.
- timeout() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- timeout() - Method in class org.infinispan.remoting.rpc.RpcOptions
- timeout(long) - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 12.1, the attribute was never writable
- timeout(long) - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
-
This is the maximum amount of time - in milliseconds - to wait for state from neighboring caches, before throwing an exception and aborting startup.
- timeout(long) - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
-
The time (in milliseconds) to wait for the backup site acknowledge the state chunk received and applied.
- timeout(long, TimeUnit) - Method in interface org.infinispan.BaseCacheStream
-
Sets a given time to wait for a remote operation to respond by.
- timeout(long, TimeUnit) - Method in interface org.infinispan.CacheStream
-
Sets a given time to wait for a remote operation to respond by.
- timeout(long, TimeUnit) - Method in class org.infinispan.client.hotrod.configuration.TransactionConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.since 12.0. To be removed in Infinispan 14. Use
ConfigurationBuilder.transactionTimeout(long, TimeUnit)
- timeout(long, TimeUnit) - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
-
This is the maximum amount of time - in milliseconds - to wait for state from neighboring caches, before throwing an exception and aborting startup.
- timeout(long, TimeUnit) - Method in interface org.infinispan.DoubleCacheStream
-
Sets a given time to wait for a remote operation to respond by.
- timeout(long, TimeUnit) - Method in interface org.infinispan.IntCacheStream
-
Sets a given time to wait for a remote operation to respond by.
- timeout(long, TimeUnit) - Method in interface org.infinispan.LockedStream
-
Sets the timeout for the acquisition of the lock for each entry.
- timeout(long, TimeUnit) - Method in interface org.infinispan.LongCacheStream
-
Sets a given time to wait for a remote operation to respond by.
- timeout(long, TimeUnit) - Method in interface org.infinispan.manager.ClusterExecutor
-
Sets a duration after which a command will timeout.
- timeout(long, TimeUnit) - Method in interface org.infinispan.query.dsl.Query
-
Set the timeout for this query.
- timeout(long, TimeUnit) - Method in interface org.infinispan.query.impl.IndexedQuery
-
Set the timeout for this query.
- timeout(long, TimeUnit) - Method in class org.infinispan.query.impl.IndexedQueryImpl
- timeout(long, TimeUnit) - Method in class org.infinispan.stream.impl.DistributedCacheStream
- timeout(long, TimeUnit) - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- timeout(long, TimeUnit) - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- timeout(long, TimeUnit) - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- timeout(long, TimeUnit) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- timeout(long, TimeUnit) - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- timeout(long, TimeUnit) - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- timeout(long, TimeUnit) - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- timeout(long, TimeUnit) - Method in class org.infinispan.stream.impl.LockedStreamImpl
- timeout(long, TimeUnit) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- TIMEOUT - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- TIMEOUT - Static variable in class org.infinispan.configuration.cache.StateTransferConfiguration
- TIMEOUT - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- TIMEOUT_SCHEDULE_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
- TimeoutEnabledChannelInitializer<C extends ProtocolServerConfiguration> - Class in org.infinispan.server.hotrod.transport
-
A channel pipeline factory for environments where idle timeout is enabled.
- TimeoutEnabledChannelInitializer(ProtocolServer<C>) - Constructor for class org.infinispan.server.hotrod.transport.TimeoutEnabledChannelInitializer
- TimeoutException - Exception in org.infinispan.util.concurrent
-
Thrown when a timeout occurred.
- TimeoutException() - Constructor for exception org.infinispan.util.concurrent.TimeoutException
- TimeoutException(String) - Constructor for exception org.infinispan.util.concurrent.TimeoutException
- TimeoutException(String, Throwable) - Constructor for exception org.infinispan.util.concurrent.TimeoutException
- timeoutExecutor - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- timeoutUnit - Variable in class org.infinispan.stream.impl.AbstractCacheStream
- TimerMetricInfo<T> - Class in org.infinispan.commons.stat
-
Represents a duration event (histogram).
- TimerMetricInfo(String, String, Map<String, String>, BiConsumer<T, TimerTracker>) - Constructor for class org.infinispan.commons.stat.TimerMetricInfo
- TimerTracker - Interface in org.infinispan.commons.stat
-
Tracks a timer metric.
- timeService - Variable in class org.infinispan.container.impl.AbstractInternalDataContainer
- timeService - Variable in class org.infinispan.expiration.impl.ExpirationManagerImpl
- timeService - Variable in class org.infinispan.extendedstats.TransactionStatistics
- timeService - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- timeService - Variable in class org.infinispan.server.hotrod.tx.table.functions.TxFunction
- TimeService - Interface in org.infinispan.commons.time
-
Encapsulates all the time related logic in this interface.
- TimeServiceTicker - Class in org.infinispan.commons.time
-
A Ticker for Caffeine backed by a TimeService
- TimeServiceTicker(TimeService) - Constructor for class org.infinispan.commons.time.TimeServiceTicker
- TIMESTAMP - Static variable in class org.infinispan.globalstate.impl.GlobalStateManagerImpl
- TIMESTAMP_COLUMN - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
- TIMESTAMP_COLUMN_NAME - Static variable in class org.infinispan.persistence.jdbc.configuration.TimestampColumnConfiguration
- TIMESTAMP_COLUMN_TYPE - Static variable in class org.infinispan.persistence.jdbc.configuration.TimestampColumnConfiguration
- timeStampColumnConfiguration() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- TimestampColumnConfiguration - Class in org.infinispan.persistence.jdbc.configuration
- TimestampColumnConfiguration(AttributeSet) - Constructor for class org.infinispan.persistence.jdbc.configuration.TimestampColumnConfiguration
- TimestampColumnConfigurationBuilder - Class in org.infinispan.persistence.jdbc.configuration
- timestampColumnName() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- timestampColumnName(String) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
-
The name of the database column used to store the timestamps
- timestampColumnType() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- timestampColumnType(String) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
-
The type of the database column used to store the timestamps
- timeToLive(long) - Method in class org.infinispan.rest.NettyRestResponse.Builder
- timeUnit() - Method in class org.infinispan.remoting.rpc.RpcOptions
- TimeUnitParam - Class in org.infinispan.client.hotrod.impl
-
Time unit representation for HotRod
- TimeUnitParam() - Constructor for class org.infinispan.client.hotrod.impl.TimeUnitParam
- TimeUnitValue - Enum in org.infinispan.server.hotrod
- to(OutputStream) - Static method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- to(Writer) - Static method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- toAPI() - Method in class org.infinispan.search.mapper.search.loading.context.impl.InfinispanLoadingContext.Builder
- toArray() - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
- toArray() - Method in class org.infinispan.cache.impl.SimpleCacheImpl.EntrySetBase
- toArray() - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
- toArray() - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
- toArray() - Method in class org.infinispan.commons.util.ForwardingList
- toArray() - Method in class org.infinispan.commons.util.ImmutableHopscotchHashSet
- toArray() - Method in class org.infinispan.commons.util.ImmutableIntSet
-
Deprecated.
- toArray() - Method in class org.infinispan.commons.util.ImmutableListCopy
- toArray() - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- toArray() - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- toArray() - Method in class org.infinispan.InternalCacheSet
- toArray() - Static method in enum org.infinispan.rest.RequestHeader
- toArray() - Static method in enum org.infinispan.rest.ResponseHeader
- toArray() - Method in class org.infinispan.stream.impl.DistributedCacheStream
- toArray() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- toArray() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- toArray() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- toArray() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- toArray() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- toArray() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- toArray() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- toArray() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- toArray(IntFunction<A[]>) - Method in class org.infinispan.stream.impl.DistributedCacheStream
- toArray(IntFunction<A[]>) - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- toArray(IntFunction<A[]>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- toArray(SerializableIntFunction<A[]>) - Method in interface org.infinispan.CacheStream
-
Same as
Stream.toArray(IntFunction)
except that the BinaryOperator must also implementSerializable
- toArray(T[]) - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
- toArray(T[]) - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
- toArray(T[]) - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
- toArray(T[]) - Method in class org.infinispan.commons.util.ForwardingList
- toArray(T[]) - Method in class org.infinispan.commons.util.ImmutableHopscotchHashSet
- toArray(T[]) - Method in class org.infinispan.commons.util.ImmutableIntSet
-
Deprecated.
- toArray(T[]) - Method in class org.infinispan.commons.util.ImmutableListCopy
- toArray(T[]) - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- toArray(T[]) - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- toArray(T[]) - Method in class org.infinispan.InternalCacheSet
- toArrayFinalizer() - Static method in class org.infinispan.reactive.publisher.PublisherReducers
- toArrayFinalizer(IntFunction<E[]>) - Static method in class org.infinispan.reactive.publisher.PublisherReducers
- toArrayReducer() - Static method in class org.infinispan.reactive.publisher.PublisherReducers
- toArrayReducer(IntFunction<E[]>) - Static method in class org.infinispan.reactive.publisher.PublisherReducers
- toAsync() - Method in enum org.infinispan.configuration.cache.CacheMode
- toAttribute() - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
- toBitSet() - Method in class org.infinispan.commons.util.ImmutableIntSet
-
Deprecated.
- toBitSet() - Method in interface org.infinispan.commons.util.IntSet
-
Returns a byte array that has a bit set for each int in this set where each byte represents 8 numbers.
- toBitSet() - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- toBitSet() - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- toBuilder() - Method in interface org.infinispan.query.dsl.FilterConditionContext
-
Deprecated.To be removed in Infinispan 10.0 without replacement.
- toBuilderHolder() - Method in class org.infinispan.configuration.ConfigurationManager
- toByteArray(ByteBuffer) - Static method in class org.infinispan.commons.marshall.MarshallUtil
- toBytes(long) - Method in enum org.infinispan.commons.util.MemoryUnit
-
Deprecated.
- toCacheType() - Method in enum org.infinispan.configuration.cache.CacheMode
- toCharArray(String) - Static method in class org.infinispan.commons.util.Util
- toClassArray(String[], ClassLoader) - Static method in class org.infinispan.commons.util.ReflectionUtil
- toCompletableFuture() - Method in class org.infinispan.interceptors.ExceptionSyncInvocationStage
- toCompletableFuture() - Method in class org.infinispan.interceptors.InvocationStage
-
CompletableFuture
conversion. - toCompletableFuture() - Method in class org.infinispan.interceptors.SyncInvocationStage
- toCompletionStage() - Method in interface org.infinispan.scattered.BiasManager.Revocation
- toConcreteType() - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
- toConfigurationBuilder() - Method in class org.infinispan.client.hotrod.impl.HotRodURI
- toConfigurationBuilder(ConfigurationBuilder) - Method in class org.infinispan.client.hotrod.impl.HotRodURI
- toConvertedEntityJavaClass(Object) - Method in class org.infinispan.search.mapper.mapping.impl.InfinispanMapping
- toConvertedEntityJavaClass(Object) - Method in interface org.infinispan.search.mapper.mapping.SearchMapping
- toDocumentIdentifier(Object, IdentifierBridgeToDocumentIdentifierContext) - Method in class org.infinispan.query.impl.KeyTransformationHandlerIdentifierBridge
- toElement(boolean) - Method in enum org.infinispan.configuration.cache.CacheMode
- toEntrySet(AdvancedCacheLoader<K, V>, Predicate<? super K>, InternalEntryFactory) - Static method in class org.infinispan.persistence.PersistenceUtil
- toFlagsBitSet() - Method in class org.infinispan.functional.impl.Params
-
Bridging method between flags and params, provided for efficient checks.
- toFuture() - Method in interface org.infinispan.rest.framework.RestResponse
- toGibiBytes(long) - Method in enum org.infinispan.commons.util.MemoryUnit
-
Deprecated.
- toGigaBytes(long) - Method in enum org.infinispan.commons.util.MemoryUnit
-
Deprecated.
- toHexString(byte[]) - Static method in class org.infinispan.commons.util.Util
- toHexString(byte[], int) - Static method in class org.infinispan.commons.util.Util
- toHexString(byte[], int, int) - Static method in class org.infinispan.commons.util.Util
- toImmutable(Collection<E>) - Static method in class org.infinispan.xsite.status.AbstractMixedSiteStatus
- toIntArray() - Method in class org.infinispan.commons.util.ImmutableIntSet
-
Deprecated.
- toIntArray() - Method in interface org.infinispan.commons.util.IntSet
-
Returns an array containing all of the elements in this set.
- toIntArray() - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- toIntArray() - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.ImmortalCacheValue
- toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue
- toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
- toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
- toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue
- toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.MortalCacheValue
- toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.TransientCacheValue
- toInternalCacheEntry(Object) - Method in class org.infinispan.container.entries.TransientMortalCacheValue
- toInternalCacheEntry(K) - Method in interface org.infinispan.container.entries.InternalCacheValue
- toInternalCacheValue() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
- toInternalCacheValue() - Method in interface org.infinispan.container.entries.InternalCacheEntry
-
Creates a representation of this entry as an
InternalCacheValue
. - toInternalCacheValue() - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheEntry
- toInternalCacheValue() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
- toInternalCacheValue() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
- toInternalCacheValue() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
- toInternalCacheValue() - Method in class org.infinispan.container.entries.MortalCacheEntry
- toInternalCacheValue() - Method in class org.infinispan.container.entries.TransientCacheEntry
- toInternalCacheValue() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
- toInvocationStage() - Method in interface org.infinispan.util.concurrent.locks.LockPromise
- toInvocationStage() - Method in interface org.infinispan.util.concurrent.locks.PendingLockPromise
-
If successful,
PendingLockPromise.getRemainingTimeout()
will return the remaining timeout, in millis. - toInvocationStage(Supplier<TimeoutException>) - Method in interface org.infinispan.util.concurrent.locks.ExtendedLockPromise
- toJDKByteBuffer() - Method in class org.infinispan.commons.io.ByteBufferImpl
- toJson() - Method in interface org.infinispan.commons.dataconversion.internal.Json.Schema
-
Return the JSON representation of the schema.
- toJson() - Method in interface org.infinispan.commons.dataconversion.internal.JsonSerialization
- toJson() - Method in class org.infinispan.commons.util.JVMMemoryInfoInfo
- toJson() - Method in interface org.infinispan.health.CacheHealth
- toJson() - Method in class org.infinispan.manager.CacheManagerInfo
- toJson() - Method in class org.infinispan.query.remote.json.EntityProjection
- toJson() - Method in class org.infinispan.query.remote.json.Hit
- toJson() - Method in class org.infinispan.query.remote.json.JsonProjection
- toJson() - Method in class org.infinispan.query.remote.json.JsonQueryErrorResult
- toJson() - Method in class org.infinispan.query.remote.json.JsonQueryRequest
- toJson() - Method in class org.infinispan.query.remote.json.JsonQueryResult
- toJson() - Method in class org.infinispan.query.remote.json.ProjectedJsonResult
- toJson() - Method in class org.infinispan.rest.distribution.CacheDistributionInfo
- toJson() - Method in class org.infinispan.rest.distribution.NodeDistributionInfo
- toJson() - Method in class org.infinispan.search.mapper.mapping.metamodel.IndexMetamodel
- toJson() - Method in class org.infinispan.search.mapper.mapping.metamodel.ObjectFieldMetamodel
- toJson() - Method in class org.infinispan.search.mapper.mapping.metamodel.ValueFieldMetamodel
- toJson() - Method in class org.infinispan.stats.impl.CacheContainerStatsImpl
-
Deprecated.
- toJson() - Method in class org.infinispan.stats.impl.StatsCollector
- toJson() - Method in interface org.infinispan.stats.Stats
- toJson() - Method in interface org.infinispan.tasks.Task
- toJson(RemoteStoreConfiguration) - Static method in class org.infinispan.persistence.remote.upgrade.SerializationUtils
- token(String) - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
- TokenCallbackHandler - Class in org.infinispan.client.hotrod.security
- TokenCallbackHandler(String) - Constructor for class org.infinispan.client.hotrod.security.TokenCallbackHandler
- tokenize - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- toKeyFunction - Variable in class org.infinispan.stream.impl.AbstractCacheStream
- toKeySet(AdvancedCacheLoader<K, V>, Predicate<? super K>) - Static method in class org.infinispan.persistence.PersistenceUtil
- toKeySet(NonBlockingStore<K, V>, IntSet, Predicate<? super K>) - Static method in class org.infinispan.persistence.PersistenceUtil
- toKibiBytes(long) - Method in enum org.infinispan.commons.util.MemoryUnit
-
Deprecated.
- toKiloBytes(long) - Method in enum org.infinispan.commons.util.MemoryUnit
-
Deprecated.
- toList() - Method in class org.infinispan.multimap.impl.Bucket
- TOMBSTONE_MAP_SIZE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- TOMBSTONE_MAP_SIZE - Static variable in class org.infinispan.configuration.cache.SitesConfiguration
- tombstoneMapSize() - Method in class org.infinispan.configuration.cache.SitesConfiguration
- tombstoneMapSize(int) - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
-
Sets the target tombstone map size.
- toMebiBytes(long) - Method in enum org.infinispan.commons.util.MemoryUnit
-
Deprecated.
- toMegaBytes(long) - Method in enum org.infinispan.commons.util.MemoryUnit
-
Deprecated.
- toMetricInfo() - Method in class org.infinispan.factories.impl.MBeanMetadata.AttributeMetadata
- toNewTypeIteratorFunction - Variable in class org.infinispan.util.WriteableCacheCollectionMapper
- toNullFunction() - Static method in class org.infinispan.commons.util.concurrent.CompletableFutures
- toObjectSet(Collection<?>) - Static method in class org.infinispan.commons.util.InfinispanCollections
- TopKeyLockManager - Class in org.infinispan.extendedstats.wrappers
-
Top-key stats about locks.
- TopKeyLockManager(LockManager, StreamSummaryContainer) - Constructor for class org.infinispan.extendedstats.wrappers.TopKeyLockManager
- topologicalSort() - Method in class org.infinispan.util.DependencyGraph
-
Calculates a topological sort of the graph, in linear time
- topology - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
- topology - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator
- topology - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
- TOPOLOGY_ADDRESS - Static variable in class org.infinispan.server.core.ExternalizerIds
- TOPOLOGY_AWAIT_INITIAL_TRANSFER - Static variable in class org.infinispan.server.hotrod.configuration.TopologyCacheConfiguration
- TOPOLOGY_AWARE - Enum constant in enum org.infinispan.client.hotrod.configuration.ClientIntelligence
- TOPOLOGY_AWARE_CONSISTENT_HASH_FACTORY - Static variable in interface org.infinispan.commons.marshall.Ids
- TOPOLOGY_AWARE_SYNC_CONSISTENT_HASH_FACTORY - Static variable in interface org.infinispan.commons.marshall.Ids
- TOPOLOGY_CACHE_NAME_PREFIX - Static variable in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
- TOPOLOGY_CHANGED - Enum constant in enum org.infinispan.notifications.cachelistener.event.Event.Type
- TOPOLOGY_LOCK_TIMEOUT - Static variable in class org.infinispan.server.hotrod.configuration.TopologyCacheConfiguration
- TOPOLOGY_REPL_TIMEOUT - Static variable in class org.infinispan.server.hotrod.configuration.TopologyCacheConfiguration
- TOPOLOGY_STATE_TRANSFER - Enum constant in enum org.infinispan.server.hotrod.configuration.Attribute
- TOPOLOGY_STATE_TRANSFER - Enum constant in enum org.infinispan.server.hotrod.configuration.Element
- TOPOLOGY_VIEW - Static variable in class org.infinispan.server.core.ExternalizerIds
- TopologyAffectedCommand - Interface in org.infinispan.commands
-
Some of the commands sent over the wire can only be honored by the receiver if the topology of the cluster at delivery time is still 'compatible' with the topology in place at send time (eg.
- topologyAwaitInitialTransfer() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
- topologyAwaitInitialTransfer(boolean) - Method in class org.infinispan.server.hotrod.configuration.AbstractHotRodServerChildConfigurationBuilder
- topologyAwaitInitialTransfer(boolean) - Method in interface org.infinispan.server.hotrod.configuration.HotRodServerChildConfigurationBuilder
-
Configures whether to enable waiting for initial state transfer for the topology cache.
- topologyAwaitInitialTransfer(boolean) - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
-
Configures whether to enable waiting for initial state transfer for the topology cache.
- TopologyAwareAddress - Interface in org.infinispan.remoting.transport
-
Wraps a TopologyUUID JGroups address
- TopologyAwareConsistentHashFactory - Class in org.infinispan.distribution.ch.impl
-
Default topology-aware consistent hash factory implementation.
- TopologyAwareConsistentHashFactory() - Constructor for class org.infinispan.distribution.ch.impl.TopologyAwareConsistentHashFactory
- TopologyAwareConsistentHashFactory.Externalizer - Class in org.infinispan.distribution.ch.impl
- TopologyAwareSyncConsistentHashFactory - Class in org.infinispan.distribution.ch.impl
-
A
ConsistentHashFactory
implementation that guarantees caches with the same members have the same consistent hash and also tries to distribute segments based on the topology information inTransportConfiguration
. - TopologyAwareSyncConsistentHashFactory() - Constructor for class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory
- TopologyAwareSyncConsistentHashFactory.Builder - Class in org.infinispan.distribution.ch.impl
- TopologyAwareSyncConsistentHashFactory.Externalizer - Class in org.infinispan.distribution.ch.impl
- topologyCache() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
- TopologyCacheConfiguration - Class in org.infinispan.server.hotrod.configuration
- TopologyCacheConfigurationBuilder - Class in org.infinispan.server.hotrod.configuration
- topologyCacheName() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
- TopologyChanged - Annotation Type in org.infinispan.notifications.cachelistener.annotation
-
This annotation should be used on methods that need to be notified when the
ConsistentHash
implementation in use by theDistributionManager
changes due to a change in cluster topology. - TopologyChangedEvent<K,
V> - Interface in org.infinispan.notifications.cachelistener.event -
The event passed in to methods annotated with
TopologyChanged
. - topologyId - Variable in class org.infinispan.transaction.impl.AbstractCacheTransaction
- TopologyIdUpdater() - Constructor for class org.infinispan.container.versioning.SimpleClusteredVersionGenerator.TopologyIdUpdater
- topologyInfo - Variable in class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory.Builder
- TopologyInfo - Class in org.infinispan.client.hotrod.impl
-
Maintains topology information about caches.
- TopologyInfo - Class in org.infinispan.distribution.topologyaware
-
This class holds the topology hierarchy of a cache's members and estimates for owned segments.
- TopologyInfo(int, int, Collection<Address>, Map<Address, Float>) - Constructor for class org.infinispan.distribution.topologyaware.TopologyInfo
- TopologyInfo(Configuration, ClusterInfo) - Constructor for class org.infinispan.client.hotrod.impl.TopologyInfo
- TopologyInfo.Cluster - Class in org.infinispan.distribution.topologyaware
- TopologyInfo.Location - Class in org.infinispan.distribution.topologyaware
-
Base class for locations.
- TopologyInfo.Machine - Class in org.infinispan.distribution.topologyaware
- TopologyInfo.Node - Class in org.infinispan.distribution.topologyaware
- TopologyInfo.Rack - Class in org.infinispan.distribution.topologyaware
- TopologyInfo.Site - Class in org.infinispan.distribution.topologyaware
- TopologyIracVersion - Class in org.infinispan.container.versioning.irac
-
The version stored per
CacheEntry
for IRAC. - TopologyIracVersion$___Marshaller_14f804c9dae1c80820c4a124ae0decae2266c24993f77973d0fee34d7db215d2 - Class in org.infinispan.container.versioning.irac
-
WARNING: Generated code! Do not edit!
- TopologyIracVersion$___Marshaller_14f804c9dae1c80820c4a124ae0decae2266c24993f77973d0fee34d7db215d2() - Constructor for class org.infinispan.container.versioning.irac.TopologyIracVersion$___Marshaller_14f804c9dae1c80820c4a124ae0decae2266c24993f77973d0fee34d7db215d2
- TopologyLevel - Enum in org.infinispan.distribution.topologyaware
-
The cluster topology is a tree with five levels: the entire cluster, sites, racks, machines, and individual nodes.
- topologyLockTimeout() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
- topologyLockTimeout(long) - Method in class org.infinispan.server.hotrod.configuration.AbstractHotRodServerChildConfigurationBuilder
- topologyLockTimeout(long) - Method in interface org.infinispan.server.hotrod.configuration.HotRodServerChildConfigurationBuilder
-
Configures the lock acquisition timeout for the topology cache.
- topologyLockTimeout(long) - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
-
Configures the lock acquisition timeout for the topology cache.
- TopologyManagementHelper - Class in org.infinispan.topology
- TopologyManagementHelper(GlobalComponentRegistry) - Constructor for class org.infinispan.topology.TopologyManagementHelper
- topologyNetworkPrefixOverride(boolean) - Method in class org.infinispan.server.hotrod.configuration.AbstractHotRodServerChildConfigurationBuilder
- topologyNetworkPrefixOverride(boolean) - Method in interface org.infinispan.server.hotrod.configuration.HotRodServerChildConfigurationBuilder
-
Configures whether to honor or override the network prefix returned for the available interfaces.
- topologyNetworkPrefixOverride(boolean) - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
- topologyReplTimeout() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
- topologyReplTimeout(long) - Method in class org.infinispan.server.hotrod.configuration.AbstractHotRodServerChildConfigurationBuilder
- topologyReplTimeout(long) - Method in interface org.infinispan.server.hotrod.configuration.HotRodServerChildConfigurationBuilder
-
Configures the replication timeout for the topology cache.
- topologyReplTimeout(long) - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
-
Configures the replication timeout for the topology cache.
- topologyStateTransfer() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
-
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.
- topologyStateTransfer(boolean) - Method in class org.infinispan.server.hotrod.configuration.AbstractHotRodServerChildConfigurationBuilder
- topologyStateTransfer(boolean) - Method in interface org.infinispan.server.hotrod.configuration.HotRodServerChildConfigurationBuilder
-
Configures whether to enable state transfer for the topology cache.
- topologyStateTransfer(boolean) - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
-
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.
- toPrettyString() - Method in class org.infinispan.commons.dataconversion.internal.Json
- toRFC1123(long) - Static method in class org.infinispan.rest.DateUtils
- toScopedState(ScopedPersistentState) - Method in interface org.infinispan.distribution.ch.ConsistentHash
-
Writes this ConsistentHash to the specified scoped state.
- toScopedState(ScopedPersistentState) - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
- toScopedState(ScopedPersistentState) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
- toScopedState(ScopedPersistentState) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
- toScopedState(ScopedPersistentState) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
- toSerialSupplierCollect(SerializableSupplier) - Static method in class org.infinispan.util.Casting
- toSet() - Method in class org.infinispan.multimap.impl.Bucket
- toStorage(Object) - Method in interface org.infinispan.commons.dataconversion.Encoder
-
Deprecated.Convert data in the read/write format to the storage format.
- toStorage(Object) - Method in class org.infinispan.commons.dataconversion.IdentityEncoder
-
Deprecated.
- toStorage(Object) - Method in class org.infinispan.commons.dataconversion.MarshallerEncoder
-
Deprecated.
- toStorage(Object) - Method in class org.infinispan.commons.dataconversion.UTF8Encoder
-
Deprecated.
- toStorage(Object) - Method in class org.infinispan.encoding.DataConversion
- toStorage(Object, Encoder, Wrapper) - Static method in class org.infinispan.commons.dataconversion.EncodingUtils
-
Deprecated.Encode object to storage format.
- toStr(Object) - Static method in class org.infinispan.commons.util.Util
- toStr(Collection<E>) - Static method in class org.infinispan.commons.util.Util
- toStream() - Method in class org.infinispan.container.offheap.MemoryAddressHash
-
Returns a stream of longs that are all of the various memory locations
- toString() - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
- toString() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- toString() - Method in class org.infinispan.cache.impl.CacheImpl
- toString() - Method in class org.infinispan.cache.impl.InvocationHelper
- toString() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- toString() - Method in class org.infinispan.cache.impl.StatsCollectingCache
- toString() - Method in class org.infinispan.client.hotrod.configuration.ClusterConfiguration
- toString() - Method in class org.infinispan.client.hotrod.configuration.Configuration
- toString() - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfiguration
- toString() - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfiguration
- toString() - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfigurationBuilder
- toString() - Method in class org.infinispan.client.hotrod.configuration.NearCacheConfiguration
- toString() - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
- toString() - Method in enum org.infinispan.client.hotrod.configuration.SaslQop
- toString() - Method in enum org.infinispan.client.hotrod.configuration.SaslStrength
- toString() - Method in class org.infinispan.client.hotrod.configuration.ServerConfiguration
- toString() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
- toString() - Method in class org.infinispan.client.hotrod.configuration.StatisticsConfiguration
- toString() - Method in class org.infinispan.client.hotrod.configuration.TransactionConfiguration
-
Deprecated.
- toString() - Method in class org.infinispan.client.hotrod.counter.impl.HotRodCounterEvent
- toString() - Method in class org.infinispan.client.hotrod.DataFormat
- toString() - Method in class org.infinispan.client.hotrod.event.impl.CreatedEventImpl
- toString() - Method in class org.infinispan.client.hotrod.event.impl.CustomEventImpl
- toString() - Method in class org.infinispan.client.hotrod.event.impl.ExpiredEventImpl
- toString() - Method in class org.infinispan.client.hotrod.event.impl.ModifiedEventImpl
- toString() - Method in class org.infinispan.client.hotrod.event.impl.RemovedEventImpl
- toString() - Method in exception org.infinispan.client.hotrod.exceptions.HotRodClientException
- toString() - Method in class org.infinispan.client.hotrod.impl.CacheTopologyInfoImpl
- toString() - Method in class org.infinispan.client.hotrod.impl.ClientTopology
- toString() - Method in class org.infinispan.client.hotrod.impl.HotRodURI
- toString() - Method in class org.infinispan.client.hotrod.impl.MetadataValueImpl
- toString() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- toString() - Method in class org.infinispan.client.hotrod.impl.VersionedValueImpl
- toString() - Method in class org.infinispan.client.hotrod.near.DefaultNearCacheFactory
- toString() - Method in enum org.infinispan.client.hotrod.ProtocolVersion
- toString() - Method in class org.infinispan.client.hotrod.transaction.lookup.RemoteTransactionManagerLookup
- toString() - Method in class org.infinispan.commands.CommandInvocationId
- toString() - Method in class org.infinispan.commons.configuration.AbstractTypedPropertiesConfiguration
- toString() - Method in class org.infinispan.commons.configuration.attributes.Attribute
- toString() - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
- toString() - Method in class org.infinispan.commons.configuration.attributes.ConfigurationElement
- toString() - Method in class org.infinispan.commons.configuration.Combine
- toString() - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter.Tag
- toString() - Method in class org.infinispan.commons.configuration.io.Location
- toString() - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader.Parsed
- toString() - Method in class org.infinispan.commons.dataconversion.MediaType
- toString() - Method in class org.infinispan.commons.executors.BlockingThreadPoolExecutorFactory
-
Deprecated.
- toString() - Method in class org.infinispan.commons.hash.MurmurHash3
- toString() - Method in class org.infinispan.commons.io.ByteBufferImpl
- toString() - Method in class org.infinispan.commons.io.StringBuilderWriter
- toString() - Method in class org.infinispan.commons.jdkspecific.ProcessInfo
- toString() - Method in class org.infinispan.commons.marshall.WrappedByteArray
- toString() - Method in class org.infinispan.commons.maven.LocalArtifact
- toString() - Method in class org.infinispan.commons.maven.MavenArtifact
-
Get the string representation.
- toString() - Method in class org.infinispan.commons.stat.TimerMetricInfo
- toString() - Method in class org.infinispan.commons.stat.FunctionTimerMetricInfo
- toString() - Method in class org.infinispan.commons.tx.TransactionImpl
- toString() - Method in class org.infinispan.commons.tx.XidImpl
- toString() - Method in class org.infinispan.commons.util.AbstractMap.SimpleEntry
- toString() - Method in class org.infinispan.commons.util.BloomFilter
- toString() - Method in class org.infinispan.commons.util.FastCopyHashMap
-
Returns a string representation of this map.
- toString() - Method in class org.infinispan.commons.util.KeyValueWithPrevious
- toString() - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- toString() - Method in class org.infinispan.commons.util.SegmentAwareKey
- toString() - Method in class org.infinispan.commons.util.SimpleImmutableEntry
- toString() - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- toString() - Method in class org.infinispan.commons.util.WeakValueHashMap
- toString() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- toString() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
- toString() - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.BackupForBuilder
- toString() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.ClusterLoaderConfiguration
-
Deprecated.
- toString() - Method in class org.infinispan.configuration.cache.Configuration
- toString() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfiguration
-
Deprecated.
- toString() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
-
Deprecated.
- toString() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
- toString() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.IndexReaderConfigurationBuilder
- toString() - Method in enum org.infinispan.configuration.cache.IndexStorage
- toString() - Method in class org.infinispan.configuration.cache.IndexWriterConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
- toString() - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
-
Deprecated.
- toString() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfiguration
- toString() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.MemoryStorageConfiguration
-
Deprecated.
- toString() - Method in class org.infinispan.configuration.cache.MemoryStorageConfigurationBuilder
-
Deprecated.
- toString() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
- toString() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.SecurityConfiguration
- toString() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
- toString() - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.StatisticsConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.global.AllowListConfiguration
- toString() - Method in class org.infinispan.configuration.global.BoundedThreadPoolConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.global.CachedThreadPoolConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfiguration
- toString() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
- toString() - Method in class org.infinispan.configuration.global.GlobalConfiguration
- toString() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.global.GlobalJmxConfiguration
- toString() - Method in class org.infinispan.configuration.global.GlobalJmxConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.global.GlobalMetricsConfiguration
- toString() - Method in class org.infinispan.configuration.global.GlobalMetricsConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.global.GlobalSecurityConfiguration
- toString() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
- toString() - Method in class org.infinispan.configuration.global.JGroupsConfiguration
- toString() - Method in class org.infinispan.configuration.global.JGroupsConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfiguration
- toString() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.global.ScheduledThreadPoolConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.global.SerializationConfiguration
- toString() - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.global.ShutdownConfiguration
- toString() - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.global.SiteConfiguration
-
Deprecated.
- toString() - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
-
Deprecated.
- toString() - Method in class org.infinispan.configuration.global.StackConfiguration
- toString() - Method in class org.infinispan.configuration.global.ThreadPoolConfiguration
- toString() - Method in class org.infinispan.configuration.global.ThreadsConfiguration
- toString() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.global.WhiteListConfiguration
-
Deprecated.
- toString() - Method in enum org.infinispan.configuration.parsing.Attribute
- toString() - Method in enum org.infinispan.configuration.parsing.Element
- toString() - Method in class org.infinispan.configuration.parsing.ParserRegistry.NamespaceParserPair
- toString() - Method in class org.infinispan.configuration.parsing.ParserRegistry.QName
- toString() - Method in class org.infinispan.configuration.parsing.ParserRegistry
- toString() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
- toString() - Method in class org.infinispan.container.entries.ClearCacheEntry
- toString() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
- toString() - Method in class org.infinispan.container.entries.ImmortalCacheValue
- toString() - Method in class org.infinispan.container.entries.NullCacheEntry
- toString() - Method in class org.infinispan.container.entries.ReadCommittedEntry
- toString() - Method in class org.infinispan.container.entries.RemoteMetadata
- toString() - Method in class org.infinispan.container.versioning.irac.IracEntryVersion.MapEntry
- toString() - Method in class org.infinispan.container.versioning.irac.IracEntryVersion
- toString() - Method in class org.infinispan.container.versioning.irac.IracTombstoneInfo
- toString() - Method in class org.infinispan.container.versioning.irac.TopologyIracVersion
- toString() - Method in class org.infinispan.container.versioning.NumericVersion
- toString() - Method in class org.infinispan.container.versioning.SimpleClusteredVersion
- toString() - Method in class org.infinispan.context.impl.SingleKeyNonTxInvocationContext
- toString() - Method in class org.infinispan.counter.api.CounterConfiguration
- toString() - Method in enum org.infinispan.counter.configuration.Attribute
- toString() - Method in enum org.infinispan.counter.configuration.Element
- toString() - Method in class org.infinispan.counter.impl.SyncStrongCounterAdapter
- toString() - Method in class org.infinispan.counter.impl.SyncWeakCounterAdapter
- toString() - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
- toString() - Method in class org.infinispan.distribution.ch.impl.HashFunctionPartitioner
- toString() - Method in class org.infinispan.distribution.ch.impl.OwnershipStatistics
- toString() - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
- toString() - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
- toString() - Method in class org.infinispan.distribution.DistributionInfo
- toString() - Method in class org.infinispan.distribution.group.impl.CacheEntryGroupPredicate
- toString() - Method in class org.infinispan.distribution.topologyaware.TopologyInfo.Location
- toString() - Method in class org.infinispan.distribution.topologyaware.TopologyInfo.Node
- toString() - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
- toString() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
- toString() - Method in class org.infinispan.encoding.DataConversion
- toString() - Method in class org.infinispan.extendedstats.container.LocalExtendedStatisticsContainer
- toString() - Method in class org.infinispan.extendedstats.LocalTransactionStatistics
- toString() - Method in class org.infinispan.extendedstats.RemoteTransactionStatistics
- toString() - Method in class org.infinispan.extendedstats.topK.StreamSummaryContainer
- toString() - Method in class org.infinispan.extendedstats.TransactionStatistics
- toString() - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
- toString() - Method in class org.infinispan.factories.impl.ComponentAccessor
- toString() - Method in class org.infinispan.factories.impl.ComponentAlias
- toString() - Method in class org.infinispan.factories.impl.MBeanMetadata.AttributeMetadata
- toString() - Method in class org.infinispan.factories.impl.MBeanMetadata.OperationMetadata
- toString() - Method in class org.infinispan.factories.impl.MBeanMetadata.OperationParameterMetadata
- toString() - Method in class org.infinispan.factories.impl.MBeanMetadata
- toString() - Method in class org.infinispan.factories.threads.NonBlockingThreadPoolExecutorFactory
- toString() - Method in class org.infinispan.functional.impl.CounterConfigurationMetaParam
- toString() - Method in class org.infinispan.functional.impl.MetaParams
- toString() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
- toString() - Method in class org.infinispan.functional.impl.Params
- toString() - Method in class org.infinispan.functional.impl.StatsEnvelope
- toString() - Method in class org.infinispan.functional.MetaParam.MetaCreated
- toString() - Method in class org.infinispan.functional.MetaParam.MetaEntryVersion
- toString() - Method in class org.infinispan.functional.MetaParam.MetaLastUsed
- toString() - Method in class org.infinispan.functional.MetaParam.MetaLifespan
- toString() - Method in class org.infinispan.functional.MetaParam.MetaMaxIdle
- toString() - Method in class org.infinispan.globalstate.ScopedState
- toString() - Method in class org.infinispan.interceptors.SyncInvocationStage
- toString() - Method in class org.infinispan.io.GridFile.Metadata
-
Deprecated.
- toString() - Method in class org.infinispan.io.GridFile
-
Deprecated.
- toString() - Method in class org.infinispan.jmx.ResourceDMBean
- toString() - Method in class org.infinispan.lock.api.ClusteredLockConfiguration
- toString() - Method in enum org.infinispan.lock.configuration.Attribute
- toString() - Method in enum org.infinispan.lock.configuration.Element
- toString() - Method in class org.infinispan.manager.DefaultCacheManager
- toString() - Method in class org.infinispan.metadata.EmbeddedMetadata.EmbeddedExpirableMetadata
- toString() - Method in class org.infinispan.metadata.EmbeddedMetadata.EmbeddedLifespanExpirableMetadata
- toString() - Method in class org.infinispan.metadata.EmbeddedMetadata.EmbeddedMaxIdleExpirableMetadata
- toString() - Method in class org.infinispan.metadata.EmbeddedMetadata
- toString() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
-
Deprecated.
- toString() - Method in class org.infinispan.metadata.impl.IracMetadata
- toString() - Method in class org.infinispan.metadata.impl.PrivateMetadata
- toString() - Method in class org.infinispan.metrics.config.MicrometerMeterRegisterConfigurationBuilder
- toString() - Method in class org.infinispan.metrics.config.MicrometerMeterRegistryConfiguration
- toString() - Method in class org.infinispan.multimap.impl.Bucket
- toString() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
- toString() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.ClusteredListenerInvocation
- toString() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
- toString() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerReplicateCallable
- toString() - Method in class org.infinispan.notifications.cachelistener.event.impl.EventImpl
- toString() - Method in class org.infinispan.notifications.cachemanagerlistener.event.impl.EventImpl
- toString() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfiguration
- toString() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractUnmanagedConnectionFactoryConfiguration
- toString() - Method in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
- toString() - Method in enum org.infinispan.persistence.jdbc.common.configuration.Element
- toString() - Method in class org.infinispan.persistence.jdbc.common.configuration.ManagedConnectionFactoryConfiguration
- toString() - Method in class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfiguration
- toString() - Method in class org.infinispan.persistence.jdbc.configuration.DataColumnConfiguration
- toString() - Method in class org.infinispan.persistence.jdbc.configuration.IdColumnConfiguration
- toString() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfiguration
- toString() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
- toString() - Method in class org.infinispan.persistence.jdbc.configuration.SegmentColumnConfiguration
- toString() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- toString() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
- toString() - Method in class org.infinispan.persistence.jdbc.configuration.TimestampColumnConfiguration
- toString() - Method in class org.infinispan.persistence.modifications.ModificationsList
- toString() - Method in class org.infinispan.persistence.modifications.Remove
- toString() - Method in class org.infinispan.persistence.modifications.Store
- toString() - Method in enum org.infinispan.persistence.remote.configuration.Attribute
- toString() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
- toString() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
- toString() - Method in enum org.infinispan.persistence.remote.configuration.Element
- toString() - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfiguration
- toString() - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
- toString() - Method in class org.infinispan.persistence.remote.configuration.KeyStoreConfiguration
- toString() - Method in class org.infinispan.persistence.remote.configuration.MechanismConfiguration
- toString() - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfiguration
- toString() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfiguration
- toString() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfigurationBuilder
- toString() - Method in enum org.infinispan.persistence.rocksdb.configuration.Attribute
- toString() - Method in enum org.infinispan.persistence.rocksdb.configuration.Element
- toString() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBExpirationConfiguration
- toString() - Method in class org.infinispan.persistence.sifs.configuration.DataConfiguration
- toString() - Method in class org.infinispan.persistence.sifs.configuration.IndexConfiguration
- toString() - Method in class org.infinispan.persistence.sifs.configuration.IndexConfigurationBuilder
- toString() - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfiguration
- toString() - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
- toString() - Method in class org.infinispan.persistence.sifs.EntryHeader
- toString() - Method in class org.infinispan.persistence.sifs.EntryInfo
- toString() - Method in class org.infinispan.persistence.sifs.EntryRecord
- toString() - Method in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.Parameter
- toString() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfiguration
- toString() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfiguration
- toString() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfigurationBuilder
- toString() - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfiguration
- toString() - Method in class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfiguration
- toString() - Method in class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfigurationBuilder
- toString() - Method in class org.infinispan.query.remote.client.FilterResult
- toString() - Method in class org.infinispan.reactive.publisher.impl.PublisherHandler.SegmentResult
- toString() - Method in class org.infinispan.remoting.responses.ExceptionResponse
- toString() - Method in class org.infinispan.remoting.responses.InvalidResponse
- toString() - Method in class org.infinispan.remoting.responses.PrepareResponse
- toString() - Method in class org.infinispan.remoting.responses.SuccessfulResponse
- toString() - Method in class org.infinispan.remoting.responses.UnsuccessfulResponse
- toString() - Method in class org.infinispan.remoting.responses.ValidResponse
- toString() - Method in class org.infinispan.remoting.rpc.RpcOptions
- toString() - Method in class org.infinispan.remoting.transport.AggregateBackupResponse
- toString() - Method in class org.infinispan.remoting.transport.impl.SiteUnreachableXSiteResponse
- toString() - Method in class org.infinispan.remoting.transport.jgroups.ClusterView
- toString() - Method in class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.RemoteSite
- toString() - Method in class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.RemoteSites
- toString() - Method in class org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator
- toString() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
- toString() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsBackupResponse
- toString() - Method in class org.infinispan.remoting.transport.LocalModeAddress
- toString() - Method in class org.infinispan.remoting.transport.SiteAddress
- toString() - Method in class org.infinispan.rest.CacheControl
- toString() - Method in class org.infinispan.rest.configuration.RestServerConfiguration
- toString() - Method in class org.infinispan.rest.framework.impl.InvocationImpl
- toString() - Method in class org.infinispan.rest.NettyRestRequest
- toString() - Method in class org.infinispan.rest.operations.mediatypes.Charset
- toString() - Method in class org.infinispan.rest.ServerSentEvent
- toString() - Method in class org.infinispan.search.mapper.common.impl.EntityReferenceImpl
- toString() - Method in enum org.infinispan.security.AuditContext
- toString() - Method in class org.infinispan.security.impl.CacheRoleImpl
- toString() - Method in class org.infinispan.security.impl.CacheSubjectPair
- toString() - Method in class org.infinispan.security.impl.SecureCacheImpl
- toString() - Method in class org.infinispan.security.impl.SubjectACL
- toString() - Method in class org.infinispan.security.impl.SubjectAdapter.SimplePrincipal
- toString() - Method in class org.infinispan.server.core.backup.resources.CounterResource.CounterBackupEntry
- toString() - Method in enum org.infinispan.server.core.BackupManager.Resources.Type
- toString() - Method in class org.infinispan.server.core.configuration.IpFilterConfiguration
- toString() - Method in class org.infinispan.server.core.configuration.SslEngineConfiguration
- toString() - Method in class org.infinispan.server.core.security.InetAddressPrincipal
- toString() - Method in class org.infinispan.server.core.security.simple.SimpleGroupPrincipal
- toString() - Method in class org.infinispan.server.core.security.simple.SimpleUserPrincipal
- toString() - Method in class org.infinispan.server.core.transport.IpSubnetFilterRule
- toString() - Method in class org.infinispan.server.hotrod.command.tx.ForwardCommitCommand
- toString() - Method in class org.infinispan.server.hotrod.command.tx.ForwardRollbackCommand
- toString() - Method in enum org.infinispan.server.hotrod.configuration.Attribute
- toString() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfiguration
- toString() - Method in enum org.infinispan.server.hotrod.configuration.Element
- toString() - Method in enum org.infinispan.server.hotrod.configuration.Policy
- toString() - Method in enum org.infinispan.server.hotrod.configuration.QOP
- toString() - Method in enum org.infinispan.server.hotrod.configuration.Strength
- toString() - Method in class org.infinispan.server.hotrod.counter.listener.ClientCounterEvent
- toString() - Method in class org.infinispan.server.hotrod.HotRodHeader
- toString() - Method in class org.infinispan.server.hotrod.HotRodServer
- toString() - Method in enum org.infinispan.server.hotrod.HotRodVersion
- toString() - Method in class org.infinispan.server.hotrod.iteration.IterableIterationResult
- toString() - Method in class org.infinispan.server.hotrod.MultiHomedServerAddress.InetAddressWithNetMask
- toString() - Method in class org.infinispan.server.hotrod.MultiHomedServerAddress
- toString() - Method in class org.infinispan.server.hotrod.SingleHomedServerAddress
- toString() - Method in class org.infinispan.server.hotrod.tx.table.CacheXid
- toString() - Method in class org.infinispan.server.hotrod.tx.table.ClientAddress
- toString() - Method in class org.infinispan.server.hotrod.tx.table.functions.ConditionalMarkAsRollbackFunction
- toString() - Method in class org.infinispan.server.hotrod.tx.table.functions.CreateStateFunction
- toString() - Method in class org.infinispan.server.hotrod.tx.table.functions.PreparingDecisionFunction
- toString() - Method in class org.infinispan.server.hotrod.tx.table.functions.SetCompletedTransactionFunction
- toString() - Method in class org.infinispan.server.hotrod.tx.table.functions.SetDecisionFunction
- toString() - Method in class org.infinispan.server.hotrod.tx.table.functions.SetPreparedFunction
- toString() - Method in class org.infinispan.server.hotrod.tx.table.TxState
- toString() - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfiguration
- toString() - Method in class org.infinispan.spring.common.provider.SpringCache
- toString() - Method in class org.infinispan.tasks.TaskContext
- toString() - Method in class org.infinispan.topology.CacheJoinInfo
- toString() - Method in class org.infinispan.topology.CacheStatusResponse
- toString() - Method in class org.infinispan.topology.CacheTopology
- toString() - Method in class org.infinispan.topology.ClusterCacheStatus
- toString() - Method in class org.infinispan.topology.ManagerStatusResponse
- toString() - Method in class org.infinispan.topology.PersistentUUID
- toString() - Method in class org.infinispan.transaction.impl.LocalTransaction
- toString() - Method in class org.infinispan.transaction.impl.ModificationList
- toString() - Method in class org.infinispan.transaction.impl.RemoteTransaction
- toString() - Method in class org.infinispan.transaction.lookup.EmbeddedTransactionManagerLookup
- toString() - Method in class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
- toString() - Method in class org.infinispan.transaction.lookup.WildflyTransactionManagerLookup
- toString() - Method in class org.infinispan.transaction.synchronization.SynchronizationAdapter
- toString() - Method in class org.infinispan.transaction.xa.GlobalTransaction
- toString() - Method in class org.infinispan.transaction.xa.LocalXaTransaction
- toString() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfo
- toString() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
- toString() - Method in class org.infinispan.transaction.xa.recovery.RecoveryInfoKey
- toString() - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
- toString() - Method in class org.infinispan.util.ByteString
- toString() - Method in class org.infinispan.util.concurrent.locks.impl.PerKeyLockContainer
- toString() - Method in class org.infinispan.util.concurrent.locks.impl.StripedLockContainer
- toString() - Method in class org.infinispan.util.concurrent.ReclosableLatch
- toString() - Method in exception org.infinispan.util.concurrent.TimeoutException
- toString() - Method in class org.infinispan.util.KeyValuePair
- toString() - Method in class org.infinispan.xsite.commands.remote.IracClearKeysRequest
- toString() - Method in class org.infinispan.xsite.commands.remote.IracPutManyRequest
- toString() - Method in class org.infinispan.xsite.commands.remote.IracTombstoneCheckRequest
- toString() - Method in class org.infinispan.xsite.commands.remote.XSiteRemoteEventCommand
- toString() - Method in class org.infinispan.xsite.commands.XSiteAmendOfflineStatusCommand
- toString() - Method in class org.infinispan.xsite.commands.XSiteAutoTransferStatusCommand
- toString() - Method in class org.infinispan.xsite.commands.XSiteBringOnlineCommand
- toString() - Method in class org.infinispan.xsite.commands.XSiteLocalEventCommand
- toString() - Method in class org.infinispan.xsite.commands.XSiteOfflineStatusCommand
- toString() - Method in class org.infinispan.xsite.commands.XSiteStateTransferCancelSendCommand
- toString() - Method in class org.infinispan.xsite.commands.XSiteStateTransferClearStatusCommand
- toString() - Method in class org.infinispan.xsite.commands.XSiteStateTransferFinishReceiveCommand
- toString() - Method in class org.infinispan.xsite.commands.XSiteStateTransferFinishSendCommand
- toString() - Method in class org.infinispan.xsite.commands.XSiteStateTransferRestartSendingCommand
- toString() - Method in class org.infinispan.xsite.commands.XSiteStateTransferStartReceiveCommand
- toString() - Method in class org.infinispan.xsite.commands.XSiteStateTransferStartSendCommand
- toString() - Method in class org.infinispan.xsite.commands.XSiteStateTransferStatusRequestCommand
- toString() - Method in class org.infinispan.xsite.commands.XSiteStatusCommand
- toString() - Method in class org.infinispan.xsite.commands.XSiteTakeOfflineCommand
- toString() - Method in class org.infinispan.xsite.events.XSiteEvent
- toString() - Method in class org.infinispan.xsite.spi.SiteEntry
- toString() - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateProvider
- toString() - Method in class org.infinispan.xsite.statetransfer.NoOpXSiteStateTransferManager
- toString() - Method in class org.infinispan.xsite.statetransfer.XSiteState
- toString() - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
- toString() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferCollector
- toString() - Method in class org.infinispan.xsite.status.DefaultTakeOfflineManager
- toString(boolean) - Method in class org.infinispan.client.hotrod.impl.HotRodURI
- toString(int) - Method in class org.infinispan.commons.dataconversion.internal.Json
-
Return a string representation of
this
that does not exceed a certain maximum length. - toString(Object) - Method in class org.infinispan.query.impl.DefaultTransformer
- toString(Object) - Method in interface org.infinispan.query.Transformer
-
Transforms an Object into a String.
- toString(String) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
- toString(Subject) - Static method in class org.infinispan.security.Security
-
A simplified version of Subject.toString() with the following advantages: only lists principals, ignoring credentials uses a compact, single-line format does not use synchronization does not use i18n messages
- toStringArray(Class<?>[]) - Static method in class org.infinispan.commons.util.ReflectionUtil
- toStringConfiguration(String) - Method in interface org.infinispan.commons.configuration.BasicConfiguration
-
Converts this configuration to an XML.
- toStringConfiguration(String) - Method in class org.infinispan.commons.configuration.StringConfiguration
- toStringConfiguration(String, MediaType, boolean) - Method in interface org.infinispan.commons.configuration.BasicConfiguration
-
Converts this configuration to a string representation.
- toStringConfiguration(String, MediaType, boolean) - Method in class org.infinispan.commons.configuration.StringConfiguration
- toStringConfiguration(String, MediaType, boolean) - Method in class org.infinispan.configuration.cache.Configuration
- toStringExcludingParam(String...) - Method in class org.infinispan.commons.dataconversion.MediaType
-
Deprecated, for removal: This API element is subject to removal in a future version.Use
MediaType.getParameters()
andMediaType.getTypeSubtype()
to build a custom String representation. - toSupplierCollect(Supplier) - Static method in class org.infinispan.util.Casting
- toSync() - Method in enum org.infinispan.configuration.cache.CacheMode
- toSync(boolean) - Method in enum org.infinispan.configuration.cache.CacheMode
- TOTAL_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.Since 13.0, please use
ServerStatistics.STORES
instead. - TOTAL_ORDER_EXECUTOR - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- TOTAL_RESULTS - Static variable in interface org.infinispan.query.remote.json.JSONConstants
- totalEntries() - Method in class org.infinispan.rest.distribution.CacheDistributionInfo
- totalLength() - Method in class org.infinispan.persistence.sifs.EntryHeader
- toTebiBytes(long) - Method in enum org.infinispan.commons.util.MemoryUnit
-
Deprecated.
- toTeraBytes(long) - Method in enum org.infinispan.commons.util.MemoryUnit
-
Deprecated.
- toText(StateTransferStatus) - Static method in enum org.infinispan.xsite.statetransfer.StateTransferStatus
- toTimeUnit() - Method in enum org.infinispan.server.hotrod.TimeUnitValue
- toTrueFunction() - Static method in class org.infinispan.commons.util.concurrent.CompletableFutures
- toTypedProperties(Map<?, ?>) - Static method in class org.infinispan.commons.util.TypedProperties
-
Factory method that converts a JDK
Map
(includingProperties
instance to an instance of TypedProperties, if needed. - touch() - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
- touch() - Method in class org.infinispan.configuration.cache.ExpirationConfiguration
-
Control how the timestamp of read keys are updated on all the key owners in a cluster.
- touch() - Method in class org.infinispan.rest.ServerSentEvent
- touch(int, Object, long) - Method in class org.infinispan.container.impl.AbstractDelegatingInternalDataContainer
- touch(int, Object, long) - Method in class org.infinispan.container.impl.AbstractInternalDataContainer
- touch(int, Object, long) - Method in interface org.infinispan.container.impl.InternalDataContainer
-
Touches an entry in the data container.
- touch(long) - Method in class org.infinispan.container.entries.ImmortalCacheEntry
- touch(long) - Method in interface org.infinispan.container.entries.InternalCacheEntry
-
Updates access timestamps on this instance to a specified time
- touch(long) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
- touch(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
- touch(long) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
- touch(long) - Method in class org.infinispan.container.entries.MortalCacheEntry
- touch(long) - Method in class org.infinispan.container.entries.TransientCacheEntry
- touch(long) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
- touch(Object) - Method in class org.infinispan.rest.ServerSentEvent
- touch(Object, boolean) - Method in interface org.infinispan.AdvancedCache
-
Touches the given key if present.
- touch(Object, boolean) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- touch(Object, boolean) - Method in class org.infinispan.cache.impl.CacheImpl
- touch(Object, boolean) - Method in class org.infinispan.cache.impl.EncoderCache
- touch(Object, boolean) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- touch(Object, boolean) - Method in class org.infinispan.security.impl.SecureCacheImpl
- touch(Object, int, boolean) - Method in interface org.infinispan.AdvancedCache
-
The same as
AdvancedCache.touch(Object, boolean)
except that the segment is already known. - touch(Object, int, boolean) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- touch(Object, int, boolean) - Method in class org.infinispan.cache.impl.CacheImpl
- touch(Object, int, boolean) - Method in class org.infinispan.cache.impl.EncoderCache
- touch(Object, int, boolean) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- touch(Object, int, boolean) - Method in class org.infinispan.security.impl.SecureCacheImpl
- touch(Object, int, boolean, long) - Method in class org.infinispan.cache.impl.CacheImpl
- touch(TouchMode) - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
-
Control how the timestamp of read keys are updated on all the key owners in a cluster.
- TOUCH - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- TOUCH - Static variable in class org.infinispan.configuration.cache.ExpirationConfiguration
- TouchableMap - Interface in org.infinispan.container.impl
- touchAll(long) - Method in class org.infinispan.container.impl.PeekableTouchableCaffeineMap
- touchAll(long) - Method in class org.infinispan.container.impl.PeekableTouchableContainerMap
- touchAll(long) - Method in interface org.infinispan.container.impl.PeekableTouchableMap
-
Touches all entries in the map setting the recency timestamps for both expiration eviction appropriately.
- touchAll(long) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- TouchCommand - Class in org.infinispan.expiration.impl
-
This command updates a cache entry's last access timestamp.
- TouchCommand() - Constructor for class org.infinispan.expiration.impl.TouchCommand
- TouchCommand(Object, int, long, boolean) - Constructor for class org.infinispan.expiration.impl.TouchCommand
- TOUCHED - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- touchKey(Object, long) - Method in class org.infinispan.container.impl.PeekableTouchableCaffeineMap
- touchKey(Object, long) - Method in class org.infinispan.container.impl.PeekableTouchableContainerMap
- touchKey(Object, long) - Method in interface org.infinispan.container.impl.PeekableTouchableMap
-
Touches the entry for the given key in this map.
- touchKey(Object, long) - Method in interface org.infinispan.container.impl.TouchableMap
-
Touches the entry for the given key in this map.
- touchKey(Object, long) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- TouchMode - Enum in org.infinispan.expiration
-
Control how the timestamp of read keys are updated on all the key owners in a cluster.
- TouchRequest - Enum constant in enum org.infinispan.server.memcached.MemcachedOperation
- toURI() - Method in class org.infinispan.io.GridFile
-
Deprecated.
- toURL() - Method in class org.infinispan.io.GridFile
-
Deprecated.
- toXMLString() - Method in interface org.infinispan.commons.configuration.BasicConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.
- toXMLString(String) - Method in interface org.infinispan.commons.configuration.BasicConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.
- TraceException - Exception in org.infinispan.commons.util.logging
-
This exception is used to add stack trace information to exceptions as they move from one thread to another.
- TraceException() - Constructor for exception org.infinispan.commons.util.logging.TraceException
- TRACING_PROPAGATION_ENABLED - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- tracingPropagationEnabled() - Method in class org.infinispan.client.hotrod.configuration.Configuration
-
OpenTelemetry tracing propagation will be activated if this property is true and if the OpenTelemetry API jar is detected on the classpath.
- trackClear(boolean) - Method in class org.infinispan.xsite.irac.DefaultIracManager
- trackClear(boolean) - Method in interface org.infinispan.xsite.irac.IracManager
-
Sets all keys as removed.
- trackClear(boolean) - Method in enum org.infinispan.xsite.irac.NoOpIracManager
- trackExpiredKey(int, Object, Object) - Method in class org.infinispan.xsite.irac.DefaultIracManager
- trackExpiredKey(int, Object, Object) - Method in interface org.infinispan.xsite.irac.IracManager
-
Similar to
IracManager.trackUpdatedKey(int, Object, Object)
but it tracks expired keys instead. - trackExpiredKey(int, Object, Object) - Method in enum org.infinispan.xsite.irac.NoOpIracManager
- trackForStateTransfer(Collection<XSiteState>) - Method in class org.infinispan.xsite.irac.DefaultIracManager
- trackForStateTransfer(Collection<XSiteState>) - Method in interface org.infinispan.xsite.irac.IracManager
-
Tracks a set of keys to be sent to the remote site.
- trackForStateTransfer(Collection<XSiteState>) - Method in enum org.infinispan.xsite.irac.NoOpIracManager
- trackingSegmentKey(String, int, boolean) - Method in interface org.infinispan.client.hotrod.logging.Log
- trackRequest(Address) - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsMetricsManager
-
Track the latency for a synchronous request.
- trackRequest(Address) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsMetricsManagerImpl
- trackRequest(Address) - Method in class org.infinispan.remoting.transport.jgroups.NoOpJGroupsMetricManager
- trackUpdatedKey(int, Object, Object) - Method in class org.infinispan.xsite.irac.DefaultIracManager
- trackUpdatedKey(int, Object, Object) - Method in interface org.infinispan.xsite.irac.IracManager
-
Sets the
key
as changed by thelockOwner
. - trackUpdatedKey(int, Object, Object) - Method in enum org.infinispan.xsite.irac.NoOpIracManager
- transaction() - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
- transaction() - Method in class org.infinispan.client.hotrod.configuration.Configuration
-
Deprecated, for removal: This API element is subject to removal in a future version.since 12.0. To be removed in Infinispan 14.
- transaction() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- transaction() - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
-
Transaction configuration
- transaction() - Method in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
- transaction() - Method in class org.infinispan.configuration.cache.Configuration
- transaction() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- transaction() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- TRANSACTION - Enum constant in enum org.infinispan.configuration.parsing.Element
- TRANSACTION_COMPLETED - Enum constant in enum org.infinispan.notifications.cachelistener.event.Event.Type
- TRANSACTION_INFO - Static variable in interface org.infinispan.commons.marshall.Ids
- TRANSACTION_MANAGER - Static variable in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
- TRANSACTION_MANAGER_LOOKUP - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- TRANSACTION_MANAGER_LOOKUP - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
- TRANSACTION_MANAGER_LOOKUP_CLASS - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- TRANSACTION_MODE - Static variable in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
- TRANSACTION_MODE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- TRANSACTION_MODE - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
- TRANSACTION_PROTOCOL - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- TRANSACTION_REGISTERED - Enum constant in enum org.infinispan.notifications.cachelistener.event.Event.Type
- TRANSACTION_SYNCHRONIZATION_REGISTRY_LOOKUP - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
- TRANSACTION_TIMEOUT - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- TRANSACTION_VERSION_GENERATOR - Static variable in class org.infinispan.factories.KnownComponentNames
- transactional() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- transactional() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
- transactional(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
-
This setting should be set to true when the underlying cache store supports transactions and it is desirable for the underlying store and the cache to remain synchronized.
- transactional(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
- transactional(boolean) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
-
This setting should be set to true when the underlying cache store supports transactions and it is desirable for the underlying store and the cache to remain synchronized.
- TRANSACTIONAL - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- TRANSACTIONAL - Enum constant in enum org.infinispan.persistence.spi.NonBlockingStore.Characteristic
-
If this store supports being invoked in a transactional context with prepare and commit or rollback phases.
- TRANSACTIONAL - Enum constant in enum org.infinispan.transaction.TransactionMode
- TRANSACTIONAL - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- TransactionalCache - Interface in org.infinispan.commons.api
-
This interface is implemented by caches that support (i.e.
- TransactionalCacheWriter<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
- TransactionalEvent<K,
V> - Interface in org.infinispan.notifications.cachelistener.event -
An event subtype that includes a transaction context - if one exists - as well as a boolean as to whether the call originated locally or remotely.
- TransactionalInvocationContextFactory - Class in org.infinispan.context.impl
-
Invocation context to be used for transactional caches.
- TransactionalInvocationContextFactory() - Constructor for class org.infinispan.context.impl.TransactionalInvocationContextFactory
- TransactionalRemoteLockCommand - Interface in org.infinispan.util.concurrent.locks
-
Simple interface to extract all the keys that may need to be locked for transactional commands.
- transactionalStore() - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
- transactionCompleted(TransactionCompletedEvent) - Method in class org.infinispan.notifications.cachelistener.cluster.RemoteClusterListener
- TransactionCompleted - Annotation Type in org.infinispan.notifications.cachelistener.annotation
-
This annotation should be used on methods that need to be notified when the cache is called to participate in a transaction and the transaction completes, either with a commit or a rollback.
- TransactionCompletedEvent<K,
V> - Interface in org.infinispan.notifications.cachelistener.event -
This event is passed in to any method annotated with
TransactionCompleted
. - TransactionConfiguration - Class in org.infinispan.client.hotrod.configuration
-
Deprecated, for removal: This API element is subject to removal in a future version.since 12.0. To be removed in Infinispan 14
- TransactionConfiguration - Class in org.infinispan.configuration.cache
-
Defines transactional (JTA) characteristics of the cache.
- TransactionConfigurationBuilder - Class in org.infinispan.client.hotrod.configuration
-
Deprecated, for removal: This API element is subject to removal in a future version.since 12.0. To be removed in Infinispan 14.
- TransactionConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Defines transactional (JTA) characteristics of the cache.
- TransactionConfigurationChildBuilder - Interface in org.infinispan.configuration.cache
- transactionConnectionMap - Variable in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
- TransactionCoordinator - Class in org.infinispan.transaction.impl
-
Coordinates transaction prepare/commits as received from the
TransactionManager
. - TransactionCoordinator() - Constructor for class org.infinispan.transaction.impl.TransactionCoordinator
- TransactionFactory - Class in org.infinispan.transaction.xa
-
Factory for transaction related state.
- TransactionFactory() - Constructor for class org.infinispan.transaction.xa.TransactionFactory
- TransactionFactory.TxFactoryEnum - Enum in org.infinispan.transaction.xa
- TransactionImpl - Class in org.infinispan.commons.tx
-
A basic
Transaction
implementation. - TransactionImpl() - Constructor for class org.infinispan.commons.tx.TransactionImpl
- transactionManager - Variable in class org.infinispan.cache.impl.CacheImpl
- transactionManager - Variable in class org.infinispan.cache.impl.InvocationHelper
- transactionManager(TransactionManager) - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.since 12.0. To be removed in Infinispan 14. Use
RemoteCacheConfigurationBuilder.transactionManagerLookup(TransactionManagerLookup)
instead. - TransactionManagerFactory - Class in org.infinispan.factories
-
Uses a number of mechanisms to retrieve a transaction manager.
- TransactionManagerFactory() - Constructor for class org.infinispan.factories.TransactionManagerFactory
- transactionManagerId - Variable in class org.infinispan.commons.tx.TransactionManagerImpl
- TransactionManagerImpl - Class in org.infinispan.commons.tx
-
A simple
TransactionManager
implementation. - TransactionManagerImpl() - Constructor for class org.infinispan.commons.tx.TransactionManagerImpl
- transactionManagerLookup() - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
- transactionManagerLookup() - Method in class org.infinispan.client.hotrod.configuration.TransactionConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.
- transactionManagerLookup() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
-
Configure Transaction manager lookup directly using an instance of TransactionManagerLookup.
- transactionManagerLookup() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
- transactionManagerLookup(TransactionManagerLookup) - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfigurationBuilder
-
The
TransactionManagerLookup
to lookup for theTransactionManager
to interact with. - transactionManagerLookup(TransactionManagerLookup) - Method in class org.infinispan.client.hotrod.configuration.TransactionConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.since 12.0. To be removed in Infinispan 14. Use
RemoteCacheConfigurationBuilder.transactionManagerLookup(TransactionManagerLookup)
- transactionManagerLookup(TransactionManagerLookup) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
-
Configure Transaction manager lookup directly using an instance of TransactionManagerLookup.
- TransactionManagerLookup - Interface in org.infinispan.commons.tx.lookup
-
Factory interface, allows Cache or RemoteCache to use different transactional systems.
- transactionMode() - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfiguration
- transactionMode() - Method in class org.infinispan.client.hotrod.configuration.TransactionConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.
- transactionMode() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
- transactionMode() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
- transactionMode(TransactionMode) - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfigurationBuilder
-
The
TransactionMode
in which aRemoteCache
will be enlisted. - transactionMode(TransactionMode) - Method in class org.infinispan.client.hotrod.configuration.TransactionConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.since 12.0. To be removed in Infinispan 14. Use
RemoteCacheConfigurationBuilder.transactionMode(TransactionMode)
- transactionMode(TransactionMode) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
- TransactionMode - Enum in org.infinispan.client.hotrod.configuration
-
Specifies how the
RemoteCache
is enlisted in theTransaction
. - TransactionMode - Enum in org.infinispan.configuration.cache
-
Transaction mode
- TransactionMode - Enum in org.infinispan.transaction
-
Enumeration containing the available transaction modes for a cache.
- transactionOriginatorChecker - Variable in class org.infinispan.transaction.impl.TransactionTable
- TransactionOriginatorChecker - Interface in org.infinispan.transaction.impl
-
An interface to check if the transaction originator is left or not.
- TransactionRegistered - Annotation Type in org.infinispan.notifications.cachelistener.annotation
-
This annotation should be used on methods that need to be notified when the cache is called to participate in a transaction and registers a
Synchronization
with a registeredTransactionManager
. - TransactionRegisteredEvent<K,
V> - Interface in org.infinispan.notifications.cachelistener.event -
This event is passed in to any method annotated with
TransactionRegistered
. - TransactionResourceConverter - Interface in org.infinispan.commons.tx
- transactionResponse(HotRodHeader, HotRodServer, Channel, int) - Method in class org.infinispan.server.hotrod.Encoder4x
- transactionResponse(HotRodHeader, HotRodServer, Channel, int) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- TransactionStatistics - Class in org.infinispan.extendedstats
-
Keeps the temporary statistics for a transaction.
- TransactionStatistics(ExtendedStatisticsContainer, TimeService) - Constructor for class org.infinispan.extendedstats.TransactionStatistics
- transactionStatusToString(int) - Static method in class org.infinispan.commons.tx.Util
- TransactionSynchronizationRegistryFactory - Class in org.infinispan.factories
-
Factory for the TransactionSynchronizationRegistry
- TransactionSynchronizationRegistryFactory() - Constructor for class org.infinispan.factories.TransactionSynchronizationRegistryFactory
- transactionSynchronizationRegistryLookup() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
-
Configure Transaction Synchronization Registry lookup directly using an instance of TransactionManagerLookup.
- transactionSynchronizationRegistryLookup(TransactionSynchronizationRegistryLookup) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
-
Configure Transaction Synchronization Registry lookup directly using an instance of TransactionManagerLookup.
- TransactionSynchronizationRegistryLookup - Interface in org.infinispan.transaction.lookup
- TransactionTable - Class in org.infinispan.transaction.impl
-
Repository for
RemoteTransaction
andTransactionXaAdapter
s (locally originated transactions). - TransactionTable - Interface in org.infinispan.transaction
-
Interface that allows to fetch the
GlobalTransaction
associated to local or remote transactions. - TransactionTable() - Constructor for class org.infinispan.transaction.impl.TransactionTable
- TransactionTable.CompletedTransactionStatus - Enum in org.infinispan.transaction.impl
- TransactionTableFactory - Class in org.infinispan.factories
-
Factory for
TransactionTable
objects. - TransactionTableFactory() - Constructor for class org.infinispan.factories.TransactionTableFactory
- transactionTableNotStarted() - Method in interface org.infinispan.client.hotrod.logging.Log
- transactionTimeout() - Method in class org.infinispan.client.hotrod.configuration.Configuration
- transactionTimeout(long, TimeUnit) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
- transactionTimeout(long, TimeUnit) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- transactionTimeout(long, TimeUnit) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
-
Sets the transaction's timeout.
- TransactionXaAdapter - Class in org.infinispan.transaction.xa
-
This acts both as an local
CacheTransaction
and implementor of anXAResource
that will be called by tx manager on various tx stages. - TransactionXaAdapter(LocalXaTransaction, XaTransactionTable) - Constructor for class org.infinispan.transaction.xa.TransactionXaAdapter
- TransactionXaAdapter(XaTransactionTable) - Constructor for class org.infinispan.transaction.xa.TransactionXaAdapter
- transcode(Object, MediaType, MediaType) - Method in class org.infinispan.commons.dataconversion.AbstractTranscoder
- transcode(Object, MediaType, MediaType) - Method in interface org.infinispan.commons.dataconversion.Transcoder
-
Transcodes content between two different
MediaType
. - Transcoder - Interface in org.infinispan.commons.dataconversion
-
Converts content between two or more
MediaType
s. - TranscoderMarshallerAdapter - Class in org.infinispan.commons.dataconversion
-
Base class for transcoder between application/x-java-object and byte[] produced by a marshaller.
- TranscoderMarshallerAdapter(Marshaller) - Constructor for class org.infinispan.commons.dataconversion.TranscoderMarshallerAdapter
- TranscodingException - Exception in org.infinispan.server.core.dataconversion
- TranscodingException(String) - Constructor for exception org.infinispan.server.core.dataconversion.TranscodingException
- TRANSFER_ENCODING - Enum constant in enum org.infinispan.rest.ResponseHeader
- transferComplete() - Method in interface org.infinispan.notifications.cachelistener.QueueingSegmentListener
-
This is needed to tell the handler when the complete iteration is done.
- transform(E) - Method in interface org.infinispan.commons.util.InfinispanCollections.Function
-
Transforms an instance of the given input into an instace of the type to be returned.
- transform(E) - Method in interface org.infinispan.commons.util.InfinispanCollections.MapMakerFunction
-
Transforms the given input into a key/value pair for use in a map
- transform(Function<AdvancedCache<K, V>, ? extends AdvancedCache<K, V>>) - Method in interface org.infinispan.AdvancedCache
-
Apply the
transformation
on eachAdvancedCache
instance in a delegation chain, starting with the innermost implementation. - transform(Function<AdvancedCache<K, V>, ? extends AdvancedCache<K, V>>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- transform(Function<AdvancedCache<K, V>, ? extends AdvancedCache<K, V>>) - Method in class org.infinispan.cache.impl.CacheImpl
- transform(Function<AdvancedCache<K, V>, ? extends AdvancedCache<K, V>>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- transform(Function<AdvancedCache<K, V>, ? extends AdvancedCache<K, V>>) - Method in class org.infinispan.security.impl.SecureCacheImpl
- Transformable - Annotation Type in org.infinispan.query
-
Annotate objects to convert them to keys that Infinispan can index.
- transformCollectionToMap(Collection<? extends E>, InfinispanCollections.MapMakerFunction<K, V, ? super E>) - Static method in class org.infinispan.commons.util.InfinispanCollections
-
Given a collection, transforms the collection to a map given a
InfinispanCollections.MapMakerFunction
- transformer() - Element in annotation type org.infinispan.query.Transformable
-
The
Transformer
to use. - Transformer - Interface in org.infinispan.query
-
Converts objects (cache keys only) to and from their Java types to String representations so that Infinispan can index them.
- TRANSFORMER - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- transformMapValue(Map<K, E>, InfinispanCollections.Function<E, V>) - Static method in class org.infinispan.commons.util.InfinispanCollections
-
Given a map of well known key/value types, it makes a shallow copy of it while at the same time transforming it's value type to a desired output type.
- TRANSIENT_ENTRY - Static variable in interface org.infinispan.commons.marshall.Ids
- TRANSIENT_MORTAL_ENTRY - Static variable in interface org.infinispan.commons.marshall.Ids
- TRANSIENT_MORTAL_VALUE - Static variable in interface org.infinispan.commons.marshall.Ids
- TRANSIENT_VALUE - Static variable in interface org.infinispan.commons.marshall.Ids
- TransientCacheEntry - Class in org.infinispan.container.entries
-
A cache entry that is transient, i.e., it can be considered expired after a period of not being used.
- TransientCacheEntry(Object, Object, long, long) - Constructor for class org.infinispan.container.entries.TransientCacheEntry
- TransientCacheEntry(Object, Object, PrivateMetadata, long, long) - Constructor for class org.infinispan.container.entries.TransientCacheEntry
- TransientCacheEntry.Externalizer - Class in org.infinispan.container.entries
- TransientCacheValue - Class in org.infinispan.container.entries
-
A transient cache value, to correspond with
TransientCacheEntry
- TransientCacheValue(Object, long, long) - Constructor for class org.infinispan.container.entries.TransientCacheValue
- TransientCacheValue(Object, PrivateMetadata, long, long) - Constructor for class org.infinispan.container.entries.TransientCacheValue
- TransientCacheValue.Externalizer - Class in org.infinispan.container.entries
- TransientMortalCacheEntry - Class in org.infinispan.container.entries
-
A cache entry that is both transient and mortal.
- TransientMortalCacheEntry(Object, Object, long, long, long) - Constructor for class org.infinispan.container.entries.TransientMortalCacheEntry
- TransientMortalCacheEntry(Object, Object, long, long, long, long) - Constructor for class org.infinispan.container.entries.TransientMortalCacheEntry
- TransientMortalCacheEntry(Object, Object, PrivateMetadata, long, long, long, long) - Constructor for class org.infinispan.container.entries.TransientMortalCacheEntry
- TransientMortalCacheEntry.Externalizer - Class in org.infinispan.container.entries
- TransientMortalCacheValue - Class in org.infinispan.container.entries
-
A transient, mortal cache value to correspond with
TransientMortalCacheEntry
- TransientMortalCacheValue(Object, long, long, long, long) - Constructor for class org.infinispan.container.entries.TransientMortalCacheValue
- TransientMortalCacheValue(Object, PrivateMetadata, long, long, long, long) - Constructor for class org.infinispan.container.entries.TransientMortalCacheValue
- TransientMortalCacheValue.Externalizer - Class in org.infinispan.container.entries
- TRANSITORY - Enum constant in enum org.infinispan.topology.CacheTopology.Phase
-
Used by caches that don't use 4-phase topology change.
- transport - Variable in class org.infinispan.server.core.AbstractProtocolServer
- transport - Variable in class org.infinispan.server.core.transport.NettyChannelInitializer
- transport - Variable in class org.infinispan.server.memcached.MemcachedDecoder
- transport() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
- transport() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
- transport() - Method in class org.infinispan.configuration.global.GlobalConfiguration
- transport() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- transport() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Transport-related (i.e.
- transport() - Method in class org.infinispan.configuration.global.JGroupsConfiguration
- transport() - Method in class org.infinispan.configuration.global.TransportConfiguration
- transport(Transport) - Method in class org.infinispan.configuration.global.JGroupsConfigurationBuilder
- transport(Transport) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
-
Class that represents a network transport.
- Transport - Interface in org.infinispan.remoting.transport
-
An interface that provides a communication link with remote caches.
- Transport - Interface in org.infinispan.server.core.transport
-
Server transport abstraction
- TRANSPORT - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- TRANSPORT - Enum constant in enum org.infinispan.configuration.parsing.Element
- TRANSPORT_EXECUTOR - Static variable in class org.infinispan.configuration.global.TransportConfiguration
- TRANSPORT_FACTORY - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- TRANSPORT_FACTORY - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- TransportConfiguration - Class in org.infinispan.configuration.global
- TransportConfigurationBuilder - Class in org.infinispan.configuration.global
-
Configures the transport used for network communications across the cluster.
- TransportException - Exception in org.infinispan.client.hotrod.exceptions
-
Indicates a communication exception with the Hot Rod server: e.g.
- TransportException(String, Throwable, SocketAddress) - Constructor for exception org.infinispan.client.hotrod.exceptions.TransportException
- TransportException(String, SocketAddress) - Constructor for exception org.infinispan.client.hotrod.exceptions.TransportException
- TransportException(Throwable, SocketAddress) - Constructor for exception org.infinispan.client.hotrod.exceptions.TransportException
- transportExecutor(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.
- transportFactory() - Method in class org.infinispan.client.hotrod.configuration.Configuration
- transportFactory() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.0. This method always returns null
- transportFactory(Class<? extends ChannelFactory>) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- transportFactory(Class<? extends ChannelFactory>) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- transportFactory(Class<? extends ChannelFactory>) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.0. This method has no effect
- transportFactory(String) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- transportFactory(String) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- transportFactory(String) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.0. This method has no effect
- transportFactory(TransportFactory) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
- transportFactory(TransportFactory) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- transportFactory(TransportFactory) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
-
Set the TransportFactory.
- TransportFactory - Class in org.infinispan.factories
-
Factory for Transport implementations.
- TransportFactory - Interface in org.infinispan.client.hotrod
-
TransportFactory is responsible for creating Netty's
SocketChannel
s andEventLoopGroup
s. - TransportFactory() - Constructor for class org.infinispan.factories.TransportFactory
- transportThreadPool() - Method in class org.infinispan.configuration.global.ThreadsConfiguration
-
Deprecated.Since 11.0, no longer used.
- transportThreadPool() - Method in class org.infinispan.configuration.global.ThreadsConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 11.0, no longer used.
- transportThreadPool() - Method in class org.infinispan.configuration.global.TransportConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.
- transportThreadPool() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
- transportThreadPoolName() - Method in class org.infinispan.configuration.global.TransportConfiguration
- Traversable<T> - Interface in org.infinispan.functional
-
Unsorted traversable stream for sequential and aggregating operations.
- Traversables - Class in org.infinispan.functional.impl
- TRIANGLE_ACK_EXTERNALIZER - Static variable in interface org.infinispan.commons.marshall.Ids
- TriangleAckExternalizer - Class in org.infinispan.marshall.exts
-
Externalizer for the triangle acknowledges.
- TriangleAckExternalizer() - Constructor for class org.infinispan.marshall.exts.TriangleAckExternalizer
- TriangleFunctionsUtil - Class in org.infinispan.util
-
Some utility functions for
TriangleDistributionInterceptor
. - TriangleOrderAction - Class in org.infinispan.remoting.inboundhandler.action
-
An
Action
that checks if the command is the next to be executed. - TriangleOrderAction(TrianglePerCacheInboundInvocationHandler, long, int) - Constructor for class org.infinispan.remoting.inboundhandler.action.TriangleOrderAction
- TriangleOrderManager - Class in org.infinispan.distribution
-
It manages the order of updates from the primary owner to backup owner.
- TriangleOrderManager(int) - Constructor for class org.infinispan.distribution.TriangleOrderManager
- TriConsumer<T,
U, V> - Interface in org.infinispan.util.function -
Represents an operation that accepts three input arguments and returns no result.
- trim() - Method in interface org.infinispan.commons.io.ByteBuffer
-
Returns a trimmed byte array.
- TriPredicate<T,
U, V> - Interface in org.infinispan.util.function -
Represents a predicate (boolean-valued function) of three arguments.
- truncate() - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
-
Truncate the contents of the cache, returning a
CompletableFuture
that will be completed when the truncate process completes. - truncate() - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
- truncate(long) - Method in class org.infinispan.persistence.sifs.FileProvider.Handle
- TRUST_STORE_FILE_NAME - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- TRUST_STORE_PASSWORD - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- TRUST_STORE_PATH - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- TRUST_STORE_TYPE - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- TRUSTSTORE - Enum constant in enum org.infinispan.persistence.remote.configuration.Element
- trustStoreConfiguration() - Method in class org.infinispan.persistence.remote.configuration.SslConfiguration
- TrustStoreConfiguration - Class in org.infinispan.persistence.remote.configuration
- TrustStoreConfigurationBuilder - Class in org.infinispan.persistence.remote.configuration
- TrustStoreConfigurationBuilder(SecurityConfigurationBuilder) - Constructor for class org.infinispan.persistence.remote.configuration.TrustStoreConfigurationBuilder
- trustStoreFileAndPathExclusive() - Method in interface org.infinispan.client.hotrod.logging.Log
- trustStoreFileName() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
- trustStoreFileName() - Method in class org.infinispan.persistence.remote.configuration.SslConfiguration
- trustStoreFileName() - Method in class org.infinispan.persistence.remote.configuration.TrustStoreConfiguration
- trustStoreFileName() - Method in class org.infinispan.server.core.configuration.SslConfiguration
- trustStoreFileName() - Method in class org.infinispan.server.core.configuration.SslEngineConfiguration
- trustStoreFileName(String) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
-
Specifies the filename of a truststore to use to create the
SSLContext
You also need to specify aSslConfigurationBuilder.trustStorePassword(char[])
. - trustStoreFileName(String) - Method in class org.infinispan.commons.util.SslContextFactory
- trustStoreFileName(String) - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
-
Specifies the filename of a truststore to use to create the
SSLContext
You also need to specify aSslConfigurationBuilder.trustStorePassword(char[])
. - trustStoreFileName(String) - Method in class org.infinispan.persistence.remote.configuration.TrustStoreConfigurationBuilder
- trustStoreFileName(String) - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
-
Specifies the filename of a truststore to use to create the
SSLContext
You also need to specify aSslConfigurationBuilder.trustStorePassword(char[])
. - trustStoreFileName(String) - Method in class org.infinispan.server.core.configuration.SslEngineConfigurationBuilder
-
Specifies the filename of a truststore to use to create the
SSLContext
You also need to specify aSslEngineConfigurationBuilder.trustStorePassword(char[])
. - trustStorePassword() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
- trustStorePassword() - Method in class org.infinispan.persistence.remote.configuration.SslConfiguration
- trustStorePassword() - Method in class org.infinispan.persistence.remote.configuration.TrustStoreConfiguration
- trustStorePassword() - Method in class org.infinispan.server.core.configuration.SslConfiguration
- trustStorePassword() - Method in class org.infinispan.server.core.configuration.SslEngineConfiguration
- trustStorePassword(char[]) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
-
Specifies the password needed to open the truststore You also need to specify a
SslConfigurationBuilder.trustStoreFileName(String)
. - trustStorePassword(char[]) - Method in class org.infinispan.commons.util.SslContextFactory
- trustStorePassword(char[]) - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
-
Specifies the password needed to open the truststore You also need to specify a
SslConfigurationBuilder.trustStoreFileName(String)
. - trustStorePassword(char[]) - Method in class org.infinispan.persistence.remote.configuration.TrustStoreConfigurationBuilder
- trustStorePassword(char[]) - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
-
Specifies the password needed to open the truststore You also need to specify a
SslConfigurationBuilder.trustStoreFileName(String)
. - trustStorePassword(char[]) - Method in class org.infinispan.server.core.configuration.SslEngineConfigurationBuilder
-
Specifies the password needed to open the truststore You also need to specify a
SslEngineConfigurationBuilder.trustStoreFileName(String)
. - trustStorePath() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
- trustStorePath(String) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.since 12.0 to be removed in 15.0. Use
SslConfigurationBuilder.trustStoreFileName(String)
and pass pem toSslConfigurationBuilder.trustStoreType(String)
. - trustStoreType() - Method in class org.infinispan.client.hotrod.configuration.SslConfiguration
- trustStoreType() - Method in class org.infinispan.persistence.remote.configuration.SslConfiguration
- trustStoreType() - Method in class org.infinispan.persistence.remote.configuration.TrustStoreConfiguration
- trustStoreType() - Method in class org.infinispan.server.core.configuration.SslEngineConfiguration
- trustStoreType(String) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
-
Specifies the type of the truststore, such as JKS or JCEKS.
- trustStoreType(String) - Method in class org.infinispan.commons.util.SslContextFactory
- trustStoreType(String) - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
-
Specifies the type of the truststore, such as JKS or JCEKS.
- trustStoreType(String) - Method in class org.infinispan.persistence.remote.configuration.TrustStoreConfigurationBuilder
- trustStoreType(String) - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
-
Specifies the type of the truststore, such as JKS or JCEKS.
- trustStoreType(String) - Method in class org.infinispan.server.core.configuration.SslEngineConfigurationBuilder
-
Specifies the type of the truststore, such as JKS or JCEKS.
- TRY_LOCK - Enum constant in enum org.infinispan.functional.Param.LockingMode
-
The operation fails when it is not possible to acquire the lock without waiting.
- tryAcquireShared(int) - Method in class org.infinispan.util.concurrent.ReclosableLatch
- tryAdvance(Consumer<? super E>) - Method in class org.infinispan.commons.util.FlattenSpliterator
- tryAdvance(Consumer<? super S>) - Method in class org.infinispan.commons.util.SpliteratorMapper
- tryAdvance(Consumer<? super T>) - Method in class org.infinispan.commons.util.FilterSpliterator
- tryFlushAll() - Method in class org.infinispan.extendedstats.topK.StreamSummaryContainer
-
Tries to flush all the enqueue offers to be visible globally.
- tryJavaDeserialize(byte[], byte[], ClassAllowList) - Static method in class org.infinispan.client.hotrod.marshall.MarshallerUtil
- tryLock() - Method in class org.infinispan.commons.util.concurrent.NonReentrantLock
- tryLock() - Method in interface org.infinispan.lock.api.ClusteredLock
-
Acquires the lock only if it is free at the time of invocation.
- tryLock(long, TimeUnit) - Method in class org.infinispan.commons.util.concurrent.NonReentrantLock
- tryLock(long, TimeUnit) - Method in interface org.infinispan.lock.api.ClusteredLock
-
If the lock is available this method returns immediately with the
CompletableFuture
holding the valuetrue
. - tryLookup(ClassLoader) - Method in enum org.infinispan.commons.tx.lookup.LookupNames.TransactionManagerFactory
- tryReleaseShared(int) - Method in class org.infinispan.util.concurrent.ReclosableLatch
- trySplit() - Method in class org.infinispan.commons.util.FilterSpliterator
- trySplit() - Method in class org.infinispan.commons.util.FlattenSpliterator
- trySplit() - Method in class org.infinispan.commons.util.SpliteratorMapper
- TTL_SECONDS_HEADER - Enum constant in enum org.infinispan.rest.RequestHeader
- TwoStepTranscoder - Class in org.infinispan.encoding.impl
-
Performs conversions where there is no direct transcoder, but there are two transcoders available: one from source media type to application/x-java-object one from application/x-java-object to the destination media type
- TwoStepTranscoder(Transcoder, Transcoder) - Constructor for class org.infinispan.encoding.impl.TwoStepTranscoder
- TwoWayKey2StringMapper - Interface in org.infinispan.persistence.keymappers
-
Extends
Key2StringMapper
and allows a bidirectional transformation between keys and Strings. - twoWayKey2StringMapperIsMissing(String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- tx - Variable in class org.infinispan.transaction.impl.AbstractCacheTransaction
- TX_STATE - Static variable in class org.infinispan.server.core.ExternalizerIds
- TxClusterExpirationManager<K,
V> - Class in org.infinispan.expiration.impl - TxClusterExpirationManager() - Constructor for class org.infinispan.expiration.impl.TxClusterExpirationManager
- txCoordinator - Variable in class org.infinispan.transaction.impl.TransactionTable
- TxFunction - Class in org.infinispan.server.hotrod.tx.table.functions
- TxFunction() - Constructor for class org.infinispan.server.hotrod.tx.table.functions.TxFunction
- TxInvocationContext<T extends AbstractCacheTransaction> - Interface in org.infinispan.context.impl
-
Interface defining additional functionality for invocation contexts that propagate within a transaction's scope.
- TxLockedStreamImpl<K,
V> - Class in org.infinispan.stream.impl -
Locked Stream that is designed for transactions.
- TxLockedStreamImpl(TransactionManager, CacheStream<CacheEntry<K, V>>, long, TimeUnit) - Constructor for class org.infinispan.stream.impl.TxLockedStreamImpl
- TxState - Class in org.infinispan.server.hotrod.tx.table
-
A transaction state stored globally in all the cluster members.
- TxState(GlobalTransaction, boolean, long, TimeService) - Constructor for class org.infinispan.server.hotrod.tx.table.TxState
- type - Variable in class org.infinispan.server.core.backup.resources.CounterResource
- type() - Method in class org.infinispan.commons.util.Either
- type() - Method in class org.infinispan.counter.api.CounterConfiguration
- type() - Method in interface org.infinispan.search.mapper.common.EntityReference
- type() - Method in class org.infinispan.search.mapper.common.impl.EntityReferenceImpl
- TYPE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- TYPE - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
- TYPE - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- TYPE - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.Attribute
- TYPE - Static variable in interface org.infinispan.jmx.ObjectNameKeys
- TYPE - Static variable in interface org.infinispan.query.remote.json.JSONConstants
- TYPE - Static variable in interface org.infinispan.rest.JSONConstants
- TYPE_PROPERTY - Static variable in class org.infinispan.server.core.dataconversion.JsonTranscoder
- TypedProperties - Class in org.infinispan.commons.util
-
Type-aware properties.
- TypedProperties() - Constructor for class org.infinispan.commons.util.TypedProperties
-
Default constructor that returns an empty instance
- TypedProperties(Map<?, ?>) - Constructor for class org.infinispan.commons.util.TypedProperties
-
Copy constructor
- TypedPropertiesAttributeCopier - Class in org.infinispan.commons.configuration.attributes
-
TypedPropertiesAttributeCopier.
- TypedPropertiesAttributeCopier() - Constructor for class org.infinispan.commons.configuration.attributes.TypedPropertiesAttributeCopier
- typeFromId(DatabindContext, String) - Method in class org.infinispan.server.core.dataconversion.json.SecureTypeIdResolver
-
Deprecated.
- typeIdentifier() - Method in interface org.infinispan.search.mapper.session.impl.InfinispanIndexedTypeContext
- typeIsUsingDefaultTransformer(Class<?>) - Method in interface org.infinispan.query.logging.Log
- typeModel(Class<T>) - Method in class org.infinispan.search.mapper.model.impl.InfinispanBootstrapIntrospector
- typeModel(String) - Method in class org.infinispan.search.mapper.model.impl.InfinispanBootstrapIntrospector
- TYPES - Static variable in interface org.infinispan.commons.configuration.io.xml.XmlPullParser
-
This array can be used to convert the event type integer constants such as START_TAG or TEXT to to a string.
U
- UDP(Properties) - Static method in class org.infinispan.remoting.transport.jgroups.BuiltinJGroupsChannelConfigurator
- unableToCalculateLocalExecutionTimeWithoutContention(Throwable) - Method in interface org.infinispan.extendedstats.logging.Log
- unableToCopyValue(ExtendedStatistic, ExtendedStatistic, Throwable) - Method in interface org.infinispan.extendedstats.logging.Log
- unableToDetectDialect(String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- unableToFetchCaches() - Method in interface org.infinispan.counter.logging.Log
- unableToFindBackupResource(String, Set<String>) - Method in interface org.infinispan.server.core.logging.Log
- unableToFindResource(String, String) - Method in interface org.infinispan.server.core.logging.Log
- unableToGetPercentile(int, PercentileStatistic, Throwable) - Method in interface org.infinispan.extendedstats.logging.Log
- unableToGetStatistic(ExtendedStatistic, Throwable) - Method in interface org.infinispan.extendedstats.logging.Log
- unableToLoadTheClass(String, Throwable) - Method in interface org.infinispan.search.mapper.log.impl.Log
- unableToReadEventFromServer(Throwable, SocketAddress) - Method in interface org.infinispan.client.hotrod.logging.Log
- unableToResumeSuspendedTx(Transaction, Throwable) - Method in interface org.infinispan.query.logging.Log
- unableToSetAccesible(Method, Exception) - Method in interface org.infinispan.client.hotrod.logging.Log
- unableToSuspendTx(Throwable) - Method in interface org.infinispan.query.logging.Log
- unableToUnmarshallBytes(String, Exception) - Method in interface org.infinispan.client.hotrod.logging.Log
- UnacceptableDataFormatException - Exception in org.infinispan.rest.operations.exceptions
- UnacceptableDataFormatException() - Constructor for exception org.infinispan.rest.operations.exceptions.UnacceptableDataFormatException
- UnacceptableDataFormatException(String) - Constructor for exception org.infinispan.rest.operations.exceptions.UnacceptableDataFormatException
- unauthorizedOperation(String) - Method in interface org.infinispan.server.hotrod.logging.Log
- UNBOUNDED - Static variable in interface org.infinispan.context.InvocationContextFactory
-
To be used when building InvocationContext with
InvocationContextFactory.createInvocationContext(boolean, int)
as an indicator of the fact that the size of the keys to be accessed in the context is not known. - UNBOUNDED_STRONG - Enum constant in enum org.infinispan.counter.api.CounterType
-
A strong consistent and unbounded counter.
- unBoundedDataContainer(int) - Static method in class org.infinispan.container.impl.DefaultDataContainer
- uncaughtExceptionInThePipeline(Throwable) - Method in interface org.infinispan.rest.logging.Log
- unchecked(Throwable) - Static method in class org.infinispan.commons.util.Util
- uncheckedAwait(CompletableFuture<?>, long, TimeUnit) - Static method in class org.infinispan.commons.util.concurrent.CompletableFutures
-
Same as
CompletableFutures.await(CompletableFuture, long, TimeUnit)
but wraps checked exceptions inCacheException
- uncheckedAwait(CompletableFuture<T>) - Static method in class org.infinispan.commons.util.concurrent.CompletableFutures
-
Same as
CompletableFutures.await(CompletableFuture)
but wraps checked exceptions inCacheException
- UnclosableObjectInputStream - Class in org.infinispan.io
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.0
- UnclosableObjectInputStream(ObjectInput) - Constructor for class org.infinispan.io.UnclosableObjectInputStream
-
Deprecated.
- UnclosableObjectOutputStream - Class in org.infinispan.io
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.0
- UnclosableObjectOutputStream(ObjectOutput) - Constructor for class org.infinispan.io.UnclosableObjectOutputStream
-
Deprecated.
- undefineConfiguration(String) - Method in class org.infinispan.manager.DefaultCacheManager
- undefineConfiguration(String) - Method in interface org.infinispan.manager.EmbeddedCacheManager
-
Removes a configuration from the set of defined configurations.
- undefineConfiguration(String) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
- UndefineConfigurationAction - Class in org.infinispan.security.actions
-
UndefineConfigurationAction.
- UndefineConfigurationAction(EmbeddedCacheManager, String) - Constructor for class org.infinispan.security.actions.UndefineConfigurationAction
- undefineCounter(String) - Method in class org.infinispan.client.hotrod.counter.impl.RemoteCounterManager
- undefineCounter(String) - Method in interface org.infinispan.counter.api.CounterManager
-
It removes the counter and its configuration from the cluster.
- undefinedCounter(String) - Method in interface org.infinispan.counter.logging.Log
- undelegate() - Method in class org.infinispan.persistence.support.DelegatingCacheLoader
- undelegate() - Method in class org.infinispan.persistence.support.DelegatingCacheWriter
- underlyingStream - Variable in class org.infinispan.util.AbstractDelegatingCacheStream
- unexpectedAttribute(ConfigurationReader, int) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Get an exception reporting an unexpected XML attribute.
- unexpectedAttribute(ConfigurationReader, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Get an exception reporting an unexpected XML attribute.
- unexpectedClassNotFoundException(ClassNotFoundException) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- unexpectedElement(ConfigurationReader) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Get an exception reporting an unexpected XML element.
- unexpectedElement(ConfigurationReader, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- unexpectedElement(ConfigurationReader, T) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- unexpectedEndElement(ConfigurationReader) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Get an exception reporting an unexpected end tag for an XML element.
- unexpectedErrorConsumingEvent(Object, Throwable) - Method in interface org.infinispan.client.hotrod.logging.Log
- unexpectedEvent(Event) - Method in interface org.infinispan.server.hotrod.logging.Log
- unexpectedIsolationLevel(String) - Method in interface org.infinispan.server.hotrod.logging.Log
- unexpectedListenerId(String) - Method in interface org.infinispan.client.hotrod.logging.Log
- UnicastEventContext() - Constructor for class org.infinispan.notifications.cachelistener.cluster.impl.BatchingClusterEventManagerImpl.UnicastEventContext
- unicodeEscapeString(String) - Static method in class org.infinispan.commons.util.Util
- unicodeUnescapeString(String) - Static method in class org.infinispan.commons.util.Util
- unignoreCache(String) - Method in interface org.infinispan.server.core.ServerStateManager
- union(CH, CH) - Method in interface org.infinispan.distribution.ch.ConsistentHashFactory
-
Deprecated.Creates a union of two compatible ConsistentHashes (use the same hashing function and have the same configuration parameters).
- union(DefaultConsistentHash) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHash
-
Merges two consistent hash objects that have the same number of segments, numOwners and hash function.
- union(DefaultConsistentHash, DefaultConsistentHash) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
-
Merges two consistent hash objects that have the same number of segments, numOwners and hash function.
- union(DefaultConsistentHash, DefaultConsistentHash) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory
- union(ReplicatedConsistentHash) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHash
- union(ReplicatedConsistentHash, ReplicatedConsistentHash) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory
- union(ReplicatedConsistentHash, ReplicatedConsistentHash) - Method in class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory
- union(ScatteredConsistentHash) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHash
-
Prefers owners from the second hash -> effectively this will make pendingCH == unionCH (I think)
- union(ScatteredConsistentHash, ScatteredConsistentHash) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory
-
Merges two consistent hash objects that have the same number of segments, numOwners and hash function.
- unionCapacityFactors(AbstractConsistentHash) - Method in class org.infinispan.distribution.ch.impl.AbstractConsistentHash
- UNIX - Enum constant in enum org.infinispan.commons.util.OS
- UNKNOWN - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- UNKNOWN - Enum constant in enum org.infinispan.configuration.parsing.Element
- UNKNOWN - Enum constant in enum org.infinispan.counter.configuration.Attribute
- UNKNOWN - Enum constant in enum org.infinispan.counter.configuration.Element
- UNKNOWN - Enum constant in enum org.infinispan.lock.configuration.Attribute
- UNKNOWN - Enum constant in enum org.infinispan.lock.configuration.Element
- UNKNOWN - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
- UNKNOWN - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
- UNKNOWN - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- UNKNOWN - Enum constant in enum org.infinispan.persistence.remote.configuration.Element
- UNKNOWN - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.Attribute
- UNKNOWN - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.Element
- UNKNOWN - Enum constant in enum org.infinispan.server.hotrod.configuration.Attribute
- UNKNOWN - Enum constant in enum org.infinispan.server.hotrod.configuration.Element
- UNKNOWN - Enum constant in enum org.infinispan.server.hotrod.HotRodVersion
- unknownAction(String) - Method in interface org.infinispan.rest.logging.Log
- unknownEvent(short) - Method in interface org.infinispan.client.hotrod.logging.Log
- unknownMessageId(long) - Method in interface org.infinispan.client.hotrod.logging.Log
- UnknownOperation - Enum constant in enum org.infinispan.server.hotrod.OperationStatus
- unknownScriptProperty(String) - Method in interface org.infinispan.scripting.logging.Log
- UnknownVersion - Enum constant in enum org.infinispan.server.hotrod.OperationStatus
- unlock() - Method in class org.infinispan.commons.util.concurrent.NonReentrantLock
- unlock() - Method in interface org.infinispan.lock.api.ClusteredLock
-
Releases the lock.
- unlock(Object, Object) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticLockManager
- unlock(Object, Object) - Method in class org.infinispan.extendedstats.wrappers.TopKeyLockManager
- unlock(Object, Object) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
- unlock(Object, Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
-
Releases the lock for the
key
if thelockOwner
is the lock owner. - UNLOCK_FAILED_MSG - Static variable in interface org.infinispan.lock.logging.Log
- unlockAll(Collection<?>, Object) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticLockManager
- unlockAll(Collection<?>, Object) - Method in class org.infinispan.extendedstats.wrappers.TopKeyLockManager
- unlockAll(Collection<?>, Object) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
- unlockAll(Collection<?>, Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
-
Same as
LockManager.unlock(Object, Object)
but for multiple keys. - unlockAll(InvocationContext) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticLockManager
- unlockAll(InvocationContext) - Method in class org.infinispan.extendedstats.wrappers.TopKeyLockManager
- unlockAll(InvocationContext) - Method in class org.infinispan.util.concurrent.locks.impl.DefaultLockManager
- unlockAll(InvocationContext) - Method in interface org.infinispan.util.concurrent.locks.LockManager
-
Same as
unlockAll(context.getLockedKeys(), context.getKeyLockOwner();
. - unlockFailed(String, Object) - Method in interface org.infinispan.lock.logging.Log
- unmarshall(byte[]) - Method in class org.infinispan.commons.dataconversion.MarshallerEncoder
-
Deprecated.
- unmarshall(InputStream, StreamAwareMarshaller) - Static method in class org.infinispan.persistence.jdbc.common.JdbcUtil
- unmarshall(ByteBuffer, Marshaller) - Static method in class org.infinispan.persistence.jdbc.common.JdbcUtil
- unmarshallArray(ObjectInput, MarshallUtil.ArrayBuilder<E>) - Static method in class org.infinispan.commons.marshall.MarshallUtil
-
Unmarshall arrays.
- unmarshallByteArray(ObjectInput) - Static method in class org.infinispan.commons.marshall.MarshallUtil
-
Same as
MarshallUtil.unmarshallArray(ObjectInput, ArrayBuilder)
but specialized for byte array. - unmarshallCollection(ObjectInput, MarshallUtil.CollectionBuilder<E, T>) - Static method in class org.infinispan.commons.marshall.MarshallUtil
-
Unmarshal a
Collection
. - unmarshallCollection(ObjectInput, MarshallUtil.CollectionBuilder<E, T>, MarshallUtil.ElementReader<E>) - Static method in class org.infinispan.commons.marshall.MarshallUtil
-
Unmarshal a
Collection
. - unmarshallCollectionUnbounded(ObjectInput, MarshallUtil.UnboundedCollectionBuilder<E, T>) - Static method in class org.infinispan.commons.marshall.MarshallUtil
- unmarshallEnum(ObjectInput, MarshallUtil.EnumBuilder<E>) - Static method in class org.infinispan.commons.marshall.MarshallUtil
- unmarshallIntCollection(ObjectInput, MarshallUtil.CollectionBuilder<Integer, T>) - Static method in class org.infinispan.commons.marshall.MarshallUtil
-
Unmarshalls a collection of integers.
- unmarshallMap(ObjectInput, MarshallUtil.ElementReader<K>, MarshallUtil.ElementReader<V>, MarshallUtil.MapBuilder<K, V, T>) - Static method in class org.infinispan.commons.marshall.MarshallUtil
-
Unmarshall the
Map
. - unmarshallMap(ObjectInput, MarshallUtil.MapBuilder<K, V, T>) - Static method in class org.infinispan.commons.marshall.MarshallUtil
-
Unmarshall the
Map
. - unmarshallSize(DataInput) - Static method in class org.infinispan.commons.marshall.MarshallUtil
-
Unmarshall an integer.
- unmarshallString(ObjectInput) - Static method in class org.infinispan.commons.marshall.MarshallUtil
-
Unmarshall a
String
. - unmarshallUUID(ObjectInput, boolean) - Static method in class org.infinispan.commons.marshall.MarshallUtil
-
Unmarshall
UUID
. - unnamedParametersNotAllowed(int, String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- unordered() - Method in interface org.infinispan.CacheStream
- unordered() - Method in interface org.infinispan.DoubleCacheStream
- unordered() - Method in interface org.infinispan.IntCacheStream
- unordered() - Method in interface org.infinispan.LongCacheStream
- unordered() - Method in class org.infinispan.stream.impl.AbstractCacheStream
- unordered() - Method in class org.infinispan.stream.impl.IntermediateCacheStream
- unordered() - Method in class org.infinispan.stream.impl.IntermediateDoubleCacheStream
- unordered() - Method in class org.infinispan.stream.impl.IntermediateIntCacheStream
- unordered() - Method in class org.infinispan.stream.impl.IntermediateLongCacheStream
- unordered() - Method in class org.infinispan.stream.impl.LockedStreamImpl
- unordered() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- unpack(InvocationContext, VisitableCommand, Object) - Static method in class org.infinispan.functional.impl.StatsEnvelope
- unpackCollection(InvocationContext, VisitableCommand, Object) - Static method in class org.infinispan.functional.impl.StatsEnvelope
- unpackStream(InvocationContext, VisitableCommand, Object) - Static method in class org.infinispan.functional.impl.StatsEnvelope
- UnpooledOffHeapMemoryAllocator - Class in org.infinispan.container.offheap
-
Memory allocator that just allocates memory directly using
Unsafe
. - UnpooledOffHeapMemoryAllocator() - Constructor for class org.infinispan.container.offheap.UnpooledOffHeapMemoryAllocator
- unproxy(Object) - Method in class org.infinispan.search.mapper.model.impl.InfinispanRuntimeIntrospector
- unquote(String) - Static method in class org.infinispan.commons.util.Util
- unregister() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
-
Stops handling the invocation.
- unregisterFilter(FilterSubscription) - Method in interface org.infinispan.objectfilter.Matcher
- unregisterInternalCache(String) - Method in class org.infinispan.registry.impl.InternalCacheRegistryImpl
- unregisterL1WriteSynchronizer(Object, L1WriteSynchronizer) - Method in class org.infinispan.distribution.impl.L1ManagerImpl
- unregisterL1WriteSynchronizer(Object, L1WriteSynchronizer) - Method in interface org.infinispan.distribution.L1Manager
-
Unregister the given write synchronizer if present.
- unregisterListener() - Method in class org.infinispan.spring.common.session.AbstractApplicationPublisherBridge
- unregisterListener() - Method in class org.infinispan.spring.embedded.session.EmbeddedApplicationPublishedBridge
- unregisterListener() - Method in class org.infinispan.spring.remote.session.RemoteApplicationPublishedBridge
- unregisterMarshaller(BaseMarshaller<?>) - Method in interface org.infinispan.query.remote.ProtobufMetadataManager
- unregisterMBean(ObjectName) - Method in class org.infinispan.jmx.CacheJmxRegistration
-
Unregisters the MBean located under the given
ObjectName
, if it exists. - unregisterMetrics() - Method in class org.infinispan.server.core.AbstractProtocolServer
- unregisterNamedComponentRegistry(String) - Method in class org.infinispan.factories.GlobalComponentRegistry
- unregisterProtofile(String) - Method in interface org.infinispan.query.remote.client.ProtobufMetadataManagerMBean
-
Unregister a *.proto schema file.
- unregisterProtofiles(String[]) - Method in interface org.infinispan.query.remote.client.ProtobufMetadataManagerMBean
-
Unregisters multiple *.proto schema files.
- unregisterSegment(int) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
- unregisterSegment(int) - Method in interface org.infinispan.scattered.ScatteredVersionManager
-
Move the segment to
ScatteredVersionManager.SegmentState.NOT_OWNED
state. - unregisterServerMBeans() - Method in class org.infinispan.server.core.AbstractProtocolServer
- UNRELIABLE_RETURN_VALUES - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- UNRELIABLE_RETURN_VALUES - Static variable in class org.infinispan.configuration.cache.UnsafeConfiguration
- unreliableReturnValues() - Method in class org.infinispan.configuration.cache.UnsafeConfiguration
-
Specifies whether Infinispan is allowed to disregard the
Map
contract when providing return values forBasicCache.put(Object, Object)
andBasicCache.remove(Object)
methods. - unreliableReturnValues(boolean) - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
-
Specify whether Infinispan is allowed to disregard the
Map
contract when providing return values forBasicCache.put(Object, Object)
andBasicCache.remove(Object)
methods. - unsafe() - Method in class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
- unsafe() - Method in class org.infinispan.configuration.cache.Configuration
- unsafe() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- unsafe() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- UNSAFE - Enum constant in enum org.infinispan.configuration.parsing.Element
- UnsafeConfiguration - Class in org.infinispan.configuration.cache
-
Controls certain tuning parameters that may break some of Infinispan's public API contracts in exchange for better performance in some cases.
- UnsafeConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Controls certain tuning parameters that may break some of Infinispan's public API contracts in exchange for better performance in some cases.
- UnsafeConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
- unsetEnum(long, Enum<?>) - Static method in class org.infinispan.commons.util.EnumUtil
- unsignedLongResponse(HotRodHeader, HotRodServer, Channel, long) - Method in class org.infinispan.server.hotrod.Encoder4x
- unsignedLongResponse(HotRodHeader, HotRodServer, Channel, long) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- UnsignedNumeric - Class in org.infinispan.commons.io
-
Helper to read and write unsigned numerics
- UnsignedNumeric() - Constructor for class org.infinispan.commons.io.UnsignedNumeric
- unstartedRemoteCacheManager() - Method in interface org.infinispan.client.hotrod.logging.Log
- UNSUCCESSFUL_RESPONSE - Static variable in interface org.infinispan.commons.marshall.Ids
- UnsuccessfulResponse - Class in org.infinispan.remoting.responses
-
An unsuccessful response
- UnsuccessfulResponse.Externalizer - Class in org.infinispan.remoting.responses
- unsupportedConfigurationOption() - Method in interface org.infinispan.rest.logging.Log
- unsupportedDataFormat(String) - Method in interface org.infinispan.rest.logging.Log
- unsupportedDataFormat(MediaType) - Method in interface org.infinispan.server.core.logging.Log
- UnsupportedKeyTypeException - Exception in org.infinispan.persistence.keymappers
-
Exception thrown by certain cache stores when one tries to persist an entry with an unsupported key type.
- UnsupportedKeyTypeException(Object) - Constructor for exception org.infinispan.persistence.keymappers.UnsupportedKeyTypeException
- UnsupportedKeyTypeException(String) - Constructor for exception org.infinispan.persistence.keymappers.UnsupportedKeyTypeException
- UnsupportedKeyTypeException(String, Throwable) - Constructor for exception org.infinispan.persistence.keymappers.UnsupportedKeyTypeException
- UnsupportedKeyTypeException(Throwable) - Constructor for exception org.infinispan.persistence.keymappers.UnsupportedKeyTypeException
- unsupportedMech(String, List<String>) - Method in interface org.infinispan.client.hotrod.logging.Log
- UnsupportedMergePolicy() - Constructor for class org.infinispan.conflict.MergePolicy.UnsupportedMergePolicy
- UNSURE_RESPONSE - Static variable in interface org.infinispan.commons.marshall.Ids
- UnsureResponse - Class in org.infinispan.remoting.responses
-
An unsure response - used with Dist - essentially asks the caller to check the next response from the next node since the sender is in a state of flux (probably in the middle of rebalancing)
- UnsureResponse() - Constructor for class org.infinispan.remoting.responses.UnsureResponse
- UnsureResponse.Externalizer - Class in org.infinispan.remoting.responses
- until() - Element in annotation type org.infinispan.configuration.parsing.Namespace
-
The last version of the schema where this is supported.
- unwrap() - Method in class org.infinispan.distribution.group.impl.GroupingPartitioner
- unwrap() - Method in class org.infinispan.stream.impl.AbstractCacheStream
- unwrap() - Method in class org.infinispan.stream.impl.DistributedCacheStream
- unwrap() - Method in class org.infinispan.stream.impl.DistributedDoubleCacheStream
- unwrap() - Method in class org.infinispan.stream.impl.DistributedIntCacheStream
- unwrap() - Method in class org.infinispan.stream.impl.DistributedLongCacheStream
- unwrap(byte[], int, int) - Method in class org.infinispan.server.core.security.SubjectSaslServer
- unwrap(Object) - Method in class org.infinispan.commons.dataconversion.ByteArrayWrapper
- unwrap(Object) - Method in class org.infinispan.commons.dataconversion.IdentityWrapper
- unwrap(Object) - Method in interface org.infinispan.commons.dataconversion.Wrapper
- unwrap(Object, Class<T>) - Static method in class org.infinispan.commons.util.ReflectionUtil
- unwrapAny(Class<T>, Object...) - Static method in class org.infinispan.commons.util.ReflectionUtil
- unwrapCache(Cache<K, V>) - Static method in class org.infinispan.cache.impl.AbstractDelegatingCache
-
Fully unwraps a given cache returning the base cache.
- unwrapExceptionMessage(Throwable) - Static method in class org.infinispan.commons.util.Util
- unwrapSuppressed(Throwable, Throwable) - Static method in class org.infinispan.commons.util.Util
- up() - Method in class org.infinispan.commons.dataconversion.internal.Json
- Updatable<T> - Interface in org.infinispan.commons.configuration.attributes
-
An interface for defining updatable attributes/attributeset.
- update(boolean) - Method in class org.infinispan.server.hotrod.HotRodServer.ExtendedCacheInfo
- update(long, TimeUnit) - Method in interface org.infinispan.commons.stat.TimerTracker
-
Adds a record.
- update(String, Attribute<T>) - Method in class org.infinispan.commons.configuration.attributes.Attribute
-
Updates this attribute with the value of the other attribute only if the attribute is mutable and the other has been modified from its default value
- update(String, AttributeSet) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
- update(String, T) - Method in class org.infinispan.commons.configuration.attributes.ConfigurationElement
- update(String, T) - Method in interface org.infinispan.commons.configuration.attributes.Updatable
-
Updates the mutable part of this instance with the values of the other instance
- update(Duration) - Method in interface org.infinispan.commons.stat.TimerTracker
-
Adds a record.
- update(InternalCacheEntry<K, V>, Metadata) - Method in interface org.infinispan.container.impl.InternalEntryFactory
-
TODO: Adjust javadoc Updates an existing
InternalCacheEntry
with new metadata. - update(InternalCacheEntry<K, V>, V, Metadata) - Method in interface org.infinispan.container.impl.InternalEntryFactory
-
Similar to
InternalEntryFactory.update(org.infinispan.container.entries.InternalCacheEntry, org.infinispan.metadata.Metadata)
but it also updates theInternalCacheEntry
value. - update(InternalCacheEntry, Object, Metadata) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
- update(InternalCacheEntry, Metadata) - Method in class org.infinispan.container.impl.InternalEntryFactoryImpl
- update(CacheXid, TxFunction, long) - Method in class org.infinispan.server.hotrod.tx.table.GlobalTxTable
- update(T) - Method in class org.infinispan.util.concurrent.ConditionFuture
-
Update the value and complete any outstanding condition stages for which the value satisfies the predicate.
- UPDATE - Enum constant in enum org.infinispan.commons.api.CacheContainerAdmin.AdminFlag
-
If a configuration already exists, and is compatible with the supplied configuration, update it.
- UPDATE - Enum constant in enum org.infinispan.notifications.cachemanagerlistener.event.ConfigurationChangedEvent.EventType
- UPDATE - Static variable in class org.infinispan.functional.impl.StatsEnvelope
- UPDATE_BLOOM_FILTER - Enum constant in enum org.infinispan.server.hotrod.HotRodOperation
- UPDATE_BLOOM_FILTER_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- UPDATE_INDEX - Static variable in interface org.infinispan.query.impl.ModuleCommandIds
- UPDATE_INDEX_STREAM - Static variable in interface org.infinispan.query.impl.ModuleCommandIds
- updateAndUnlock(TemporaryTable.LockedEntry, int, int) - Method in class org.infinispan.persistence.sifs.TemporaryTable
- updateAsync(T, Executor) - Method in class org.infinispan.util.concurrent.ConditionFuture
-
Update the value and complete any outstanding condition stages for which the value satisfies the predicate.
- updateAvailabilityMode(List<Address>, AvailabilityMode, boolean) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
-
Enter a new availability mode.
- updateAvailabilityMode(List<Address>, AvailabilityMode, boolean) - Method in class org.infinispan.topology.ClusterCacheStatus
- updateBloomFilter() - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- updateBloomFilter() - Method in interface org.infinispan.client.hotrod.impl.InternalRemoteCache
-
Sends the current bloom filter to the listener node where a near cache listener is installed.
- updateBloomFilter() - Method in class org.infinispan.client.hotrod.impl.InvalidatedNearRemoteCache
- updateBloomFilter() - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- updateCacheInfo(WrappedBytes, CacheInfo, CacheInfo) - Method in class org.infinispan.client.hotrod.impl.TopologyInfo
- updateCacheInfo(HotRodServer.ExtendedCacheInfo) - Method in class org.infinispan.server.hotrod.HotRodServer
- updateConfiguration(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.ImmutableLocalConfigurationStorage
- updateConfiguration(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.OverlayLocalConfigurationStorage
- updateConfiguration(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
- updateConfiguration(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.LocalConfigurationStorage
-
Updates an existing configuration.
- updateConfigurationAttribute(String, String, String) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
- updateConfigurationAttribute(String, String, String) - Method in interface org.infinispan.client.hotrod.RemoteCacheManagerAdmin
-
Updates a mutable configuration attribute for the given cache.
- updateConsistentHash(CacheTopology) - Method in interface org.infinispan.topology.CacheTopologyHandler
-
Invoked when the CH has to be immediately updated because of a leave or when the state transfer has completed and we have to install a permanent CH (pendingCH == null).
- updateCreationTimestamp() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
- updateCreationTimestamp() - Method in interface org.infinispan.metadata.Metadata
-
Returns if the creation timestamp is updated when an entry is modified.
- updateCreationTimestamp(boolean) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata.Builder
- updateCreationTimestamp(boolean) - Method in interface org.infinispan.metadata.Metadata.Builder
-
Sets how the creation timestamp is updated.
- updateCurrentTopology(List<Address>) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
-
Use the configured
ConsistentHashFactory
to create a new CH with the givenmembers
, but do not start a rebalance. - updateCurrentTopology(List<Address>) - Method in class org.infinispan.topology.ClusterCacheStatus
- updateIndexSchema(String) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
- updateIndexSchema(String) - Method in interface org.infinispan.client.hotrod.RemoteCacheManagerAdmin
-
Updates the index schema state for the given cache, the cache engine is hot restarted so that index persisted or not persisted state will be preserved.
- updateJsonWithParameter(ResultSet, AbstractSchemaJdbcStore.Parameter, int, Json, boolean) - Method in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.SchemaTableOperations
- updateMaxIdle(long, long) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
-
Update max idle time for an entry.
- updateMaxIdle(long, long) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
- updateMembers(CH, List<Address>, Map<Address, Float>) - Method in interface org.infinispan.distribution.ch.ConsistentHashFactory
-
Deprecated.Updates an existing consistent hash instance to remove owners that are not in the
newMembers
list. - updateMembers(Collection<Address>) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferCollector
- updateMembers(DefaultConsistentHash, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory
-
Leavers are removed and segments without owners are assigned new owners.
- updateMembers(DefaultConsistentHash, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory
- updateMembers(ReplicatedConsistentHash, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory
- updateMembers(ReplicatedConsistentHash, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory
- updateMembers(ScatteredConsistentHash, List<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory
-
Leavers are removed and segments without owners are assigned new owners.
- updateMetadata(CacheEntry, Metadata) - Static method in class org.infinispan.metadata.Metadatas
-
Set the
providedMetadata
on the cache entry. - updatePreloadedEntryVersion(EntryVersion) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
- updatePreloadedEntryVersion(EntryVersion) - Method in interface org.infinispan.scattered.ScatteredVersionManager
-
This is called only during preload.
- updatePreviousValue() - Method in interface org.infinispan.container.entries.MVCCEntry
-
Update the previous value of the entry - set it to current value.
- updatePreviousValue() - Method in class org.infinispan.container.entries.ReadCommittedEntry
- updateRank(ViewChangedEvent) - Method in class org.infinispan.container.versioning.RankCalculator
- updateTopologiesAfterMerge(CacheTopology, CacheTopology, AvailabilityMode) - Method in interface org.infinispan.partitionhandling.impl.AvailabilityStrategyContext
-
Updates both the stable and the current topologies.
- updateTopologiesAfterMerge(CacheTopology, CacheTopology, AvailabilityMode) - Method in class org.infinispan.topology.ClusterCacheStatus
- updateTotalBytesRead(int) - Method in class org.infinispan.server.core.transport.NettyTransport
- updateTotalBytesWritten(int) - Method in class org.infinispan.server.core.transport.NettyTransport
- updateVersion(int, IracEntryVersion) - Method in class org.infinispan.container.versioning.irac.DefaultIracVersionGenerator
- updateVersion(int, IracEntryVersion) - Method in interface org.infinispan.container.versioning.irac.IracVersionGenerator
-
Updates the version for the
segment
with a newremoteVersion
seen. - updateVersion(int, IracEntryVersion) - Method in class org.infinispan.container.versioning.irac.NoOpIracVersionGenerator
- UPPER_BOUND - Enum constant in enum org.infinispan.counter.configuration.Attribute
- UPPER_BOUND - Enum constant in enum org.infinispan.counter.configuration.Element
- UPPER_BOUND - Static variable in exception org.infinispan.counter.exception.CounterOutOfBoundsException
- UPPER_BOUND_REACHED - Enum constant in enum org.infinispan.counter.api.CounterState
-
The counter value has reached its max threshold.
- upperBound() - Method in class org.infinispan.counter.api.CounterConfiguration
- upperBound() - Method in class org.infinispan.counter.configuration.StrongCounterConfiguration
- upperBound(long) - Method in class org.infinispan.counter.api.CounterConfiguration.Builder
-
Sets the upper bound (inclusive) of the counter.
- upperBound(long) - Method in class org.infinispan.counter.configuration.StrongCounterConfigurationBuilder
-
Sets the upper bound (inclusive) of the counter if a bounded counter is desired.
- upsert() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfiguration
- upsert(String) - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfigurationBuilder
-
Configures the upsert statement to be used when writing entries to the database.
- UPSERT - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
- UPSERT - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Element
- UPSERT - Static variable in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfiguration
- upsertEntry(Connection, int, MarshallableEntry<? extends K, ? extends V>) - Method in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
- upsertEntry(Connection, int, MarshallableEntry<? extends K, ? extends V>) - Method in interface org.infinispan.persistence.jdbc.common.TableOperations
- uri() - Element in annotation type org.infinispan.configuration.parsing.Namespace
-
The URI of the namespace.
- uri() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
- uri() - Method in interface org.infinispan.rest.framework.RestRequest
- uri() - Method in class org.infinispan.rest.NettyRestRequest
- uri(String) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
- uri(String) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- uri(String) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
-
Configures this builder using the specified URI.
- uri(String) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- uri(URI) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
- uri(URI) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- uri(URI) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
-
Configures this builder using the specified URI.
- URI - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- URI - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- URLArtifact - Class in org.infinispan.commons.maven
-
Represents a generic URL artifact.
- URLArtifact(String) - Constructor for class org.infinispan.commons.maven.URLArtifact
- URLConfigurationResourceResolver - Class in org.infinispan.commons.configuration.io
- URLConfigurationResourceResolver(URL) - Constructor for class org.infinispan.commons.configuration.io.URLConfigurationResourceResolver
- urlDecode(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.
- urlEncode(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.
- USE_1_PC_FOR_AUTO_COMMIT_TRANSACTIONS - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
- USE_AUTH - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- USE_LOCK_STRIPING - Static variable in class org.infinispan.configuration.cache.LockingConfiguration
- USE_NATIVE_EPOLL - Static variable in class org.infinispan.server.core.transport.NativeTransport
- USE_NATIVE_IOURING - Static variable in class org.infinispan.server.core.transport.NativeTransport
- USE_SSL - Static variable in class org.infinispan.client.hotrod.impl.ConfigurationProperties
- USE_SYNCHRONIZATION - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
- USE_TWO_PHASE_COMMIT - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- USE_TWO_PHASE_COMMIT - Static variable in class org.infinispan.configuration.cache.BackupConfiguration
- use1PcForAutoCommitTransactions() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
-
Before Infinispan 5.1 you could access the cache both transactionally and non-transactionally.
- use1PcForAutoCommitTransactions() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
- use1PcForAutoCommitTransactions(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
-
Before Infinispan 5.1 you could access the cache both transactionally and non-transactionally.
- useCount - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
- useCurrentTopologyAsStable(String, boolean) - Method in interface org.infinispan.topology.ClusterTopologyManager
- useCurrentTopologyAsStable(String, boolean) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- useLockStriping() - Method in class org.infinispan.configuration.cache.LockingConfiguration
-
If true, a pool of shared locks is maintained for all entries that need to be locked.
- useLockStriping(boolean) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
-
If true, a pool of shared locks is maintained for all entries that need to be locked.
- useNativeIfAvailable(boolean) - Method in class org.infinispan.commons.util.SslContextFactory
- usePC - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- USER_AGENT - Enum constant in enum org.infinispan.rest.RequestHeader
- USER_EXT_ID_MIN - Static variable in interface org.infinispan.commons.marshall.AdvancedExternalizer
-
Deprecated.The minimum ID which will be respected by Infinispan for user specified
AdvancedExternalizer
implementations. - USER_EXT_ID_MIN - Static variable in class org.infinispan.jboss.marshalling.core.JBossUserMarshaller
- USER_MARSHALLER - Static variable in class org.infinispan.factories.KnownComponentNames
- useRawData() - Element in annotation type org.infinispan.client.hotrod.annotation.ClientListener
-
This option affects the type of the parameters received by a configured filter and/or converter.
- UserContextInitializer - Interface in org.infinispan.commons.marshall
-
Interface used to initialise a
SerializationContext
using the specified Pojos, Marshaller implementations and provided .proto schemas. - UserContextInitializerImpl - Class in org.infinispan.commons.marshall
-
WARNING: Generated code! Do not edit!
- UserContextInitializerImpl() - Constructor for class org.infinispan.commons.marshall.UserContextInitializerImpl
- useRequestFormat() - Method in interface org.infinispan.notifications.cachelistener.filter.CacheEventConverter
- userEventTriggered(ChannelHandlerContext, Object) - Method in class org.infinispan.server.core.transport.AccessControlFilter
- userEventTriggered(ChannelHandlerContext, Object) - Method in class org.infinispan.server.core.transport.IdleStateHandlerProvider
- username() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractUnmanagedConnectionFactoryConfiguration
- username() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
- username() - Method in class org.infinispan.persistence.remote.configuration.MechanismConfiguration
- username(String) - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
-
Specifies the username to be used for authentication.
- username(String) - Method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfigurationBuilder
- username(String) - Method in class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfigurationBuilder
- username(String) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
-
Specifies the username to be used for authentication.
- username(String) - Method in class org.infinispan.persistence.remote.configuration.MechanismConfigurationBuilder
- USERNAME - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
- USERNAME - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
- USERNAME - Static variable in class org.infinispan.persistence.jdbc.common.configuration.AbstractUnmanagedConnectionFactoryConfiguration
- UserPrincipal - Interface in org.infinispan.server.core.security
-
UserPrincipal.
- UserRaisedFunctionalException - Exception in org.infinispan.util
-
Thrown when client's code passed as a labda expression in commands such as
ComputeIfAbsentCommand
raises a exception. - UserRaisedFunctionalException(Throwable) - Constructor for exception org.infinispan.util.UserRaisedFunctionalException
- useStorageFormat() - Method in interface org.infinispan.notifications.cachelistener.CacheEntryListenerInvocation
- useStorageFormat() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
- useStorageFormat() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
- useStorageFormat(boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- useSynchronization() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
- useSynchronization(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
-
Configures whether the cache registers a synchronization with the transaction manager, or registers itself as an XA resource.
- useTwoPhaseCommit(boolean) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
-
Controls if replication happens in a two phase commit (2PC) for synchronous backups.
- useVirtualThread(boolean) - Method in class org.infinispan.factories.threads.DefaultThreadFactory
- useVirtualThreads() - Static method in class org.infinispan.commons.jdkspecific.ThreadCreator
- usingAsyncStore() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
- usingSegmentedStore() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
-
Returns if any store is
StoreConfiguration.segmented()
- usingStores() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
- usingTransport(String) - Method in interface org.infinispan.server.core.logging.Log
- UTF8 - Static variable in interface org.infinispan.commons.dataconversion.EncoderIds
-
Deprecated.
- UTF8 - Static variable in class org.infinispan.rest.operations.mediatypes.Charset
-
Default
Charset
- UTF8. - UTF8Encoder - Class 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.
- UTF8Encoder() - Constructor for class org.infinispan.commons.dataconversion.UTF8Encoder
-
Deprecated.
- UTF8StringMarshaller - Class in org.infinispan.commons.marshall
- UTF8StringMarshaller() - Constructor for class org.infinispan.commons.marshall.UTF8StringMarshaller
- Util - Class in org.infinispan.client.hotrod.impl
- Util - Class in org.infinispan.commons.tx
-
Transaction related util class.
- Util - Class in org.infinispan.commons.util
-
General utility methods used throughout the Infinispan code base.
- Util - Class in org.infinispan.counter.impl
-
Utility methods.
- Util - Class in org.infinispan.server.hotrod.tx.operation
-
Util operations to handle client transactions in Hot Rod server.
- Util() - Constructor for class org.infinispan.server.hotrod.tx.operation.Util
- Util.ByteGetter - Interface in org.infinispan.commons.util
-
Returns the byte at
index
. - Utils - Class in org.infinispan.counter.impl
-
Utility methods.
- UUID - Static variable in interface org.infinispan.commons.marshall.Ids
- UUID - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- UuidExternalizer - Class in org.infinispan.marshall.exts
- UuidExternalizer() - Constructor for class org.infinispan.marshall.exts.UuidExternalizer
V
- VALID - Enum constant in enum org.infinispan.counter.api.CounterState
-
The counter value is valid.
- validate() - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
- validate() - Method in class org.infinispan.client.hotrod.configuration.ClusterConfigurationBuilder
- validate() - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- validate() - Method in class org.infinispan.client.hotrod.configuration.NearCacheConfigurationBuilder
- validate() - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfigurationBuilder
- validate() - Method in class org.infinispan.client.hotrod.configuration.SecurityConfigurationBuilder
- validate() - Method in class org.infinispan.client.hotrod.configuration.ServerConfigurationBuilder
- validate() - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
- validate() - Method in class org.infinispan.client.hotrod.configuration.TransactionConfigurationBuilder
-
Deprecated.
- validate() - Method in class org.infinispan.commons.configuration.attributes.Attribute
- validate() - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Validates the
Attribute
values. - validate() - Method in interface org.infinispan.commons.configuration.Builder
-
Validate the data in this builder before building the configuration bean
- validate() - Method in class org.infinispan.commons.executors.BlockingThreadPoolExecutorFactory
-
Deprecated.
- validate() - Method in enum org.infinispan.commons.executors.CachedThreadPoolExecutorFactory
- validate() - Method in enum org.infinispan.commons.executors.ScheduledThreadPoolExecutorFactory
- validate() - Method in interface org.infinispan.commons.executors.ThreadPoolExecutorFactory
-
Validate parameters for the thread pool executor factory
- validate() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.BackupForBuilder
- validate() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
-
Deprecated.
- validate() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
-
Deprecated.
- validate() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.StatisticsConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.global.AllowListConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.global.CacheContainerConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.global.GlobalStorageConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.global.JGroupsConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.global.PrincipalRoleMapperConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.global.RolePermissionMapperConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
-
Deprecated.
- validate() - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.global.WhiteListConfigurationBuilder
-
Deprecated.
- validate() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
- validate() - Method in class org.infinispan.counter.configuration.WeakCounterConfigurationBuilder
- validate() - Method in class org.infinispan.counter.configuration.CounterManagerConfigurationBuilder
- validate() - Method in class org.infinispan.counter.configuration.StrongCounterConfigurationBuilder
- validate() - Method in class org.infinispan.factories.threads.EnhancedQueueExecutorFactory
- validate() - Method in class org.infinispan.factories.threads.NonBlockingThreadPoolExecutorFactory
- validate() - Method in class org.infinispan.lock.configuration.ClusteredLockConfigurationBuilder
- validate() - Method in class org.infinispan.lock.configuration.ClusteredLockManagerConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.jdbc.common.configuration.ManagedConnectionFactoryConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.jdbc.configuration.DataColumnConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.jdbc.configuration.IdColumnConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.jdbc.configuration.SegmentColumnConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.jdbc.configuration.TimestampColumnConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.sifs.configuration.IndexConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcStoreConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.sql.configuration.SchemaJdbcConfigurationBuilder
- validate() - Method in class org.infinispan.rest.configuration.AuthenticationConfigurationBuilder
- validate() - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- validate() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- validate() - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
- validate() - Method in class org.infinispan.server.core.configuration.SslEngineConfigurationBuilder
- validate() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
- validate() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
- validate() - Method in class org.infinispan.server.hotrod.configuration.SaslConfigurationBuilder
- validate(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
- validate(boolean) - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
- validate(boolean) - Method in class org.infinispan.persistence.sql.configuration.QueriesJdbcConfigurationBuilder
- validate(Json) - Method in interface org.infinispan.commons.dataconversion.internal.Json.Schema
-
Validate a JSON document according to this schema.
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.BackupForBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- validate(GlobalConfiguration) - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
-
Deprecated.
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
-
Deprecated.
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.SecurityConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.StatisticsConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.parsing.SFSToSIFSConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.persistence.jdbc.common.configuration.ManagedConnectionFactoryConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.persistence.jdbc.common.configuration.PooledConnectionFactoryConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.persistence.jdbc.common.configuration.SimpleConnectionFactoryConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.persistence.rocksdb.configuration.RocksDBStoreConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.persistence.sifs.configuration.SoftIndexFileStoreConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.persistence.sql.configuration.TableJdbcStoreConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.security.impl.CreatePermissionConfigurationBuilder
- validate(T) - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
- validate(T) - Method in interface org.infinispan.commons.configuration.attributes.AttributeValidator
- validateAndAddFilterListenerInvocations(Object, AbstractListenerImpl.AbstractInvocationBuilder, Set<Class<? extends Annotation>>) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
- validateAndAddListenerInvocations(Object, AbstractListenerImpl.AbstractInvocationBuilder) - Method in class org.infinispan.notifications.impl.AbstractListenerImpl
-
Loops through all valid methods on the object passed in, and caches the relevant methods as
ListenerInvocation
for invocation by reflection. - validateConfigurationUpdate(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.ImmutableLocalConfigurationStorage
- validateConfigurationUpdate(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
- validateConfigurationUpdate(String, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.LocalConfigurationStorage
-
Validates an update to an existing configuration.
- validateFlags(EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.ImmutableLocalConfigurationStorage
- validateFlags(EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.OverlayLocalConfigurationStorage
- validateFlags(EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
- validateFlags(EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.LocalConfigurationStorage
-
Checks whether this
LocalConfigurationStorage
supports the supplied flags. - validateGlobalStateStoreLocation(GlobalConfiguration, String, Attribute<?>...) - Static method in class org.infinispan.persistence.PersistenceUtil
- validateStrongCounterBounds(long, long, long) - Static method in class org.infinispan.counter.impl.Utils
-
Validates the lower and upper bound for a strong counter.
- validateUpdate(String, Attribute<T>) - Method in class org.infinispan.commons.configuration.attributes.Attribute
- validateUpdate(String, AttributeSet) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
- validateUpdate(String, T) - Method in class org.infinispan.commons.configuration.attributes.ConfigurationElement
- validateUpdate(String, T) - Method in interface org.infinispan.commons.configuration.attributes.Updatable
-
Verifies that updating the mutable part of this instance with the values of the other instance is possible
- validator(AttributeValidator<? super T>) - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition.Builder
- validOnly() - Static method in class org.infinispan.remoting.transport.impl.MapResponseCollector
- validOnly() - Static method in class org.infinispan.remoting.transport.impl.SingleResponseCollector
- validOnly() - Static method in class org.infinispan.remoting.transport.impl.SingletonMapResponseCollector
- validOnly() - Static method in class org.infinispan.remoting.transport.impl.VoidResponseCollector
- validOnly(int) - Static method in class org.infinispan.remoting.transport.impl.MapResponseCollector
- ValidResponse - Class in org.infinispan.remoting.responses
-
A valid response
- ValidResponse() - Constructor for class org.infinispan.remoting.responses.ValidResponse
- ValidResponseCollector<T> - Class in org.infinispan.remoting.transport
-
Base class for response collectors, splitting responses into valid responses, exception responses, and target missing.
- ValidResponseCollector() - Constructor for class org.infinispan.remoting.transport.ValidResponseCollector
- ValidSingleResponseCollector<T> - Class in org.infinispan.remoting.transport
- ValidSingleResponseCollector() - Constructor for class org.infinispan.remoting.transport.ValidSingleResponseCollector
- value - Variable in class org.infinispan.container.entries.AbstractInternalCacheEntry
- value - Variable in class org.infinispan.container.entries.ImmortalCacheValue
- value - Variable in class org.infinispan.container.entries.ReadCommittedEntry
- value - Variable in class org.infinispan.functional.MetaParam.MetaBoolean
- value - Variable in class org.infinispan.functional.MetaParam.MetaLong
- value - Variable in class org.infinispan.query.remote.json.Hit
- value - Variable in enum org.infinispan.server.hotrod.tx.table.Status
- value() - Element in annotation type org.infinispan.commons.configuration.BuiltBy
- value() - Element in annotation type org.infinispan.commons.configuration.ConfigurationFor
- value() - Element in annotation type org.infinispan.commons.configuration.ConfiguredBy
- value() - Element in annotation type org.infinispan.commons.marshall.SerializeFunctionWith
-
Specify the externalizer class to be used by the annotated class.
- value() - Element in annotation type org.infinispan.commons.marshall.SerializeWith
-
Deprecated.Specify the externalizer class to be used by the annotated class.
- value() - Element in annotation type org.infinispan.commons.util.Experimental
- value() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
- value() - Element in annotation type org.infinispan.configuration.parsing.Namespaces
- value() - Element in annotation type org.infinispan.configuration.serializing.SerializedWith
- value() - Element in annotation type org.infinispan.external.JGroupsProtocolComponent
- value() - Element in annotation type org.infinispan.factories.annotations.ComponentName
- value() - Element in annotation type org.infinispan.factories.scopes.Scope
- value() - Method in class org.infinispan.functional.impl.StatsEnvelope
- value() - Method in interface org.infinispan.reactive.publisher.impl.SegmentPublisherSupplier.Notification
-
The value when present for this notification
- value() - Method in interface org.infinispan.search.mapper.mapping.EntityConverter.ConvertedEntity
- value() - Method in class org.infinispan.xsite.statetransfer.XSiteState
- value(R, int) - Method in interface org.infinispan.reactive.publisher.impl.Notifications.NotificationBuilder
- value(R, int) - Static method in class org.infinispan.reactive.publisher.impl.Notifications
- VALUE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- VALUE - Enum constant in enum org.infinispan.counter.configuration.Attribute
- VALUE - Enum constant in enum org.infinispan.server.hotrod.configuration.Attribute
- VALUE - Static variable in class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
- VALUE - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- VALUE_CONTENT_TYPE_HEADER - Enum constant in enum org.infinispan.rest.ResponseHeader
- VALUE_DATA_TYPE - Enum constant in enum org.infinispan.configuration.parsing.Element
- VALUE_EQUIVALENCE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- VALUE_SIZE - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- VALUE_SIZE_ESTIMATE - Enum constant in enum org.infinispan.persistence.remote.configuration.Attribute
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 12.0, will be removed in 15.0
- VALUE_SIZE_ESTIMATE - 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
- VALUE_TRANSFER - Enum constant in enum org.infinispan.scattered.ScatteredVersionManager.SegmentState
- valueAllowed(Object) - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
- valueAllowed(Object) - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareEntryCollection
- valueAllowed(Object) - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareEntryIterator
- valueAllowed(Object) - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator
- ValueAndMetadata() - Constructor for class org.infinispan.cache.impl.SimpleCacheImpl.ValueAndMetadata
- valueConversion - Variable in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.ProtoSchemaOptions
- valueDataConversion - Variable in class org.infinispan.functional.impl.ReadWriteMapImpl
- valueDataType() - Method in class org.infinispan.configuration.cache.EncodingConfiguration
- ValueFieldMetamodel - Class in org.infinispan.search.mapper.mapping.metamodel
- ValueFieldMetamodel(boolean, boolean, IndexValueFieldTypeDescriptor) - Constructor for class org.infinispan.search.mapper.mapping.metamodel.ValueFieldMetamodel
- valueFromStorage(Object) - Method in class org.infinispan.cache.impl.EncoderCache
- valueLength() - Method in class org.infinispan.persistence.sifs.EntryHeader
- valueMarshaller(Marshaller) - Method in class org.infinispan.client.hotrod.DataFormat.Builder
- valueMatcher() - Element in annotation type org.infinispan.commons.marshall.SerializeFunctionWith
-
Specify the value matching capabilities of this function.
- valueMatcher(Object) - Method in interface org.infinispan.commons.marshall.LambdaExternalizer
- valueMatcher(Object) - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.ConstantLambdaExternalizer
- valueMatcher(Object) - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.LambdaWithMetasExternalizer
- valueMatcher(Object) - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.SetValueIfEqualsReturnBooleanExternalizer
- ValueMatcherMode - Enum in org.infinispan.commons.marshall
-
Value matcher mode.
- valueMessageName - Variable in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.ProtoSchemaOptions
- valueMultipleColumnWithoutSchema() - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- valueNotInSchema(List<String>, String) - Method in interface org.infinispan.persistence.jdbc.common.logging.Log
- valueOf(byte) - Static method in enum org.infinispan.server.hotrod.tx.table.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum org.infinispan.commons.api.CacheContainerAdmin.AdminFlag
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum org.infinispan.commons.marshall.ValueMatcherMode
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum org.infinispan.configuration.cache.CacheMode
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum org.infinispan.configuration.cache.CacheType
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum org.infinispan.configuration.cache.XSiteStateTransferMode
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum org.infinispan.counter.api.CounterState
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum org.infinispan.counter.api.CounterType
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum org.infinispan.counter.api.Storage
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum org.infinispan.functional.Param.ExecutionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum org.infinispan.functional.Param.LockingMode
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum org.infinispan.functional.Param.PersistenceMode
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum org.infinispan.functional.Param.ReplicationMode
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum org.infinispan.functional.Param.StatisticsMode
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum org.infinispan.notifications.cachelistener.event.Event.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum org.infinispan.partitionhandling.AvailabilityMode
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum org.infinispan.reactive.publisher.impl.DeliveryGuarantee
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum org.infinispan.topology.CacheTopology.Phase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.client.hotrod.configuration.ClientIntelligence
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.client.hotrod.configuration.ExhaustedAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.client.hotrod.configuration.NearCacheMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.client.hotrod.configuration.SaslQop
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.client.hotrod.configuration.SaslStrength
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.client.hotrod.configuration.TransactionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.client.hotrod.DefaultTemplate
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.client.hotrod.event.ClientEvent.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.client.hotrod.Flag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.client.hotrod.impl.VersionedOperationResponse.RspCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.client.hotrod.ProtocolVersion
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.commands.VisitableCommand.LoadType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.commons.api.CacheContainerAdmin.AdminFlag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.commons.configuration.Combine.Attributes
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.commons.configuration.Combine.RepeatedAttributes
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.commons.configuration.io.ConfigurationFormatFeature
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.commons.configuration.io.ConfigurationReader.ElementType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.commons.configuration.io.NamingStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.commons.executors.CachedThreadPoolExecutorFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.commons.executors.ScheduledThreadPoolExecutorFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.commons.marshall.ValueMatcherMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.commons.tx.DefaultResourceConverter
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.commons.tx.lookup.LookupNames.TransactionManagerFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.commons.util.Either.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.commons.util.MemoryUnit
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.commons.util.OS
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.configuration.cache.BackupConfiguration.BackupStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.configuration.cache.BackupFailurePolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.configuration.cache.BiasAcquisition
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.configuration.cache.CacheMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.configuration.cache.CacheType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.configuration.cache.Index
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.configuration.cache.IndexStartupMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.configuration.cache.IndexStorage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.configuration.cache.InterceptorConfiguration.Position
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.configuration.cache.StorageType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.configuration.cache.TransactionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.configuration.cache.VersioningScheme
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.configuration.cache.XSiteStateTransferMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.configuration.global.ShutdownHookBehavior
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.configuration.parsing.Attribute
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.configuration.parsing.CacheParser.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.configuration.parsing.CacheParser.TransactionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.configuration.parsing.Element
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.configuration.parsing.ParsedCacheMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.configuration.parsing.ParserScope
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.conflict.MergePolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.container.entries.ReadCommittedEntry.Flags
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.container.versioning.InequalVersionComparisonResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.context.Flag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.counter.api.CounterState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.counter.api.CounterType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.counter.api.Storage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.counter.configuration.Attribute
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.counter.configuration.Element
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.counter.configuration.Reliability
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.distribution.DataLocality
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.distribution.Ownership
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.distribution.topologyaware.TopologyLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.eviction.EvictionStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.eviction.EvictionType
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.expiration.TouchMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.extendedstats.container.ExtendedStatistic
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.extendedstats.percentiles.PercentileStatistic
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.extendedstats.topK.StreamSummaryContainer.Stat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.factories.impl.Scopes
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.factories.scopes.Scopes
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.functional.Param.ExecutionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.functional.Param.LockingMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.functional.Param.PersistenceMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.functional.Param.ReplicationMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.functional.Param.StatisticsMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.globalstate.ConfigurationStorage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.health.HealthStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.lifecycle.ComponentStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.lock.api.OwnershipLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.lock.configuration.Attribute
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.lock.configuration.Element
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.lock.configuration.Reliability
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.manager.ClusterExecutionPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.notifications.cachelistener.event.Event.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.notifications.cachemanagerlistener.event.ConfigurationChangedEvent.EventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.notifications.cachemanagerlistener.event.Event.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.notifications.Listener.Observation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.partitionhandling.AvailabilityMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.partitionhandling.PartitionHandling
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.persistence.jdbc.common.configuration.Element
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.persistence.jdbc.common.DatabaseType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.persistence.modifications.Modification.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.persistence.remote.configuration.Attribute
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.persistence.remote.configuration.Element
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.persistence.remote.configuration.ExhaustedAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.persistence.rocksdb.configuration.Attribute
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.persistence.rocksdb.configuration.CompressionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.persistence.rocksdb.configuration.Element
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.persistence.spi.NonBlockingStore.Characteristic
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.persistence.sql.AbstractSchemaJdbcStore.ProtostreamFieldType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.query.dsl.SortOrder
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.reactive.publisher.impl.DeliveryGuarantee
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.remoting.inboundhandler.action.ActionStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.remoting.rpc.ResponseMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.remoting.transport.impl.EmptyRaftManager
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.StackCombine
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.remoting.transport.jgroups.RaftUtil
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.rest.configuration.ExtendedHeaders
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.rest.framework.LookupResult.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.rest.framework.Method
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.rest.RequestHeader
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.rest.ResponseHeader
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.rest.ResponseWriter
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.scattered.ScatteredVersionManager.SegmentState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.security.AuditContext
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.security.AuditResponse
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.security.AuthorizationPermission
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.server.core.admin.AdminOperation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.server.core.admin.AdminOperationParameter
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.server.core.BackupManager.Resources.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.server.core.BackupManager.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.server.hotrod.configuration.Attribute
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.server.hotrod.configuration.Element
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.server.hotrod.configuration.Policy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.server.hotrod.configuration.QOP
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.server.hotrod.configuration.Strength
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.server.hotrod.counter.listener.ListenerOperationStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.server.hotrod.HotRodDecoderState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.server.hotrod.HotRodOperation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.server.hotrod.HotRodVersion
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.server.hotrod.OperationStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.server.hotrod.ProtocolFlag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.server.hotrod.TimeUnitValue
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.server.hotrod.tx.ControlByte
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.server.hotrod.tx.table.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.server.memcached.MemcachedDecoderState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.server.memcached.MemcachedOperation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.stream.impl.IntermediateType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.tasks.TaskExecutionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.tasks.TaskInstantiationMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.topology.CacheTopology.Phase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.topology.ClusterTopologyManager.ClusterManagerStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.topology.RebalancingStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.transaction.impl.TransactionTable.CompletedTransactionStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.transaction.LockingMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.transaction.TransactionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.util.CacheTopologyUtil
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.util.concurrent.DataOperationOrderer.Operation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.util.concurrent.IsolationLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.util.concurrent.locks.LockState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.xsite.events.XSiteEventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.xsite.irac.NoOpIracManager
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.xsite.spi.XSiteMergePolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.xsite.statetransfer.StateTransferStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.xsite.status.BringSiteOnlineResponse
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.xsite.status.SiteState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.xsite.status.TakeSiteOfflineResponse
-
Returns the enum constant of this type with the specified name.
- valueOrException(Object, Throwable) - Static method in class org.infinispan.interceptors.BaseAsyncInterceptor
-
Return the value if
throwable != null
, throw the exception otherwise. - valueParameters - Variable in class org.infinispan.persistence.sql.AbstractSchemaJdbcStore.ProtoSchemaOptions
- valueResponse(HotRodHeader, HotRodServer, Channel, OperationStatus, byte[]) - Method in class org.infinispan.server.hotrod.Encoder4x
- valueResponse(HotRodHeader, HotRodServer, Channel, OperationStatus, byte[]) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- valueResponse(HotRodHeader, HotRodServer, Channel, OperationStatus, CacheEntry<byte[], byte[]>) - Method in class org.infinispan.server.hotrod.Encoder4x
- valueResponse(HotRodHeader, HotRodServer, Channel, OperationStatus, CacheEntry<byte[], byte[]>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- values - Variable in class org.infinispan.commons.util.AbstractMap
- values - Variable in class org.infinispan.commons.util.ArrayMap
- values() - Method in class org.infinispan.cache.impl.AbstractDelegatingCache
- values() - Method in class org.infinispan.cache.impl.CacheImpl
- values() - Method in class org.infinispan.cache.impl.DecoratedCache
- values() - Method in class org.infinispan.cache.impl.EncoderCache
- values() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- values() - Method in interface org.infinispan.Cache
-
Returns a collection view of the values contained in this cache across the entire cluster.
- values() - Static method in enum org.infinispan.client.hotrod.configuration.ClientIntelligence
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.client.hotrod.configuration.ExhaustedAction
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.client.hotrod.configuration.NearCacheMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.client.hotrod.configuration.SaslQop
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.client.hotrod.configuration.SaslStrength
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.client.hotrod.configuration.TransactionMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.client.hotrod.DefaultTemplate
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.client.hotrod.event.ClientEvent.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.client.hotrod.Flag
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.client.hotrod.impl.VersionedOperationResponse.RspCode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.client.hotrod.ProtocolVersion
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in interface org.infinispan.client.hotrod.RemoteCache
- values() - Static method in enum org.infinispan.commands.VisitableCommand.LoadType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.commons.api.CacheContainerAdmin.AdminFlag
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.commons.configuration.Combine.Attributes
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.commons.configuration.Combine.RepeatedAttributes
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.commons.configuration.io.ConfigurationFormatFeature
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.commons.configuration.io.ConfigurationReader.ElementType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.commons.configuration.io.NamingStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.commons.executors.CachedThreadPoolExecutorFactory
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.commons.executors.ScheduledThreadPoolExecutorFactory
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.commons.marshall.ValueMatcherMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.commons.tx.DefaultResourceConverter
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.commons.tx.lookup.LookupNames.TransactionManagerFactory
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.infinispan.commons.util.AbstractDelegatingMap
- values() - Method in class org.infinispan.commons.util.ArrayMap
- values() - Static method in enum org.infinispan.commons.util.Either.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.infinispan.commons.util.FastCopyHashMap
- values() - Static method in enum org.infinispan.commons.util.MemoryUnit
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.commons.util.OS
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.configuration.cache.BackupConfiguration.BackupStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.configuration.cache.BackupFailurePolicy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.configuration.cache.BiasAcquisition
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.configuration.cache.CacheMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.configuration.cache.CacheType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.configuration.cache.Index
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.configuration.cache.IndexStartupMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.configuration.cache.IndexStorage
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.configuration.cache.InterceptorConfiguration.Position
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.configuration.cache.StorageType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.configuration.cache.TransactionMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.configuration.cache.VersioningScheme
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.configuration.cache.XSiteStateTransferMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.configuration.global.ShutdownHookBehavior
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.configuration.parsing.Attribute
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.configuration.parsing.CacheParser.Mode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.configuration.parsing.CacheParser.TransactionMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.configuration.parsing.Element
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.configuration.parsing.ParsedCacheMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.configuration.parsing.ParserScope
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.conflict.MergePolicy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.container.entries.ReadCommittedEntry.Flags
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- values() - Static method in enum org.infinispan.container.versioning.InequalVersionComparisonResult
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.context.Flag
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.counter.api.CounterState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.counter.api.CounterType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.counter.api.Storage
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.counter.configuration.Attribute
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.counter.configuration.Element
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.counter.configuration.Reliability
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.distribution.DataLocality
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.distribution.Ownership
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.distribution.topologyaware.TopologyLevel
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
-
NOTE: this method is not supported.
- values() - Static method in enum org.infinispan.eviction.EvictionStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.eviction.EvictionType
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.expiration.TouchMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.extendedstats.container.ExtendedStatistic
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.extendedstats.percentiles.PercentileStatistic
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.extendedstats.topK.StreamSummaryContainer.Stat
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.factories.impl.Scopes
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.factories.scopes.Scopes
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.functional.Param.ExecutionMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.functional.Param.LockingMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.functional.Param.PersistenceMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.functional.Param.ReplicationMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.functional.Param.StatisticsMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.globalstate.ConfigurationStorage
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.health.HealthStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.lifecycle.ComponentStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.lock.api.OwnershipLevel
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.lock.configuration.Attribute
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.lock.configuration.Element
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.lock.configuration.Reliability
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.manager.ClusterExecutionPolicy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.notifications.cachelistener.event.Event.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.notifications.cachemanagerlistener.event.ConfigurationChangedEvent.EventType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.notifications.cachemanagerlistener.event.Event.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.notifications.Listener.Observation
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.partitionhandling.AvailabilityMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.partitionhandling.PartitionHandling
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.persistence.jdbc.common.configuration.Element
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.persistence.jdbc.common.DatabaseType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.persistence.modifications.Modification.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.persistence.remote.configuration.Attribute
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.persistence.remote.configuration.Element
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.persistence.remote.configuration.ExhaustedAction
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.persistence.rocksdb.configuration.Attribute
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.persistence.rocksdb.configuration.CompressionType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.persistence.rocksdb.configuration.Element
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.persistence.spi.NonBlockingStore.Characteristic
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.persistence.sql.AbstractSchemaJdbcStore.ProtostreamFieldType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.query.dsl.SortOrder
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.reactive.publisher.impl.DeliveryGuarantee
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.remoting.inboundhandler.action.ActionStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.remoting.rpc.ResponseMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.remoting.transport.impl.EmptyRaftManager
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.remoting.transport.jgroups.EmbeddedJGroupsChannelConfigurator.StackCombine
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.remoting.transport.jgroups.RaftUtil
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.rest.configuration.ExtendedHeaders
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.rest.framework.LookupResult.Status
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.rest.framework.Method
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.rest.RequestHeader
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.rest.ResponseHeader
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.rest.ResponseWriter
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.scattered.ScatteredVersionManager.SegmentState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.security.AuditContext
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.security.AuditResponse
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.security.AuthorizationPermission
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.infinispan.security.impl.SecureCacheImpl
- values() - Static method in enum org.infinispan.server.core.admin.AdminOperation
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.server.core.admin.AdminOperationParameter
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.server.core.BackupManager.Resources.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.server.core.BackupManager.Status
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.server.hotrod.configuration.Attribute
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.server.hotrod.configuration.Element
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.server.hotrod.configuration.Policy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.server.hotrod.configuration.QOP
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.server.hotrod.configuration.Strength
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.server.hotrod.counter.listener.ListenerOperationStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.server.hotrod.HotRodDecoderState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.server.hotrod.HotRodOperation
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.server.hotrod.HotRodVersion
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.server.hotrod.OperationStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.server.hotrod.ProtocolFlag
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.server.hotrod.TimeUnitValue
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.server.hotrod.tx.ControlByte
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.server.hotrod.tx.table.Status
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.server.memcached.MemcachedDecoderState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.server.memcached.MemcachedOperation
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.stream.impl.IntermediateType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.tasks.TaskExecutionMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.tasks.TaskInstantiationMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.topology.CacheTopology.Phase
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.topology.ClusterTopologyManager.ClusterManagerStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.topology.RebalancingStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.transaction.impl.TransactionTable.CompletedTransactionStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.transaction.LockingMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.transaction.TransactionMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.util.CacheTopologyUtil
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.util.concurrent.DataOperationOrderer.Operation
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.util.concurrent.IsolationLevel
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.util.concurrent.locks.LockState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.xsite.events.XSiteEventType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.xsite.irac.NoOpIracManager
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.xsite.spi.XSiteMergePolicy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.xsite.statetransfer.StateTransferStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.xsite.status.BringSiteOnlineResponse
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.xsite.status.SiteState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.xsite.status.TakeSiteOfflineResponse
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values(IntSet) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- values(IntSet) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- values(IntSet) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
This method is identical to
RemoteCache.values()
except that it will only return values that map to the given segments. - Values() - Constructor for class org.infinispan.cache.impl.SimpleCacheImpl.Values
- Values() - Constructor for class org.infinispan.commons.util.FastCopyHashMap.Values
- valueSegment() - Method in interface org.infinispan.reactive.publisher.impl.SegmentPublisherSupplier.Notification
-
The segment that maps for the value of this notification
- valuesFuture(int) - Method in class org.infinispan.scattered.impl.ScatteredVersionManagerImpl
- valuesFuture(int) - Method in interface org.infinispan.scattered.ScatteredVersionManager
- valueSizeEstimate() - Method in class org.infinispan.client.hotrod.configuration.Configuration
-
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
- valueSizeEstimate() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
-
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
- valueSizeEstimate(int) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
-
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
- valueSizeEstimate(int) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
-
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
- valueSizeEstimate(int) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
-
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
- valueSizeEstimate(int) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
-
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
- valueSizeEstimate(int) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
-
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
- valueSizeEstimate(int) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
-
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
- valueToBytes(Object) - Method in class org.infinispan.client.hotrod.DataFormat
- valueToBytes(Object) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- valueToBytes(Object) - Method in interface org.infinispan.client.hotrod.marshall.MediaTypeMarshaller
-
Transforms the value object to the marshalled form.
- valueToBytes(Object, int, int) - Method in class org.infinispan.client.hotrod.DataFormat
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 12.0, will be removed in 15.0
- valueToObj(byte[], ClassAllowList) - Method in class org.infinispan.client.hotrod.DataFormat
- valueToStorage(Object) - Method in class org.infinispan.cache.impl.EncoderCache
- valueType(MediaType) - Method in class org.infinispan.client.hotrod.DataFormat.Builder
- valueWithVersionResponse(HotRodHeader, HotRodServer, Channel, byte[], long) - Method in class org.infinispan.server.hotrod.Encoder4x
- valueWithVersionResponse(HotRodHeader, HotRodServer, Channel, byte[], long) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- variables() - Method in interface org.infinispan.rest.framework.RestRequest
- variables() - Method in class org.infinispan.rest.NettyRestRequest
- verbose - Variable in class org.infinispan.commons.maven.AbstractArtifact
- verbose(boolean) - Method in class org.infinispan.commons.maven.AbstractArtifact
- verbose(boolean) - Method in interface org.infinispan.commons.maven.Artifact
- VerbosityRequest - Enum constant in enum org.infinispan.server.memcached.MemcachedOperation
- version - Variable in class org.infinispan.metadata.EmbeddedMetadata.Builder
- version - Variable in class org.infinispan.metadata.EmbeddedMetadata
- version - Variable in class org.infinispan.scattered.impl.ScatteredStateConsumerImpl.KeyAndVersion
- version() - Method in class org.infinispan.client.hotrod.configuration.Configuration
- version() - Method in class org.infinispan.commons.util.Version
- version() - Method in class org.infinispan.container.entries.RemoteMetadata
- version() - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata
- version() - Method in class org.infinispan.metadata.EmbeddedMetadata
- version() - Method in class org.infinispan.metadata.impl.InternalMetadataImpl
-
Deprecated.
- version() - Method in class org.infinispan.metadata.impl.L1Metadata
- version() - Method in interface org.infinispan.metadata.Metadata
-
Returns the version of the cache entry with which this metadata object is associated.
- version(String) - Method in interface org.infinispan.client.hotrod.logging.Log
- version(ProtocolVersion) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
- version(ProtocolVersion) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- version(ProtocolVersion) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
-
This property defines the protocol version that this client should use.
- version(EntryVersion) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata.Builder
- version(EntryVersion) - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
- version(EntryVersion) - Method in interface org.infinispan.metadata.Metadata.Builder
-
Set version.
- Version - Class in org.infinispan.commons.util
-
Contains version information about this release of Infinispan.
- Version - Class in org.infinispan
-
Deprecated, for removal: This API element is subject to removal in a future version.Use
Version
instead - Version() - Constructor for class org.infinispan.Version
-
Deprecated.
- VERSION - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- VERSION - Static variable in class org.infinispan.commons.configuration.io.xml.MXParser
- VERSION - Static variable in class org.infinispan.globalstate.impl.GlobalStateManagerImpl
- VERSION_20 - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- VERSION_21 - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- VERSION_22 - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- VERSION_24 - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- VERSION_26 - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- VERSION_28 - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- VERSION_30 - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- VERSION_31 - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- VERSION_40 - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- VERSION_MAJOR - Static variable in class org.infinispan.globalstate.impl.GlobalStateManagerImpl
- VERSION_PROJECTION_KEY - Static variable in class org.infinispan.query.remote.json.JsonQueryResponse
- Versioned - Interface in org.infinispan.client.hotrod
-
Versioned
- Versioned - Interface in org.infinispan.container.entries.versioned
-
Deprecated, for removal: This API element is subject to removal in a future version.since 11.0 (no longer used).
- VERSIONED_RESULT - Static variable in interface org.infinispan.commons.marshall.Ids
- VERSIONED_RESULTS - Static variable in interface org.infinispan.commons.marshall.Ids
- VersionedEncoder - Interface in org.infinispan.server.hotrod
-
This class represents the work to be done by an encoder of a particular Hot Rod protocol version.
- VersionedMetadata - Interface in org.infinispan.client.hotrod
-
VersionedMetadata
- VersionedMetadataImpl - Class in org.infinispan.client.hotrod.impl
- VersionedMetadataImpl(long, int, long, int, long) - Constructor for class org.infinispan.client.hotrod.impl.VersionedMetadataImpl
- VersionedOperationResponse<V> - Class in org.infinispan.client.hotrod.impl
- VersionedOperationResponse(V, VersionedOperationResponse.RspCode) - Constructor for class org.infinispan.client.hotrod.impl.VersionedOperationResponse
- VersionedOperationResponse.RspCode - Enum in org.infinispan.client.hotrod.impl
- VersionedRepeatableReadEntry<K,
V> - Class in org.infinispan.container.entries -
A version of RepeatableReadEntry that can perform write-skew checks during prepare.
- VersionedRepeatableReadEntry(K, V, Metadata) - Constructor for class org.infinispan.container.entries.VersionedRepeatableReadEntry
- VersionedValue<V> - Interface in org.infinispan.client.hotrod
-
Besides the key and value, also contains an version.
- VersionedValueImpl<V> - Class in org.infinispan.client.hotrod.impl
- VersionedValueImpl(long, V) - Constructor for class org.infinispan.client.hotrod.impl.VersionedValueImpl
- versionFromEntry(CacheEntry<?, ?>) - Static method in class org.infinispan.transaction.impl.WriteSkewHelper
- VersionGenerator - Interface in org.infinispan.container.versioning
-
Generates versions
- VersionGeneratorFactory - Class in org.infinispan.factories
-
Version generator component factory.
- VersionGeneratorFactory() - Constructor for class org.infinispan.factories.VersionGeneratorFactory
- VERSIONING - Enum constant in enum org.infinispan.configuration.parsing.Element
- VERSIONING_SCHEME - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- VersioningScheme - Enum in org.infinispan.configuration.cache
-
The various versioning schemes supported
- VersionRequest - Enum constant in enum org.infinispan.server.memcached.MemcachedOperation
- VIEW_CHANGED - Enum constant in enum org.infinispan.notifications.cachemanagerlistener.event.Event.Type
- viewChange(ViewChangedEvent) - Method in class org.infinispan.notifications.cachelistener.cluster.RemoteClusterListener
- viewChange(ViewChangedEvent) - Method in class org.infinispan.reactive.publisher.impl.PublisherHandler
- ViewChanged - Annotation Type in org.infinispan.notifications.cachemanagerlistener.annotation
-
This annotation should be used on methods that need to be notified when the cache is used in a cluster and the cluster topology changes (i.e., a member joins or leaves the cluster).
- ViewChangedEvent - Interface in org.infinispan.notifications.cachemanagerlistener.event
-
This event is passed in to any method annotated with
ViewChanged
. - vInt(ByteBuf) - Static method in class org.infinispan.server.hotrod.Intrinsics
- VInt - Class in org.infinispan.server.core.transport
-
Reads and writes unsigned variable length integer values.
- VInt() - Constructor for class org.infinispan.server.core.transport.VInt
- VISITABLE_COMMAND - Static variable in class org.infinispan.xsite.commands.remote.Ids
- VisitableCommand - Interface in org.infinispan.commands
-
A type of command that can accept
Visitor
s, such asDDAsyncInterceptor
. - VisitableCommand.LoadType - Enum in org.infinispan.commands
- visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitClearCommand(InvocationContext, ClearCommand) - Method in interface org.infinispan.commands.Visitor
- visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
- visitCollection(InvocationContext, Collection<? extends VisitableCommand>) - Method in class org.infinispan.commands.AbstractVisitor
-
Helper method to visit a collection of VisitableCommands.
- visitCommand(InvocationContext, VisitableCommand) - Method in interface org.infinispan.interceptors.AsyncInterceptor
-
Perform some work for a command invocation.
- visitCommand(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitCommitCommand(TxInvocationContext, CommitCommand) - Method in interface org.infinispan.commands.Visitor
- visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
- visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
- visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitComputeCommand(InvocationContext, ComputeCommand) - Method in interface org.infinispan.commands.Visitor
- visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
- visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
- visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in interface org.infinispan.commands.Visitor
- visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
- visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
- visitEntrySetCommand(InvocationContext, EntrySetCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitEntrySetCommand(InvocationContext, EntrySetCommand) - Method in interface org.infinispan.commands.Visitor
- visitEntrySetCommand(InvocationContext, EntrySetCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitEntrySetCommand(InvocationContext, EntrySetCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
- visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitEvictCommand(InvocationContext, EvictCommand) - Method in interface org.infinispan.commands.Visitor
- visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitGetAllCommand(InvocationContext, GetAllCommand) - Method in interface org.infinispan.commands.Visitor
- visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
- visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
- visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
- visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in interface org.infinispan.commands.Visitor
- visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
- visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in interface org.infinispan.commands.Visitor
- visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
- visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
- visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
- visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in interface org.infinispan.commands.Visitor
- visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitInvalidateL1Command(InvocationContext, InvalidateL1Command) - Method in class org.infinispan.commands.AbstractVisitor
- visitInvalidateL1Command(InvocationContext, InvalidateL1Command) - Method in interface org.infinispan.commands.Visitor
- visitInvalidateL1Command(InvocationContext, InvalidateL1Command) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitIracPutKeyValueCommand(InvocationContext, IracPutKeyValueCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitIracPutKeyValueCommand(InvocationContext, IracPutKeyValueCommand) - Method in interface org.infinispan.commands.Visitor
- visitIracPutKeyValueCommand(InvocationContext, IracPutKeyValueCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitIracPutKeyValueCommand(InvocationContext, IracPutKeyValueCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
- visitKeySetCommand(InvocationContext, KeySetCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitKeySetCommand(InvocationContext, KeySetCommand) - Method in interface org.infinispan.commands.Visitor
- visitKeySetCommand(InvocationContext, KeySetCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitKeySetCommand(InvocationContext, KeySetCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
- visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in interface org.infinispan.commands.Visitor
- visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- Visitor - Interface in org.infinispan.commands
- visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in interface org.infinispan.commands.Visitor
- visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
- visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
- visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in interface org.infinispan.commands.Visitor
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.extendedstats.topK.CacheUsageInterceptor
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
- visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitPutMapCommand(InvocationContext, PutMapCommand) - Method in interface org.infinispan.commands.Visitor
- visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
- visitReadOnlyKeyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitReadOnlyKeyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in interface org.infinispan.commands.Visitor
- visitReadOnlyKeyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitReadOnlyManyCommand(InvocationContext, ReadOnlyManyCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitReadOnlyManyCommand(InvocationContext, ReadOnlyManyCommand) - Method in interface org.infinispan.commands.Visitor
- visitReadOnlyManyCommand(InvocationContext, ReadOnlyManyCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in interface org.infinispan.commands.Visitor
- visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
- visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
- visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in interface org.infinispan.commands.Visitor
- visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in interface org.infinispan.commands.Visitor
- visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in interface org.infinispan.commands.Visitor
- visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitRemoveCommand(InvocationContext, RemoveCommand) - Method in interface org.infinispan.commands.Visitor
- visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
- visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
- visitRemoveExpiredCommand(InvocationContext, RemoveExpiredCommand) - Method in interface org.infinispan.commands.Visitor
- visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in interface org.infinispan.commands.Visitor
- visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
- visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.partitionhandling.impl.PartitionHandlingInterceptor
- visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in interface org.infinispan.commands.Visitor
- visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.extendedstats.wrappers.ExtendedStatisticInterceptor
- visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitSizeCommand(InvocationContext, SizeCommand) - Method in interface org.infinispan.commands.Visitor
- visitSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitTouchCommand(InvocationContext, TouchCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitTouchCommand(InvocationContext, TouchCommand) - Method in interface org.infinispan.commands.Visitor
- visitTouchCommand(InvocationContext, TouchCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitUnknownCommand(InvocationContext, VisitableCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitUnknownCommand(InvocationContext, VisitableCommand) - Method in interface org.infinispan.commands.Visitor
-
Deprecated, for removal: This API element is subject to removal in a future version.since 11.0 will be removed in the next major version with no direct replacement. There is no reason that a unknown command should be passed through the interceptor chain.
- visitUnknownCommand(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in interface org.infinispan.commands.Visitor
- visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in interface org.infinispan.commands.Visitor
- visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in interface org.infinispan.commands.Visitor
- visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.commands.AbstractVisitor
- visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in interface org.infinispan.commands.Visitor
- visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- vLong(ByteBuf) - Static method in class org.infinispan.server.hotrod.Intrinsics
- VLong - Class in org.infinispan.server.core.transport
-
Reads and writes unsigned variable length long values.
- VLong() - Constructor for class org.infinispan.server.core.transport.VLong
- VoidCallbackHandler - Class in org.infinispan.client.hotrod.security
-
No-op
CallbackHandler
. - VoidCallbackHandler() - Constructor for class org.infinispan.client.hotrod.security.VoidCallbackHandler
- voidCompletionStageToFlowable(CompletionStage<Void>) - Static method in class org.infinispan.reactive.RxJavaInterop
- voidCompletionStageToFlowable(CompletionStage<Void>, boolean) - Static method in class org.infinispan.reactive.RxJavaInterop
-
Same as
RxJavaInterop.voidCompletionStageToFlowable(CompletionStage)
except that you can optionally have it so that if a throwable occurs in the stage that it isn't propagated if the returned Flowable's subscription was cancelled. - voidMerge(ValidResponse, Void) - Static method in class org.infinispan.util.TriangleFunctionsUtil
- VoidResponseCollector - Class in org.infinispan.remoting.transport.impl
-
Response collector that discards successful responses and returns
null
. - VOLATILE - Enum constant in enum org.infinispan.commons.api.CacheContainerAdmin.AdminFlag
-
Configuration changes will not be persisted to the global state.
- VOLATILE - Enum constant in enum org.infinispan.counter.api.Storage
-
The counter value is lost when the cluster is restarted/stopped.
- VOLATILE - Enum constant in enum org.infinispan.globalstate.ConfigurationStorage
-
Stores cache configurations in volatile storage.
- VOLATILE_CONFIGURATION_STORAGE - Enum constant in enum org.infinispan.configuration.parsing.Element
- VolatileLocalConfigurationStorage - Class in org.infinispan.globalstate.impl
-
An implementation of
LocalConfigurationStorage
which does only supportsCacheContainerAdmin.AdminFlag.VOLATILE
operations - VolatileLocalConfigurationStorage() - Constructor for class org.infinispan.globalstate.impl.VolatileLocalConfigurationStorage
W
- WAIT - Enum constant in enum org.infinispan.client.hotrod.configuration.ExhaustedAction
- WAIT - Enum constant in enum org.infinispan.persistence.remote.configuration.ExhaustedAction
- WAIT_FOR_VALID_RESPONSE - Enum constant in enum org.infinispan.remoting.rpc.ResponseMode
- WAIT_TIME - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- WAIT_TIME - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- waitForBackupToFinish() - Method in class org.infinispan.remoting.transport.AggregateBackupResponse
- waitForBackupToFinish() - Method in interface org.infinispan.remoting.transport.BackupResponse
- waitForBackupToFinish() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsBackupResponse
- waitForView(int) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
-
Deprecated, for removal: This API element is subject to removal in a future version.
- waitForView(int) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- waitForView(int) - Method in interface org.infinispan.remoting.transport.Transport
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 9.0, please use
Transport.withView(int)
instead. - WAITING - Enum constant in enum org.infinispan.util.concurrent.locks.LockState
-
The lock owner is in the queue waiting for the lock to be available.
- waitTime() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- waitTime(long) - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
-
The wait time, in milliseconds, between each retry.
- waitUntilAllCompleted() - Method in class org.infinispan.executors.ExecutorAllCompletionService
- WAKEUP_INTERVAL - Static variable in class org.infinispan.configuration.cache.ExpirationConfiguration
- wakeupInterval() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
- wakeUpInterval() - Method in class org.infinispan.configuration.cache.ExpirationConfiguration
-
Interval (in milliseconds) between subsequent runs to purge expired entries from memory and any cache stores.
- wakeUpInterval(long) - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
-
Interval (in milliseconds) between subsequent runs to purge expired entries from memory and any cache stores.
- wakeUpInterval(long, TimeUnit) - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
-
Interval (in milliseconds) between subsequent runs to purge expired entries from memory and any cache stores.
- wallClockTime() - Method in class org.infinispan.commons.time.DefaultTimeService
- wallClockTime() - Method in interface org.infinispan.commons.time.TimeService
- WARN - Enum constant in enum org.infinispan.configuration.cache.BackupFailurePolicy
- warnConditionalOperationNonTransactional(String) - Method in interface org.infinispan.server.hotrod.logging.Log
- warnDeprecatedCall(String) - Method in interface org.infinispan.rest.logging.Log
- warnForceReturnPreviousNonTransactional(String) - Method in interface org.infinispan.server.hotrod.logging.Log
- warnInvalidNumber(String, String) - Method in interface org.infinispan.rest.logging.Log
- warnPerfRemoteIterationWithoutPagination(String) - Method in interface org.infinispan.client.hotrod.logging.Log
- wasTopologyRestoredFromState() - Method in class org.infinispan.topology.CacheTopology
- WEAK - Enum constant in enum org.infinispan.counter.api.CounterType
-
A weak consistent counter.
- WEAK_COUNTER - Enum constant in enum org.infinispan.counter.configuration.Element
- WEAK_COUNTER_KEY - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- WeakCounter - Interface in org.infinispan.counter.api
-
A weak consistent counter interface.
- WeakCounterConfiguration - Class in org.infinispan.counter.configuration
-
WeakCounter
configuration. - WeakCounterConfigurationBuilder - Class in org.infinispan.counter.configuration
-
WeakCounter
configuration builder. - WeakCounterConfigurationBuilder(CounterManagerConfigurationBuilder) - Constructor for class org.infinispan.counter.configuration.WeakCounterConfigurationBuilder
- WeakValueHashMap<K,
V> - Class in org.infinispan.commons.util -
This Map will remove entries when the value in the map has been cleaned from garbage collection
- WeakValueHashMap() - Constructor for class org.infinispan.commons.util.WeakValueHashMap
-
Constructs a new, empty
WeakValueHashMap
with the default initial capacity and the default load factor, which is0.75
. - WeakValueHashMap(int) - Constructor for class org.infinispan.commons.util.WeakValueHashMap
-
Constructs a new, empty
WeakValueHashMap
with the given initial capacity and the default load factor, which is0.75
. - WeakValueHashMap(int, float) - Constructor for class org.infinispan.commons.util.WeakValueHashMap
-
Constructs a new, empty
WeakValueHashMap
with the given initial capacity and the given load factor. - WeakValueHashMap(Map<K, V>) - Constructor for class org.infinispan.commons.util.WeakValueHashMap
-
Constructs a new
WeakValueHashMap
with the same mappings as the specified Map. - WeakValueHashMap.ValueRef<K,
V> - Interface in org.infinispan.commons.util - WEBLOGIC - Enum constant in enum org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
- WEBSPHERE_4 - Enum constant in enum org.infinispan.commons.tx.lookup.LookupNames.TransactionManagerFactory
- WEBSPHERE_51_6 - Enum constant in enum org.infinispan.commons.tx.lookup.LookupNames.TransactionManagerFactory
- WEBSPHERE_6 - Enum constant in enum org.infinispan.commons.tx.lookup.LookupNames.TransactionManagerFactory
- WEBSPHERE_LIBERTY - Enum constant in enum org.infinispan.commons.tx.lookup.LookupNames.TransactionManagerFactory
- WHEN_FULL - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- WHEN_FULL - Static variable in class org.infinispan.configuration.cache.MemoryConfiguration
- WHEN_SPLIT - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- WHEN_SPLIT - Static variable in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
- whenCompleteBlocking(CompletionStage<V>, BiConsumer<? super V, ? super Throwable>, Object) - Method in interface org.infinispan.util.concurrent.BlockingManager
-
Replacement for
CompletionStage.whenCompleteAsync()
that invokes theBiConsumer
in a blocking thread (if the current thread is non-blocking) or in the current thread (if the current thread is blocking). - whenCompleteBlocking(CompletionStage<V>, BiConsumer<? super V, ? super Throwable>, Object) - Method in class org.infinispan.util.concurrent.BlockingManagerImpl
- whenCompleted(XSiteResponse.XSiteResponseCompleted) - Method in class org.infinispan.remoting.transport.impl.SiteUnreachableXSiteResponse
- whenCompleted(XSiteResponse.XSiteResponseCompleted) - Method in class org.infinispan.remoting.transport.impl.XSiteResponseImpl
- whenCompleted(XSiteResponse.XSiteResponseCompleted) - Method in interface org.infinispan.remoting.transport.XSiteResponse
- whenFull() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
- whenFull() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
- whenFull(EvictionStrategy) - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
- whenSplit() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
- whenSplit(PartitionHandling) - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
- WHITE_LIST - Enum constant in enum org.infinispan.configuration.parsing.Element
-
Deprecated, for removal: This API element is subject to removal in a future version.
- whitelist() - Method in class org.infinispan.client.hotrod.event.impl.ClientListenerNotifier
-
Deprecated, for removal: This API element is subject to removal in a future version.Use
ClientListenerNotifier.allowList()
instead. To be removed in 14.0. - whiteList() - Method in class org.infinispan.configuration.global.SerializationConfiguration
-
Deprecated, for removal: This API element is subject to removal in a future version.
- whiteList() - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.since 12.0. Use
SerializationConfigurationBuilder.allowList()
instead. To be removed in 14.0. - WhiteListConfiguration - Class in org.infinispan.configuration.global
-
Deprecated, for removal: This API element is subject to removal in a future version.
- WhiteListConfigurationBuilder - Class in org.infinispan.configuration.global
-
Deprecated, for removal: This API element is subject to removal in a future version.since 12.0. Use
AllowListConfigurationBuilder
through @SerializationConfigurationBuilder.allowList()
. Will be removed in 14.0. - wildcard - Variable in class org.infinispan.server.core.backup.resources.CounterResource
- WILDFLY - Enum constant in enum org.infinispan.commons.tx.lookup.LookupNames.TransactionManagerFactory
- WildflyTransactionManagerLookup - Class in org.infinispan.transaction.lookup
-
WildFly transaction client lookup (WildFly 11 and later).
- WildflyTransactionManagerLookup() - Constructor for class org.infinispan.transaction.lookup.WildflyTransactionManagerLookup
- WINDOWS - Enum constant in enum org.infinispan.commons.util.OS
- wire(T, WireContext, boolean) - Method in class org.infinispan.factories.impl.ComponentAccessor
- WireContext - Class in org.infinispan.factories.impl
-
Used by
ComponentAccessor
implementations for retrieving a component based on name and class. - wired() - Method in interface org.infinispan.factories.impl.ComponentRef
- wireDependencies(Object) - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.Wires an object instance with dependencies annotated with the
Inject
annotation, creating more components as needed based on the Configuration passed in if these additional components don't exist in theComponentRegistry
. - wireDependencies(Object, boolean) - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.Wires an object instance with dependencies annotated with the
Inject
annotation, creating more components as needed based on the Configuration passed in if these additional components don't exist in theComponentRegistry
. - wireDependencies(Object, boolean) - Method in interface org.infinispan.factories.impl.BasicComponentRegistry
-
Look up the dependencies of
target
as if it were a component, and inject them. - wireDependencies(Object, boolean) - Method in class org.infinispan.factories.impl.BasicComponentRegistryImpl
- wireDependencies(CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- wireRealCache() - Method in class org.infinispan.cache.impl.EncoderCache
- with(ClassLoader) - Method in interface org.infinispan.AdvancedCache
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 9.4, unmarshalling always uses the classloader from the global configuration.
- with(ClassLoader) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- with(ClassLoader) - Method in class org.infinispan.cache.impl.CacheImpl
- with(ClassLoader) - Method in class org.infinispan.cache.impl.DecoratedCache
- with(ClassLoader) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- with(ClassLoader) - Method in class org.infinispan.cache.impl.StatsCollectingCache
- with(ClassLoader) - Method in class org.infinispan.security.impl.SecureCacheImpl
- with(Json, Object...) - Method in class org.infinispan.commons.dataconversion.internal.Json
-
Same as
{}@link #with(Json,Json...options)}
with each option argument converted toJson
first. - with(Json, Json[]) - Method in class org.infinispan.commons.dataconversion.internal.Json
-
Combine this object or array with the passed in object or array.
- withAction(String) - Method in class org.infinispan.rest.framework.impl.InvocationImpl.Builder
- withAnnotationDeclared(List<Class<?>>, Class<? extends Annotation>) - Static method in class org.infinispan.commons.util.ClassFinder
- withAnnotationPresent(Class<? extends Annotation>) - Static method in class org.infinispan.commons.util.ClassFinder
- withAnnotationPresent(List<Class<?>>, Class<? extends Annotation>) - Static method in class org.infinispan.commons.util.ClassFinder
- withCharset(Charset) - Method in class org.infinispan.commons.dataconversion.MediaType
- withClassType(Class<?>) - Method in class org.infinispan.commons.dataconversion.MediaType
- withDataFormat(DataFormat) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- withDataFormat(DataFormat) - Method in interface org.infinispan.client.hotrod.impl.InternalRemoteCache
- withDataFormat(DataFormat) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- withDataFormat(DataFormat) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
Return a new instance of
RemoteCache
using the suppliedDataFormat
. - withDefaultName(Class<?>, Object) - Static method in class org.infinispan.search.mapper.common.impl.EntityReferenceImpl
- withEncoding(Class<? extends Encoder>) - Method in interface org.infinispan.AdvancedCache
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 12.1, to be removed in a future version.
- withEncoding(Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- withEncoding(Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.CacheImpl
- withEncoding(Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.DecoratedCache
- withEncoding(Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.EncoderCache
- withEncoding(Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- withEncoding(Class<? extends Encoder>) - Method in class org.infinispan.encoding.DataConversion
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 12.1, to be removed in a future version.
- withEncoding(Class<? extends Encoder>) - Method in class org.infinispan.security.impl.SecureCacheImpl
- withEncoding(Class<? extends Encoder>, Class<? extends Encoder>) - Method in interface org.infinispan.AdvancedCache
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 12.1, to be removed in a future version.
- withEncoding(Class<? extends Encoder>, Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- withEncoding(Class<? extends Encoder>, Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.CacheImpl
- withEncoding(Class<? extends Encoder>, Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.DecoratedCache
- withEncoding(Class<? extends Encoder>, Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.EncoderCache
- withEncoding(Class<? extends Encoder>, Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- withEncoding(Class<? extends Encoder>, Class<? extends Encoder>) - Method in class org.infinispan.security.impl.SecureCacheImpl
- withEncoding(String) - Method in class org.infinispan.commons.dataconversion.MediaType
- withException(Address, Exception) - Method in class org.infinispan.remoting.transport.ValidSingleResponseCollector
- withExecutorProperties(Properties) - Method in class org.infinispan.client.hotrod.configuration.ExecutorFactoryConfigurationBuilder
-
Set key/value properties to this executor factory configuration
- withExecutorProperties(Properties) - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
-
Set key/value properties to this executor factory configuration
- withFlags(Collection<Flag>) - Method in interface org.infinispan.AdvancedCache
-
An alternative to
AdvancedCache.withFlags(Flag...)
not requiring array allocation. - withFlags(Collection<Flag>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- withFlags(Collection<Flag>) - Method in class org.infinispan.cache.impl.CacheImpl
- withFlags(Collection<Flag>) - Method in class org.infinispan.cache.impl.DecoratedCache
- withFlags(Collection<Flag>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- withFlags(Collection<Flag>) - Method in class org.infinispan.security.impl.SecureCacheImpl
- withFlags(EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
- withFlags(EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.commons.api.CacheContainerAdmin
-
Sets any additional
CacheContainerAdmin.AdminFlag
s to be used when performing administrative operations. - withFlags(EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.manager.DefaultCacheManagerAdmin
- withFlags(Flag...) - Method in class org.infinispan.client.hotrod.impl.DelegatingRemoteCache
- withFlags(Flag...) - Method in interface org.infinispan.client.hotrod.impl.InternalRemoteCache
- withFlags(Flag...) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheImpl
- withFlags(Flag...) - Method in interface org.infinispan.client.hotrod.RemoteCache
-
Applies one or more
Flag
s to the scope of a single invocation. - withFlags(CacheContainerAdmin.AdminFlag...) - Method in class org.infinispan.client.hotrod.impl.RemoteCacheManagerAdminImpl
- withFlags(CacheContainerAdmin.AdminFlag...) - Method in interface org.infinispan.commons.api.CacheContainerAdmin
-
Sets any additional
CacheContainerAdmin.AdminFlag
s to be used when performing administrative operations. - withFlags(CacheContainerAdmin.AdminFlag...) - Method in class org.infinispan.manager.DefaultCacheManagerAdmin
- withFlags(Flag) - Method in interface org.infinispan.AdvancedCache
-
An alternative to
AdvancedCache.withFlags(Flag...)
optimized for a single flag. - withFlags(Flag) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- withFlags(Flag) - Method in class org.infinispan.cache.impl.CacheImpl
- withFlags(Flag) - Method in class org.infinispan.cache.impl.DecoratedCache
- withFlags(Flag...) - Method in interface org.infinispan.AdvancedCache
-
A method that adds flags to any API call.
- withFlags(Flag...) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- withFlags(Flag...) - Method in class org.infinispan.cache.impl.CacheImpl
- withFlags(Flag...) - Method in class org.infinispan.cache.impl.DecoratedCache
- withFlags(Flag...) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- withFlags(Flag...) - Method in class org.infinispan.cache.impl.StatsCollectingCache
- withFlags(Flag...) - Method in class org.infinispan.security.impl.SecureCacheImpl
- withGroupers(List<Grouper<?>>) - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
-
Set the groupers to use
- WithinThreadExecutor - Class in org.infinispan.util.concurrent
-
An executor that works within the current thread.
- WithinThreadExecutor() - Constructor for class org.infinispan.util.concurrent.WithinThreadExecutor
- WithinThreadExecutorFactory - Class in org.infinispan.executors
-
Executor factory that creates WithinThreadExecutor.
- WithinThreadExecutorFactory() - Constructor for class org.infinispan.executors.WithinThreadExecutorFactory
- withKeyEncoding(Class<? extends Encoder>) - Method in interface org.infinispan.AdvancedCache
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 12.1, to be removed in a future version.
- withKeyEncoding(Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- withKeyEncoding(Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.CacheImpl
- withKeyEncoding(Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.EncoderCache
- withKeyEncoding(Class<? extends Encoder>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- withKeyEncoding(Class<? extends Encoder>) - Method in class org.infinispan.security.impl.SecureCacheImpl
- withMediaType(String, String) - Method in interface org.infinispan.AdvancedCache
-
Deprecated, for removal: This API element is subject to removal in a future version.Use
AdvancedCache.withMediaType(MediaType, MediaType)
instead. - withMediaType(String, String) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- withMediaType(String, String) - Method in class org.infinispan.cache.impl.CacheImpl
- withMediaType(String, String) - Method in class org.infinispan.cache.impl.EncoderCache
- withMediaType(String, String) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- withMediaType(String, String) - Method in class org.infinispan.security.impl.SecureCacheImpl
- withMediaType(MediaType, MediaType) - Method in interface org.infinispan.AdvancedCache
- withMediaType(MediaType, MediaType) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- withMediaType(MediaType, MediaType) - Method in class org.infinispan.cache.impl.CacheImpl
- withMediaType(MediaType, MediaType) - Method in class org.infinispan.cache.impl.EncoderCache
- withMediaType(MediaType, MediaType) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- withMediaType(MediaType, MediaType) - Method in class org.infinispan.security.impl.SecureCacheImpl
- withNamingStrategy(NamingStrategy) - Method in class org.infinispan.commons.configuration.io.ConfigurationReader.Builder
- withoutParameters() - Method in class org.infinispan.commons.dataconversion.MediaType
- withoutValueType() - Method in class org.infinispan.client.hotrod.DataFormat
- withParameter(String, String) - Method in class org.infinispan.commons.dataconversion.MediaType
- withParameters(Map<String, Object>) - Method in interface org.infinispan.objectfilter.ObjectFilter
-
Creates a new ObjectFilter instance based on the current one and the given parameter values.
- withParameters(Map<String, String>) - Method in class org.infinispan.commons.dataconversion.MediaType
- withParams(Param<?>...) - Method in interface org.infinispan.functional.FunctionalMap.ReadOnlyMap
-
Tweak read-only functional map executions providing
Param
instances. - withParams(Param<?>...) - Method in interface org.infinispan.functional.FunctionalMap.ReadWriteMap
-
Tweak read-write functional map executions providing
Param
instances. - withParams(Param<?>...) - Method in interface org.infinispan.functional.FunctionalMap
-
Tweak functional map executions providing
Param
instances. - withParams(Param<?>...) - Method in interface org.infinispan.functional.FunctionalMap.WriteOnlyMap
-
Tweak write-only functional map executions providing
Param
instances. - withParams(Param<?>...) - Method in class org.infinispan.functional.impl.FunctionalMapImpl
- withParams(Param<?>...) - Method in class org.infinispan.functional.impl.ReadOnlyMapImpl
- withParams(Param<?>...) - Method in class org.infinispan.functional.impl.ReadWriteMapImpl
- withParams(Param<?>...) - Method in class org.infinispan.functional.impl.WriteOnlyMapImpl
- withPoolProperties(Properties) - Method in class org.infinispan.client.hotrod.configuration.ConnectionPoolConfigurationBuilder
-
Configures the connection pool parameter according to properties
- withProperties(Properties) - Method in class org.infinispan.client.hotrod.configuration.AbstractConfigurationChildBuilder
- withProperties(Properties) - Method in class org.infinispan.client.hotrod.configuration.AuthenticationConfigurationBuilder
- withProperties(Properties) - Method in class org.infinispan.client.hotrod.configuration.ConfigurationBuilder
- withProperties(Properties) - Method in interface org.infinispan.client.hotrod.configuration.ConfigurationChildBuilder
-
Configures this builder using the specified properties.
- withProperties(Properties) - Method in class org.infinispan.client.hotrod.configuration.NearCacheConfigurationBuilder
- withProperties(Properties) - Method in class org.infinispan.client.hotrod.configuration.RemoteCacheConfigurationBuilder
- withProperties(Properties) - Method in class org.infinispan.client.hotrod.configuration.SslConfigurationBuilder
- withProperties(Properties) - Method in class org.infinispan.client.hotrod.configuration.StatisticsConfigurationBuilder
- withProperties(Properties) - Method in class org.infinispan.commons.configuration.io.ConfigurationReader.Builder
- withProperties(Properties) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
-
Properties passed to the cache store or loader
- withProperties(Properties) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
- withProperties(Properties) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.Since 12.0, please
IndexingConfigurationBuilder.writer()
andIndexingConfigurationBuilder.reader()
to define indexing behavior. - withProperties(Properties) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
-
Deprecated.Sets interceptor properties
- withProperties(Properties) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
-
Properties passed to the cache store or loader
- withProperties(Properties) - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
-
Set key/value properties to this executor factory configuration
- withProperties(Properties) - Method in class org.infinispan.configuration.global.GlobalJmxConfigurationBuilder
-
Sets properties which are then passed to the MBean Server Lookup implementation specified.
- withProperties(Properties) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
-
Deprecated.Sets properties which are then passed to the MBean Server Lookup implementation specified.
- withProperties(Properties) - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
-
Set key/value properties to this executor factory configuration
- withProperties(Properties) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
-
Sets transport properties
- withProperties(Properties) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- withReplacer(PropertyReplacer) - Method in class org.infinispan.commons.configuration.io.ConfigurationReader.Builder
- withRequestMediaType(MediaType) - Method in class org.infinispan.encoding.DataConversion
- withResolver(ConfigurationResourceResolver) - Method in class org.infinispan.commons.configuration.io.ConfigurationReader.Builder
- withStorageMediaType() - Method in interface org.infinispan.AdvancedCache
-
Perform any cache operations using the same
MediaType
of the cache storage. - withStorageMediaType() - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- withStorageMediaType() - Method in class org.infinispan.cache.impl.CacheImpl
- withStorageMediaType() - Method in class org.infinispan.cache.impl.EncoderCache
- withStorageMediaType() - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- withStorageMediaType() - Method in class org.infinispan.security.impl.SecureCacheImpl
- withSubject(Subject) - Method in interface org.infinispan.AdvancedCache
-
Performs any cache operations using the specified
Subject
. - withSubject(Subject) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
- withSubject(Subject) - Method in class org.infinispan.cache.impl.CacheImpl
- withSubject(Subject) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- withSubject(Subject) - Method in class org.infinispan.manager.DefaultCacheManager
- withSubject(Subject) - Method in class org.infinispan.manager.DefaultCacheManagerAdmin
- withSubject(Subject) - Method in interface org.infinispan.manager.EmbeddedCacheManager
- withSubject(Subject) - Method in interface org.infinispan.manager.EmbeddedCacheManagerAdmin
-
Performs any cache manager operations using the specified
Subject
. - withSubject(Subject) - Method in class org.infinispan.manager.impl.AbstractDelegatingEmbeddedCacheManager
- withSubject(Subject) - Method in class org.infinispan.security.impl.SecureCacheImpl
- withType(MediaType) - Method in class org.infinispan.commons.configuration.io.ConfigurationReader.Builder
- withType(MediaType) - Method in class org.infinispan.commons.configuration.io.ConfigurationWriter.Builder
- withValidResponse(Address, ValidResponse) - Method in class org.infinispan.remoting.transport.impl.SingleResponseCollector
- withValidResponse(Address, ValidResponse) - Method in class org.infinispan.remoting.transport.impl.SingletonMapResponseCollector
- withValidResponse(Address, ValidResponse) - Method in class org.infinispan.remoting.transport.ValidSingleResponseCollector
- withView(int) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- withView(int) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- withView(int) - Method in interface org.infinispan.remoting.transport.Transport
- withWrapping(Class<? extends Wrapper>) - Method in interface org.infinispan.AdvancedCache
-
Deprecated.Since 11.0. To be removed in 14.0, with no replacement.
- withWrapping(Class<? extends Wrapper>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
-
Deprecated, for removal: This API element is subject to removal in a future version.
- withWrapping(Class<? extends Wrapper>) - Method in class org.infinispan.cache.impl.CacheImpl
- withWrapping(Class<? extends Wrapper>) - Method in class org.infinispan.cache.impl.DecoratedCache
-
Deprecated, for removal: This API element is subject to removal in a future version.
- withWrapping(Class<? extends Wrapper>) - Method in class org.infinispan.cache.impl.EncoderCache
- withWrapping(Class<? extends Wrapper>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- withWrapping(Class<? extends Wrapper>) - Method in class org.infinispan.encoding.DataConversion
-
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.
- withWrapping(Class<? extends Wrapper>) - Method in class org.infinispan.security.impl.SecureCacheImpl
- withWrapping(Class<? extends Wrapper>, Class<? extends Wrapper>) - Method in interface org.infinispan.AdvancedCache
-
Deprecated.Since 11.0. To be removed in 14.0, with no replacement.
- withWrapping(Class<? extends Wrapper>, Class<? extends Wrapper>) - Method in class org.infinispan.cache.impl.AbstractDelegatingAdvancedCache
-
Deprecated, for removal: This API element is subject to removal in a future version.
- withWrapping(Class<? extends Wrapper>, Class<? extends Wrapper>) - Method in class org.infinispan.cache.impl.CacheImpl
- withWrapping(Class<? extends Wrapper>, Class<? extends Wrapper>) - Method in class org.infinispan.cache.impl.DecoratedCache
-
Deprecated, for removal: This API element is subject to removal in a future version.
- withWrapping(Class<? extends Wrapper>, Class<? extends Wrapper>) - Method in class org.infinispan.cache.impl.EncoderCache
- withWrapping(Class<? extends Wrapper>, Class<? extends Wrapper>) - Method in class org.infinispan.cache.impl.SimpleCacheImpl
- withWrapping(Class<? extends Wrapper>, Class<? extends Wrapper>) - Method in class org.infinispan.security.impl.SecureCacheImpl
- workspace() - Method in class org.infinispan.search.mapper.scope.impl.SearchScopeImpl
- workspace() - Method in interface org.infinispan.search.mapper.scope.SearchScope
-
Create a
SearchWorkspace
for the indexes mapped to types in this scope, or to any of their sub-types. - WR_LOCAL_EXECUTION - Enum constant in enum org.infinispan.extendedstats.percentiles.PercentileStatistic
- WR_REMOTE_EXECUTION - Enum constant in enum org.infinispan.extendedstats.percentiles.PercentileStatistic
- WR_TX_ABORTED_EXECUTION_TIME - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- WR_TX_SUCCESSFUL_EXECUTION_TIME - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- wrap(byte[], int, int) - Method in class org.infinispan.server.core.security.SubjectSaslServer
- wrap(GroupedFlowable<Integer, ? extends Type>) - Static method in class org.infinispan.persistence.support.SegmentPublisherWrapper
- wrap(Object) - Method in class org.infinispan.commons.dataconversion.ByteArrayWrapper
- wrap(Object) - Method in class org.infinispan.commons.dataconversion.IdentityWrapper
- wrap(Object) - Method in interface org.infinispan.commons.dataconversion.Wrapper
- wrapBytes(byte[]) - Static method in class org.infinispan.client.hotrod.impl.Util
- wrapElement(E) - Method in class org.infinispan.cache.impl.AbstractCacheBackedSet
-
Wrap the element if needed
- wrapElement(K) - Method in class org.infinispan.cache.impl.CacheBackedKeySet
- wrapElement(CacheEntry<K, V>) - Method in class org.infinispan.cache.impl.CacheBackedEntrySet
- wrapEntryForReading(InvocationContext, Object, int, boolean, boolean, CompletionStage<Void>) - Method in interface org.infinispan.container.impl.EntryFactory
-
Wraps an entry for reading.
- wrapEntryForReading(InvocationContext, Object, int, boolean, boolean, CompletionStage<Void>) - Method in class org.infinispan.container.impl.EntryFactoryImpl
- wrapEntryForWriting(InvocationContext, Object, int, boolean, boolean, CompletionStage<Void>) - Method in interface org.infinispan.container.impl.EntryFactory
-
Insert an entry that exists in the data container into the context.
- wrapEntryForWriting(InvocationContext, Object, int, boolean, boolean, CompletionStage<Void>) - Method in class org.infinispan.container.impl.EntryFactoryImpl
- wrapEntryForWritingSkipExpiration(InvocationContext, Object, int, boolean) - Method in interface org.infinispan.container.impl.EntryFactory
-
Insert an entry that exists in the data container into the context, even if it is expired Doesn't do anything if the key was already wrapped
- wrapEntryForWritingSkipExpiration(InvocationContext, Object, int, boolean) - Method in class org.infinispan.container.impl.EntryFactoryImpl
- wrapExternalEntry(InvocationContext, Object, CacheEntry, boolean, boolean) - Method in interface org.infinispan.container.impl.EntryFactory
-
Insert an external entry (e.g.
- wrapExternalEntry(InvocationContext, Object, CacheEntry, boolean, boolean) - Method in class org.infinispan.container.impl.EntryFactoryImpl
- WRAPPED_BYTE_ARRAY - Static variable in interface org.infinispan.commons.marshall.Ids
- WRAPPED_BYTE_ARRAY - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- WRAPPED_MESSAGE - Static variable in interface org.infinispan.commons.marshall.ProtoStreamTypeIds
- WRAPPED_PARAM - Static variable in class org.infinispan.encoding.ProtostreamTranscoder
- wrappedBuffer(byte[]...) - Static method in class org.infinispan.server.core.transport.ExtendedByteBuf
- wrappedBuffer(byte[]...) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
- WrappedByteArray - Class in org.infinispan.commons.marshall
-
Simple wrapper around a byte[] to provide equals and hashCode semantics
- WrappedByteArray(byte[]) - Constructor for class org.infinispan.commons.marshall.WrappedByteArray
- WrappedByteArray(byte[], int) - Constructor for class org.infinispan.commons.marshall.WrappedByteArray
- WrappedByteArray.Externalizer - Class in org.infinispan.commons.marshall
- WrappedByteArray$___Marshaller_dd5f1f82b70f419159a02b94c2ffa39a035efa36bc3f94e3bec8f1fb78d5e078 - Class in org.infinispan.commons.marshall
-
WARNING: Generated code! Do not edit!
- WrappedByteArray$___Marshaller_dd5f1f82b70f419159a02b94c2ffa39a035efa36bc3f94e3bec8f1fb78d5e078() - Constructor for class org.infinispan.commons.marshall.WrappedByteArray$___Marshaller_dd5f1f82b70f419159a02b94c2ffa39a035efa36bc3f94e3bec8f1fb78d5e078
- WrappedByteArrayOrPrimitiveMapper - Class in org.infinispan.persistence.keymappers
-
This class is an implementation for
TwoWayKey2StringMapper
that supports both primitives andWrappedByteArray
s. - WrappedByteArrayOrPrimitiveMapper() - Constructor for class org.infinispan.persistence.keymappers.WrappedByteArrayOrPrimitiveMapper
- WrappedByteArraySizeCalculator<K,
V> - Class in org.infinispan.marshall.core -
Size calculator that supports a
WrappedByteArray
by adding its size and the underlying byte[]. - WrappedByteArraySizeCalculator(EntrySizeCalculator<?, ?>) - Constructor for class org.infinispan.marshall.core.WrappedByteArraySizeCalculator
- WrappedBytes - Interface in org.infinispan.commons.marshall
-
Interface that describes and object holding onto some bytes
- Wrapper - Interface in org.infinispan.commons.dataconversion
-
A Wrapper is used to decorate objects produced by the
Encoder
. - WrapperIds - Interface in org.infinispan.commons.dataconversion
- wrapRemoteException(Address, Throwable) - Static method in class org.infinispan.remoting.transport.ResponseCollectors
- WritableGridFileChannel - Class in org.infinispan.io
-
Deprecated, for removal: This API element is subject to removal in a future version.since 10.0
- write(byte[]) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- write(byte[]) - Method in class org.infinispan.io.GridOutputStream
-
Deprecated.
- write(byte[]) - Method in class org.infinispan.io.UnclosableObjectOutputStream
-
Deprecated.
- write(byte[], int, int) - Method in class org.infinispan.commons.io.ExposedByteArrayOutputStream
-
Deprecated.
- write(byte[], int, int) - Method in class org.infinispan.commons.io.LazyByteArrayOutputStream
- write(byte[], int, int) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- write(byte[], int, int) - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
-
Deprecated.
- write(byte[], int, int) - Method in class org.infinispan.io.GridOutputStream
-
Deprecated.
- write(byte[], int, int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
-
Deprecated.
- write(char[], int, int) - Method in class org.infinispan.commons.io.StringBuilderWriter
- write(int) - Method in class org.infinispan.commons.io.ExposedByteArrayOutputStream
-
Deprecated.
- write(int) - Method in class org.infinispan.commons.io.LazyByteArrayOutputStream
- write(int) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- write(int) - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
-
Deprecated.
- write(int) - Method in class org.infinispan.io.GridOutputStream
-
Deprecated.
- write(int) - Method in class org.infinispan.io.ImmutableMarshalledValueByteStream
-
Deprecated.
- write(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
-
Deprecated.
- write(int, MarshallableEntry<? extends K, ? extends V>) - Method in class org.infinispan.persistence.async.AsyncNonBlockingStore
- write(int, MarshallableEntry<? extends K, ? extends V>) - Method in class org.infinispan.persistence.file.SingleFileStore
- write(int, MarshallableEntry<? extends K, ? extends V>) - Method in class org.infinispan.persistence.jdbc.common.impl.BaseJdbcStore
- write(int, MarshallableEntry<? extends K, ? extends V>) - Method in class org.infinispan.persistence.remote.RemoteStore
- write(int, MarshallableEntry<? extends K, ? extends V>) - Method in class org.infinispan.persistence.rocksdb.RocksDBStore
- write(int, MarshallableEntry<? extends K, ? extends V>) - Method in class org.infinispan.persistence.sifs.NonBlockingSoftIndexFileStore
- write(int, MarshallableEntry<? extends K, ? extends V>) - Method in interface org.infinispan.persistence.spi.NonBlockingStore
-
Writes the entry to the store for the given segment returning a stage that completes normally when it is finished.
- write(int, MarshallableEntry<? extends K, ? extends V>) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
-
Deprecated.Persists the entry to the storage with the given segment to optimize future lookups.
- write(int, MarshallableEntry<? extends K, ? extends V>) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- write(int, MarshallableEntry<? extends K, ? extends V>) - Method in class org.infinispan.persistence.support.DelegatingNonBlockingStore
- write(int, MarshallableEntry<? extends K, ? extends V>) - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
- write(ByteBuf, int) - Static method in class org.infinispan.server.core.transport.VInt
- write(ByteBuf, long) - Static method in class org.infinispan.server.core.transport.VLong
- write(ChannelHandlerContext, Object, ChannelPromise) - Method in class org.infinispan.rest.CorsHandler
- write(ChannelHandlerContext, Object, ChannelPromise) - Method in class org.infinispan.server.core.transport.SaslQopHandler
- write(ChannelHandlerContext, Object, ChannelPromise) - Method in class org.infinispan.server.core.transport.StatsChannelHandler
- write(String) - Method in class org.infinispan.commons.io.StringBuilderWriter
- write(ByteBuffer) - Method in class org.infinispan.io.WritableGridFileChannel
-
Deprecated.
- write(ByteBuffer, long) - Method in class org.infinispan.persistence.sifs.FileProvider.Handle
- write(ConfigurationWriter) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Writes the attributes of this attributeset as part of the current element
- write(ConfigurationWriter) - Method in class org.infinispan.commons.configuration.attributes.ConfigurationElement
-
Writes this
ConfigurationElement
to the writer - write(ConfigurationWriter, Enum<?>) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Writes this attributeset to the specified ConfigurationWriter as an element
- write(ConfigurationWriter, String) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Writes this attributeset to the specified ConfigurationWriter as an element
- write(ConfigurationWriter, String, AttributeDefinition<?>...) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Writes the specified attributes in this attributeset to the specified ConfigurationWriter as an element
- write(ConfigurationWriter, AttributeDefinition<?>) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Writer a single attribute to the specified
ConfigurationWriter
using the attribute's xmlName - write(ConfigurationWriter, AttributeDefinition<?>, Enum<?>) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Writer a single attribute to the specified
ConfigurationWriter
using the supplied name - write(ConfigurationWriter, AttributeDefinition<?>, String) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Writer a single attribute to the specified
ConfigurationWriter
using the supplied name - write(MarshallableEntry<? extends K, ? extends V>) - Method in interface org.infinispan.persistence.spi.CacheWriter
-
Deprecated.Persists the entry to the storage.
- write(MarshallableEntry<? extends K, ? extends V>) - Method in class org.infinispan.persistence.support.AbstractSegmentedAdvancedLoadWriteStore
- write(MarshallableEntry<? extends K, ? extends V>) - Method in class org.infinispan.persistence.support.DelegatingCacheWriter
- write(ProtobufTagMarshaller.WriteContext, Subject) - Method in class org.infinispan.security.impl.SubjectAdapter$___Marshaller_75e0224333a6eeeafc364cef114fe68e65410956aa87814e98e0722f4d8a588d
- write(ProtobufTagMarshaller.WriteContext, MediaType) - Method in class org.infinispan.commons.dataconversion.MediaType$___Marshaller_f2fc301543ca54d0326b5d8ce3b7199226a678253252e7ac46f1fad54bd90568
- write(ProtobufTagMarshaller.WriteContext, WrappedByteArray) - Method in class org.infinispan.commons.marshall.WrappedByteArray$___Marshaller_dd5f1f82b70f419159a02b94c2ffa39a035efa36bc3f94e3bec8f1fb78d5e078
- write(ProtobufTagMarshaller.WriteContext, KeyValueWithPrevious) - Method in class org.infinispan.commons.util.KeyValueWithPrevious$___Marshaller_9145896a24b67e12a03ab245b027743214e8f0a00cff4e94594e6701c8f07ff1
- write(ProtobufTagMarshaller.WriteContext, NullValue) - Method in class org.infinispan.commons.util.NullValue$___Marshaller_a83283d4dbbe8b8520f457699d99f19344b973d04786829de1e22c08915e6e56
- write(ProtobufTagMarshaller.WriteContext, RemoteMetadata) - Method in class org.infinispan.container.entries.RemoteMetadata$___Marshaller_4cb4a1b59ce257eb4994240cafc1894764116cb17c3875df246d2943dcbdce0d
- write(ProtobufTagMarshaller.WriteContext, IracEntryVersion) - Method in class org.infinispan.container.versioning.irac.IracEntryVersion$___Marshaller_1d33e9a17b1520460201f2d05b09e88a3eb2df8efbb49f8a10103069f8b573d5
- write(ProtobufTagMarshaller.WriteContext, IracEntryVersion.MapEntry) - Method in class org.infinispan.container.versioning.irac.MapEntry$___Marshaller_37a121f54771729f5bc90dae7b319161c44a1e9491f8af866c7aba312bf9651e
- write(ProtobufTagMarshaller.WriteContext, TopologyIracVersion) - Method in class org.infinispan.container.versioning.irac.TopologyIracVersion$___Marshaller_14f804c9dae1c80820c4a124ae0decae2266c24993f77973d0fee34d7db215d2
- write(ProtobufTagMarshaller.WriteContext, NumericVersion) - Method in class org.infinispan.container.versioning.NumericVersion$___Marshaller_54e14f07f0b2d32fc02dc14b15442c6b41ee1d50304f1e61ddb56d9feb6975b1
- write(ProtobufTagMarshaller.WriteContext, SimpleClusteredVersion) - Method in class org.infinispan.container.versioning.SimpleClusteredVersion$___Marshaller_f7402494821fa8e2ee025bf7d4a4b60322db5a0eb2018b6aa5836c002c8e07b7
- write(ProtobufTagMarshaller.WriteContext, CounterConfiguration) - Method in class org.infinispan.counter.api.CounterConfiguration$___Marshaller_200ccbe7f9bd55cd3d0f90bae5ea29adc0a29590c936038020329c50ede7e29f
- write(ProtobufTagMarshaller.WriteContext, MetaParamsInternalMetadata) - Method in class org.infinispan.functional.impl.MetaParamsInternalMetadata$___Marshaller_d639102389197d7d9d67594c1f4f7cd51d35bdb2ed77d89d90c58b8d63ad3ab0
- write(ProtobufTagMarshaller.WriteContext, EmbeddedMetadata) - Method in class org.infinispan.metadata.EmbeddedMetadata$___Marshaller_d44c815cc3de96e45a01e06b569541e480035dc14f5499e3f3edc3fa7c6fe67
- write(ProtobufTagMarshaller.WriteContext, EmbeddedMetadata.EmbeddedExpirableMetadata) - Method in class org.infinispan.metadata.EmbeddedExpirableMetadata$___Marshaller_57542ccf09e811f3460251c589ca05aed449dbbc1765661fa3851dddaac8dd71
- write(ProtobufTagMarshaller.WriteContext, EmbeddedMetadata.EmbeddedLifespanExpirableMetadata) - Method in class org.infinispan.metadata.EmbeddedLifespanExpirableMetadata$___Marshaller_8da6d90d1f279b201c958e38c4b73ab7f2712dc1dc20b32c21334eacdfc6fd4b
- write(ProtobufTagMarshaller.WriteContext, EmbeddedMetadata.EmbeddedMaxIdleExpirableMetadata) - Method in class org.infinispan.metadata.EmbeddedMaxIdleExpirableMetadata$___Marshaller_6887b83200c53e83a8233e38450ed44c3191b4968b578e16a63c12add76959ed
- write(ProtobufTagMarshaller.WriteContext, IracMetadata) - Method in class org.infinispan.metadata.impl.IracMetadata$___Marshaller_cf0a6ded5e9e5b145ea5821d40d9659677d03a5df3e405762cc053e3bbb15e64
- write(ProtobufTagMarshaller.WriteContext, PrivateMetadata) - Method in class org.infinispan.metadata.impl.PrivateMetadata$___Marshaller_2707b1b527c228e45215e24669c8ab752e6a1689fb6e3510d925b1e899b8ee06
- write(ProtobufTagMarshaller.WriteContext, Bucket) - Method in class org.infinispan.multimap.impl.Bucket$___Marshaller_686dc55729a31972fef7d4722c2e90e0421789a20c8a9d4176be1714ac94d28c
- write(ProtobufTagMarshaller.WriteContext, RocksDBStore.ExpiryBucket) - Method in class org.infinispan.persistence.rocksdb.ExpiryBucket$___Marshaller_c1bbd47a4aa119c6b21703d5030cb689b65205a24de2638d9c9f2ce1f3a222f6
- write(ProtobufTagMarshaller.WriteContext, RocksDBStore.MetadataImpl) - Method in class org.infinispan.persistence.rocksdb.MetadataImpl$___Marshaller_b44737a8b6b24b0cd6de162703366becf9e68a2ce287544774acbaaa7268814
- write(ProtobufTagMarshaller.WriteContext, PersistenceContextInitializer.KnownClassKey) - Method in class org.infinispan.query.impl.KnownClassKey$___Marshaller_b1b9e11dd7f2c702e88c180bbc686b798fa5794bc27ae13347aacd2e4a465e3d
- write(ProtobufTagMarshaller.WriteContext, JGroupsAddress) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress$___Marshaller_fff84712bca7d00f611bdc3fd76a067b0a3a1f4981a7d3aad1c9257d9a5d7324
- write(ProtobufTagMarshaller.WriteContext, CacheDistributionInfo) - Method in class org.infinispan.rest.distribution.CacheDistributionInfo$___Marshaller_d29d2c8791a59bb0952e36da57e31d3d06e79a149845ac44d334bd095efcb62c
- write(ProtobufTagMarshaller.WriteContext, CacheDistributionRunnable) - Method in class org.infinispan.rest.distribution.CacheDistributionRunnable$___Marshaller_45f1040aff503b6010c6b926057475925f0a64804eab6e8f0d6f4ba5ddce3a36
- write(ProtobufTagMarshaller.WriteContext, NodeDistributionInfo) - Method in class org.infinispan.rest.distribution.NodeDistributionInfo$___Marshaller_50bcddd047df75d5979a51292e9db600cc21f4e1e18d6fe36b39e9a26196ea0e
- write(ProtobufTagMarshaller.WriteContext, CacheRoleImpl) - Method in class org.infinispan.security.impl.CacheRoleImpl$___Marshaller_8ebe2292503551beeebd9f0cc1e432a19521b4115fff99f8859a58acb74d6d74
- write(ProtobufTagMarshaller.WriteContext, ClusterRoleMapper.RoleSet) - Method in class org.infinispan.security.mappers.RoleSet$___Marshaller_2fda1a742ac008d38f1c852650748615da7cca98a60afaa87bb162ebc6157665
- write(ProtobufTagMarshaller.WriteContext, CacheResource.CacheBackupEntry) - Method in class org.infinispan.server.core.backup.resources.CacheBackupEntry$___Marshaller_b2d0dee2aac68dcec862a9e304f7e24daf8a89e2925ed0f1902a4f7e597df134
- write(ProtobufTagMarshaller.WriteContext, CounterResource.CounterBackupEntry) - Method in class org.infinispan.server.core.backup.resources.CounterBackupEntry$___Marshaller_2af248d5cc134577501d751e859e0021aca6b7f47edf43acc378580b56297af6
- write(ProtobufTagMarshaller.WriteContext, MemcachedMetadata) - Method in class org.infinispan.server.memcached.MemcachedMetadata$___Marshaller_582bc1c0173638c6bfeeee0149c471f14236f1b1d719f55da181f90c415f8bf1
- write(ProtobufTagMarshaller.WriteContext, MapSessionProtoAdapter.SessionAttribute) - Method in class org.infinispan.spring.common.session.MapSessionProtoAdapter.SessionAttributeRawMarshaller
- write(ProtobufTagMarshaller.WriteContext, MapSessionProtoAdapter.SessionAttribute) - Method in class org.infinispan.spring.common.session.SessionAttribute$___Marshaller_5dcef48338013ff033aa3ebdfe72b959048a23f1ab1b4e671508996ffee0358b
- write(ProtobufTagMarshaller.WriteContext, SessionUpdateRemappingFunction) - Method in class org.infinispan.spring.common.session.SessionUpdateRemappingFunctionProtoAdapter$___Marshaller_9c0544bb624c0af23e5a5e11e8120017e963b2cee452968f8524051818abdb2b
- write(ProtobufTagMarshaller.WriteContext, ByteString) - Method in class org.infinispan.util.ByteString$___Marshaller_8e599c0fc1e9a512b7cdb7c05fb5529744ecac265708e69fd30c5e989237252a
- write(ProtobufTagMarshaller.WriteContext, MapSession) - Method in class org.infinispan.spring.common.session.MapSessionProtoAdapter$___Marshaller_71442e7b0d28786c1f10a1743da12fcd08d64dc0b8a798e5658e855284c87eee
- WRITE - Enum constant in enum org.infinispan.security.AuthorizationPermission
-
Allows writing data to a cache
- WRITE - Enum constant in enum org.infinispan.util.concurrent.DataOperationOrderer.Operation
- WRITE_BEHIND - Enum constant in enum org.infinispan.configuration.parsing.Element
- WRITE_ONLY - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- WRITE_ONLY - Enum constant in enum org.infinispan.persistence.spi.NonBlockingStore.Characteristic
-
If this store supports only being written to.
- WRITE_ONLY - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- WRITE_QUERY_TIMEOUT - Enum constant in enum org.infinispan.persistence.jdbc.common.configuration.Attribute
- WRITE_SKEW_CHECK - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- WRITE_SKEW_PROBABILITY - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- WRITE_TX_PERCENTAGE - Enum constant in enum org.infinispan.extendedstats.container.ExtendedStatistic
- WriteableCacheCollectionMapper<E,
R> - Class in org.infinispan.util -
A writeable cache collection mapper that also has constant time operations for things such as
Collection.contains(Object)
if the underlying Collection does. - WriteableCacheCollectionMapper(CacheCollection<E>, Function<? super E, ? extends R>, Function<? super E, ? extends R>, Function<? super R, ? extends E>, InjectiveFunction<Object, ?>) - Constructor for class org.infinispan.util.WriteableCacheCollectionMapper
- WriteableCacheCollectionMapper(CacheCollection<E>, Function<? super E, ? extends R>, Function<? super R, ? extends E>, InjectiveFunction<Object, ?>) - Constructor for class org.infinispan.util.WriteableCacheCollectionMapper
- WriteableCacheSetMapper<E,
R> - Class in org.infinispan.util -
A writeable cache set mapper that also has constant time operations for things such as
Collection.contains(Object)
if the underlying Set does. - WriteableCacheSetMapper(CacheSet<E>, InjectiveFunction<? super E, ? extends R>, InjectiveFunction<? super E, ? extends R>, InjectiveFunction<? super R, ? extends E>, InjectiveFunction<Object, ?>) - Constructor for class org.infinispan.util.WriteableCacheSetMapper
- WriteableCacheSetMapper(CacheSet<E>, InjectiveFunction<? super E, ? extends R>, InjectiveFunction<? super R, ? extends E>, InjectiveFunction<Object, ?>) - Constructor for class org.infinispan.util.WriteableCacheSetMapper
- writeArrayElement(Enum<?>, Enum<?>, Enum<?>, Iterable<String>) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- writeArrayElement(Enum<?>, Enum<?>, Enum<?>, Iterable<String>) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeArrayElement(String, String, String, Iterable<String>) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeArrayElement(String, String, String, Iterable<String>) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeArrayElement(String, String, String, Iterable<String>) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeArrayElement(String, String, String, Iterable<String>) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- writeAttribute(Enum<?>, boolean) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- writeAttribute(Enum<?>, boolean) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeAttribute(Enum<?>, Iterable<String>) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- writeAttribute(Enum<?>, Iterable<String>) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeAttribute(Enum<?>, String) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- writeAttribute(Enum<?>, String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeAttribute(String, boolean) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- writeAttribute(String, boolean) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeAttribute(String, boolean) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeAttribute(String, Iterable<String>) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeAttribute(String, Iterable<String>) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeAttribute(String, Iterable<String>) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeAttribute(String, Iterable<String>) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- writeAttribute(String, String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeAttribute(String, String) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeAttribute(String, String) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeAttribute(String, String) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- writeBackups() - Method in class org.infinispan.distribution.DistributionInfo
- writeBoolean(boolean) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeBoolean(boolean) - Method in class org.infinispan.io.UnclosableObjectOutputStream
-
Deprecated.
- writeByte(int) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeByte(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
-
Deprecated.
- writeBytes(String) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeBytes(String) - Method in class org.infinispan.io.UnclosableObjectOutputStream
-
Deprecated.
- writeCache(ConfigurationWriter, String, Configuration) - Method in class org.infinispan.configuration.serializing.CoreConfigurationSerializer
- writeChar(int) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeChar(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
-
Deprecated.
- writeCharacters(String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeCharacters(String) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeCharacters(String) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeCharacters(String) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- writeChars(String) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeChars(String) - Method in class org.infinispan.io.UnclosableObjectOutputStream
-
Deprecated.
- writeCommandHeader(ObjectOutput, ReplicableCommand) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
- writeCommandParameters(ObjectOutput, ReplicableCommand) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
- writeComment(String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeComment(String) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeComment(String) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeComment(String) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- writeCommonStoreElements(ConfigurationWriter, StoreConfiguration) - Method in class org.infinispan.configuration.serializing.AbstractStoreSerializer
- writeCommonStoreSubAttributes(ConfigurationWriter, AbstractStoreConfiguration) - Method in class org.infinispan.configuration.serializing.AbstractStoreSerializer
- writeContext(int) - Method in class org.infinispan.cache.impl.DecoratedCache
- writeCounterEvent(ClientCounterEvent, ByteBuf) - Method in class org.infinispan.server.hotrod.Encoder4x
- writeCounterEvent(ClientCounterEvent, ByteBuf) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
-
Writes a
ClientCounterEvent
, including its header, using a giver channel buffer. - writeDefaultNamespace(String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeDefaultNamespace(String) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeDefaultNamespace(String) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeDefaultNamespace(String) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- writeDouble(double) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeDouble(double) - Method in class org.infinispan.io.UnclosableObjectOutputStream
-
Deprecated.
- writeEmptyElement(Enum<?>) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- writeEmptyElement(Enum<?>) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeEmptyElement(String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeEmptyElement(String) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeEmptyElement(String) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeEmptyElement(String) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- writeEndArrayElement() - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeEndArrayElement() - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeEndArrayElement() - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeEndArrayElement() - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- writeEndDocument() - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeEndDocument() - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeEndDocument() - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeEndDocument() - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- writeEndElement() - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeEndElement() - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeEndElement() - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeEndElement() - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- writeEndListElement() - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- writeEndListElement() - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeEndListElement() - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeEndListElement() - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeEndMap() - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeEndMap() - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeEndMap() - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeEndMap() - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- writeEndMapItem() - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeEndMapItem() - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeEndMapItem() - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeEndMapItem() - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- writeEntries(Iterable<MarshallableEntry<K, V>>, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- writeEntry(FileChannel, ByteBuffer, byte[], EntryMetadata, byte[], byte[], long, long) - Static method in class org.infinispan.persistence.sifs.EntryRecord
- writeEvent(Events.Event, ByteBuf) - Method in class org.infinispan.server.hotrod.Encoder4x
- writeEvent(Events.Event, ByteBuf) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
-
Write an event, including its header, using the given channel buffer
- writeExternal(ObjectOutput) - Method in class org.infinispan.io.GridFile.Metadata
-
Deprecated.
- writeExternal(Object, ObjectOutput) - Method in class org.infinispan.jboss.marshalling.commons.JBossExternalizerAdapter
- writeExternalClean(Object, AdvancedExternalizer, ObjectOutput) - Static method in class org.infinispan.marshall.core.GlobalMarshaller
- writeFloat(float) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeFloat(float) - Method in class org.infinispan.io.UnclosableObjectOutputStream
-
Deprecated.
- writeGlobalState() - Method in interface org.infinispan.globalstate.GlobalStateManager
-
Persists the global state by contacting all registered scope providers
- writeGlobalState() - Method in class org.infinispan.globalstate.impl.GlobalStateManagerImpl
- writeHeader(ByteBuffer, short, short, int, short, long, long) - Static method in class org.infinispan.persistence.sifs.EntryHeader
- writeHeader(HotRodHeader, HotRodServer, Channel, OperationStatus) - Method in class org.infinispan.server.hotrod.Encoder4x
- writeInt(int) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeInt(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
-
Deprecated.
- writeInternalClean(Object, AdvancedExternalizer, ObjectOutput) - Static method in class org.infinispan.marshall.core.GlobalMarshaller
- writeJdbcStoreAttributes(ConfigurationWriter, AbstractJdbcStoreConfiguration) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationSerializer
- writeJDBCStoreConnection(ConfigurationWriter, AbstractJdbcStoreConfiguration) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationSerializer
- writeJDBCStoreTable(ConfigurationWriter, Element, TableManipulationConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationSerializer
- writeLong(long) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeLong(long) - Method in class org.infinispan.io.UnclosableObjectOutputStream
-
Deprecated.
- writeMapCommand(PutMapCommand, InvocationContext, BiPredicate<? super PutMapCommand, Object>) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- writeMapItem(Enum<?>, Enum<?>, String) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- writeMapItem(Enum<?>, Enum<?>, String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeMapItem(Enum<?>, Enum<?>, String, String) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- writeMapItem(Enum<?>, Enum<?>, String, String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeMapItem(String, String, String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
-
Writes a complex map entry.
- writeMapItem(String, String, String) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeMapItem(String, String, String) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeMapItem(String, String, String) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- writeMapItem(String, String, String, String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
-
Writes a simple map entry.
- writeMapItem(String, String, String, String) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeMapItem(String, String, String, String) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeMapItem(String, String, String, String) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- writeMessageStream(Object, ImmutableSerializationContext, DataOutputStream) - Static method in class org.infinispan.server.core.backup.resources.CounterResource
- writeMetadata(int, int, long, long, long, ByteBuf) - Static method in class org.infinispan.server.hotrod.MetadataUtils
- writeMetadataResponse(HotRodHeader, HotRodServer, Channel, OperationStatus, CacheEntry<byte[], byte[]>) - Method in class org.infinispan.server.hotrod.Encoder4x
- writeNamespace(String, String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeNamespace(String, String) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeNamespace(String, String) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeNamespace(String, String) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- writeObject(ObjectOutput, Class) - Method in class org.infinispan.marshall.exts.ClassExternalizer
- writeObject(ObjectOutput, Enum<?>) - Method in class org.infinispan.marshall.exts.EnumExternalizer
- writeObject(ObjectOutput, Object) - Method in class org.infinispan.filter.CacheFilters.CacheFiltersExternalizer
- writeObject(ObjectOutput, Object) - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.ConstantLambdaExternalizer
- writeObject(ObjectOutput, Object) - Method in class org.infinispan.reactive.publisher.PublisherReducers.PublisherReducersExternalizer
- writeObject(ObjectOutput, Object) - Method in class org.infinispan.reactive.publisher.PublisherTransformers.PublisherTransformersExternalizer
- writeObject(ObjectOutput, Object) - Method in class org.infinispan.stream.impl.CacheBiConsumers.Externalizer
- writeObject(ObjectOutput, Object) - Method in class org.infinispan.stream.StreamMarshalling.StreamMarshallingExternalizer
- writeObject(ObjectOutput, Throwable) - Method in class org.infinispan.marshall.exts.ThrowableExternalizer
- writeObject(ObjectOutput, Collection) - Method in class org.infinispan.marshall.exts.CollectionExternalizer
- writeObject(ObjectOutput, DoubleSummaryStatistics) - Method in class org.infinispan.marshall.exts.DoubleSummaryStatisticsExternalizer
- writeObject(ObjectOutput, IntSummaryStatistics) - Method in class org.infinispan.marshall.exts.IntSummaryStatisticsExternalizer
- writeObject(ObjectOutput, LongSummaryStatistics) - Method in class org.infinispan.marshall.exts.LongSummaryStatisticsExternalizer
- writeObject(ObjectOutput, Map) - Method in class org.infinispan.commons.util.Immutables.ImmutableMapWrapperExternalizer
- writeObject(ObjectOutput, Map) - Method in class org.infinispan.marshall.exts.MapExternalizer
- writeObject(ObjectOutput, Optional) - Method in class org.infinispan.marshall.exts.OptionalExternalizer
- writeObject(ObjectOutput, Set) - Method in class org.infinispan.commons.util.Immutables.ImmutableSetWrapperExternalizer
- writeObject(ObjectOutput, Set) - Method in class org.infinispan.marshall.exts.EnumSetExternalizer
- writeObject(ObjectOutput, UUID) - Method in class org.infinispan.marshall.exts.UuidExternalizer
- writeObject(ObjectOutput, BiFunctionMapper) - Method in class org.infinispan.cache.impl.BiFunctionMapper.Externalizer
- writeObject(ObjectOutput, EncoderEntryMapper) - Method in class org.infinispan.cache.impl.EncoderEntryMapper.Externalizer
- writeObject(ObjectOutput, EncoderKeyMapper) - Method in class org.infinispan.cache.impl.EncoderKeyMapper.Externalizer
- writeObject(ObjectOutput, EncoderValueMapper) - Method in class org.infinispan.cache.impl.EncoderValueMapper.Externalizer
- writeObject(ObjectOutput, FunctionMapper) - Method in class org.infinispan.cache.impl.FunctionMapper.Externalizer
- writeObject(ObjectOutput, CacheRpcCommand) - Method in class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
- writeObject(ObjectOutput, CacheRpcCommand) - Method in class org.infinispan.marshall.exts.TriangleAckExternalizer
- writeObject(ObjectOutput, ReplicableCommand) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
- writeObject(ObjectOutput, CacheContainerAdmin.AdminFlag) - Method in class org.infinispan.commons.marshall.AdminFlagExternalizer
- writeObject(ObjectOutput, MediaType) - Method in class org.infinispan.commons.dataconversion.MediaType.MediaTypeExternalizer
- writeObject(ObjectOutput, ByteBufferImpl) - Method in class org.infinispan.commons.io.ByteBufferImpl.Externalizer
- writeObject(ObjectOutput, WrappedByteArray) - Method in class org.infinispan.commons.marshall.WrappedByteArray.Externalizer
- writeObject(ObjectOutput, ImmutableListCopy) - Method in class org.infinispan.commons.util.ImmutableListCopy.Externalizer
- writeObject(ObjectOutput, IntSet) - Method in class org.infinispan.util.IntSetExternalizer
- writeObject(ObjectOutput, ImmortalCacheEntry) - Method in class org.infinispan.container.entries.ImmortalCacheEntry.Externalizer
- writeObject(ObjectOutput, ImmortalCacheValue) - Method in class org.infinispan.container.entries.ImmortalCacheValue.Externalizer
- writeObject(ObjectOutput, MetadataImmortalCacheEntry) - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheEntry.Externalizer
- writeObject(ObjectOutput, MetadataImmortalCacheValue) - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue.Externalizer
- writeObject(ObjectOutput, MetadataMortalCacheEntry) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry.Externalizer
- writeObject(ObjectOutput, MetadataMortalCacheValue) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue.Externalizer
- writeObject(ObjectOutput, MetadataTransientCacheEntry) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry.Externalizer
- writeObject(ObjectOutput, MetadataTransientCacheValue) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue.Externalizer
- writeObject(ObjectOutput, MetadataTransientMortalCacheEntry) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry.Externalizer
- writeObject(ObjectOutput, MetadataTransientMortalCacheValue) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue.Externalizer
- writeObject(ObjectOutput, MortalCacheEntry) - Method in class org.infinispan.container.entries.MortalCacheEntry.Externalizer
- writeObject(ObjectOutput, MortalCacheValue) - Method in class org.infinispan.container.entries.MortalCacheValue.Externalizer
- writeObject(ObjectOutput, RemoteMetadata) - Method in class org.infinispan.container.entries.RemoteMetadata.Externalizer
- writeObject(ObjectOutput, TransientCacheEntry) - Method in class org.infinispan.container.entries.TransientCacheEntry.Externalizer
- writeObject(ObjectOutput, TransientCacheValue) - Method in class org.infinispan.container.entries.TransientCacheValue.Externalizer
- writeObject(ObjectOutput, TransientMortalCacheEntry) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry.Externalizer
- writeObject(ObjectOutput, TransientMortalCacheValue) - Method in class org.infinispan.container.entries.TransientMortalCacheValue.Externalizer
- writeObject(ObjectOutput, NumericVersion) - Method in class org.infinispan.container.versioning.NumericVersion.Externalizer
- writeObject(ObjectOutput, SimpleClusteredVersion) - Method in class org.infinispan.container.versioning.SimpleClusteredVersion.Externalizer
- writeObject(ObjectOutput, Flag) - Method in class org.infinispan.context.Flag.Externalizer
- writeObject(ObjectOutput, DefaultConsistentHashFactory) - Method in class org.infinispan.distribution.ch.impl.DefaultConsistentHashFactory.Externalizer
- writeObject(ObjectOutput, ReplicatedConsistentHashFactory) - Method in class org.infinispan.distribution.ch.impl.ReplicatedConsistentHashFactory.Externalizer
- writeObject(ObjectOutput, ScatteredConsistentHashFactory) - Method in class org.infinispan.distribution.ch.impl.ScatteredConsistentHashFactory.Externalizer
- writeObject(ObjectOutput, SyncConsistentHashFactory) - Method in class org.infinispan.distribution.ch.impl.SyncConsistentHashFactory.Externalizer
- writeObject(ObjectOutput, SyncReplicatedConsistentHashFactory) - Method in class org.infinispan.distribution.ch.impl.SyncReplicatedConsistentHashFactory.Externalizer
- writeObject(ObjectOutput, TopologyAwareConsistentHashFactory) - Method in class org.infinispan.distribution.ch.impl.TopologyAwareConsistentHashFactory.Externalizer
- writeObject(ObjectOutput, TopologyAwareSyncConsistentHashFactory) - Method in class org.infinispan.distribution.ch.impl.TopologyAwareSyncConsistentHashFactory.Externalizer
- writeObject(ObjectOutput, DataConversion) - Method in class org.infinispan.encoding.DataConversion.Externalizer
- writeObject(ObjectOutput, AcceptAllKeyValueFilter) - Method in class org.infinispan.filter.AcceptAllKeyValueFilter.Externalizer
- writeObject(ObjectOutput, CompositeKeyValueFilter) - Method in class org.infinispan.filter.CompositeKeyValueFilter.Externalizer
- writeObject(ObjectOutput, EntryViews.NoValueReadOnlyView) - Method in class org.infinispan.functional.impl.EntryViews.NoValueReadOnlyViewExternalizer
- writeObject(ObjectOutput, EntryViews.ReadOnlySnapshotView) - Method in class org.infinispan.functional.impl.EntryViews.ReadOnlySnapshotViewExternalizer
- writeObject(ObjectOutput, EntryViews.ReadWriteSnapshotView) - Method in class org.infinispan.functional.impl.EntryViews.ReadWriteSnapshotViewExternalizer
- writeObject(ObjectOutput, Params) - Static method in class org.infinispan.functional.impl.Params
- writeObject(ObjectOutput, StatsEnvelope) - Method in class org.infinispan.functional.impl.StatsEnvelope.Externalizer
- writeObject(ObjectOutput, MetaParam.MetaEntryVersion) - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.EntryVersionParamExternalizer
- writeObject(ObjectOutput, MetaParam.MetaLifespan) - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.LifespanExternalizer
- writeObject(ObjectOutput, MetaParam.MetaMaxIdle) - Method in class org.infinispan.marshall.exts.MetaParamExternalizers.MaxIdleExternalizer
- writeObject(ObjectOutput, CacheState) - Method in class org.infinispan.globalstate.impl.CacheState.Externalizer
- writeObject(ObjectOutput, ScopedState) - Method in class org.infinispan.globalstate.ScopedState.Externalizer
- writeObject(ObjectOutput, ScopeFilter) - Method in class org.infinispan.globalstate.ScopeFilter.Externalizer
- writeObject(ObjectOutput, MarshallableFunctions.LambdaWithMetas) - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.LambdaWithMetasExternalizer
- writeObject(ObjectOutput, MarshallableFunctions.SetValueIfEqualsReturnBoolean) - Method in class org.infinispan.marshall.core.MarshallableFunctionExternalizers.SetValueIfEqualsReturnBooleanExternalizer
- writeObject(ObjectOutput, EmbeddedMetadata) - Method in class org.infinispan.metadata.EmbeddedMetadata.Externalizer
- writeObject(ObjectOutput, InternalMetadataImpl) - Method in class org.infinispan.metadata.impl.InternalMetadataImpl.Externalizer
-
Deprecated.
- writeObject(ObjectOutput, ClusterEvent) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent.Externalizer
- writeObject(ObjectOutput, ClusterListenerRemoveCallable) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerRemoveCallable.Externalizer
- writeObject(ObjectOutput, ClusterListenerReplicateCallable) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerReplicateCallable.Externalizer
- writeObject(ObjectOutput, CacheEventConverterAsConverter) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventConverterAsConverter.Externalizer
- writeObject(ObjectOutput, CacheEventFilterAsKeyValueFilter) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterAsKeyValueFilter.Externalizer
- writeObject(ObjectOutput, CacheEventFilterConverterAsKeyValueFilterConverter) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverterAsKeyValueFilterConverter.Externalizer
- writeObject(ObjectOutput, KeyValueFilterAsCacheEventFilter) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterAsCacheEventFilter.Externalizer
- writeObject(ObjectOutput, KeyValueFilterConverterAsCacheEventFilterConverter) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter.Externalizer
- writeObject(ObjectOutput, AvailabilityMode) - Method in class org.infinispan.partitionhandling.AvailabilityMode.Externalizer
- writeObject(ObjectOutput, AddSourceRemoteStoreTask) - Method in class org.infinispan.persistence.remote.upgrade.AddSourceRemoteStoreTask.Externalizer
- writeObject(ObjectOutput, CheckRemoteStoreTask) - Method in class org.infinispan.persistence.remote.upgrade.CheckRemoteStoreTask.Externalizer
- writeObject(ObjectOutput, DisconnectRemoteStoreTask) - Method in class org.infinispan.persistence.remote.upgrade.DisconnectRemoteStoreTask.Externalizer
- writeObject(ObjectOutput, MigrationTask) - Method in class org.infinispan.persistence.remote.upgrade.MigrationTask.Externalizer
- writeObject(ObjectOutput, MigrationTask.EntryWriter) - Method in class org.infinispan.persistence.remote.upgrade.MigrationTask.EntryWriterExternalizer
- writeObject(ObjectOutput, QueryDefinition) - Method in class org.infinispan.query.impl.QueryDefinition.Externalizer
- writeObject(ObjectOutput, BiasRevocationResponse) - Method in class org.infinispan.remoting.responses.BiasRevocationResponse.Externalizer
- writeObject(ObjectOutput, CacheNotFoundResponse) - Method in class org.infinispan.remoting.responses.CacheNotFoundResponse.Externalizer
- writeObject(ObjectOutput, ExceptionResponse) - Method in class org.infinispan.remoting.responses.ExceptionResponse.Externalizer
- writeObject(ObjectOutput, SuccessfulResponse) - Method in class org.infinispan.remoting.responses.SuccessfulResponse.Externalizer
- writeObject(ObjectOutput, UnsuccessfulResponse) - Method in class org.infinispan.remoting.responses.UnsuccessfulResponse.Externalizer
- writeObject(ObjectOutput, UnsureResponse) - Method in class org.infinispan.remoting.responses.UnsureResponse.Externalizer
- writeObject(ObjectOutput, SimpleGroupPrincipal) - Method in class org.infinispan.server.core.security.simple.SimpleGroupPrincipal.Externalizer
- writeObject(ObjectOutput, SimpleSubjectUserInfo) - Method in class org.infinispan.server.core.security.simple.SimpleSubjectUserInfo.Externalizer
- writeObject(ObjectOutput, KeyValueWithPreviousEventConverter) - Method in class org.infinispan.server.hotrod.event.KeyValueWithPreviousEventConverterExternalizer
- writeObject(ObjectOutput, IterationFilter) - Method in class org.infinispan.server.hotrod.iteration.IterationFilter.IterationFilterExternalizer
- writeObject(ObjectOutput, ClusterCacheStatsImpl.DistributedCacheStatsCallable) - Method in class org.infinispan.stats.impl.ClusterCacheStatsImpl.DistributedCacheStatsCallableExternalizer
- writeObject(ObjectOutput, CacheIntermediatePublisher) - Method in class org.infinispan.stream.impl.CacheIntermediatePublisher.ReducerExternalizer
- writeObject(ObjectOutput, CacheStreamIntermediateReducer) - Method in class org.infinispan.stream.impl.CacheStreamIntermediateReducer.ReducerExternalizer
- writeObject(ObjectOutput, CacheJoinInfo) - Method in class org.infinispan.topology.CacheJoinInfo.Externalizer
- writeObject(ObjectOutput, CacheStatusResponse) - Method in class org.infinispan.topology.CacheStatusResponse.Externalizer
- writeObject(ObjectOutput, PersistentUUID) - Method in class org.infinispan.topology.PersistentUUID.Externalizer
- writeObject(ObjectOutput, GlobalTransaction) - Method in class org.infinispan.transaction.xa.GlobalTransaction.Externalizer
- writeObject(ObjectOutput, ByteString) - Static method in class org.infinispan.util.ByteString
- writeObject(ObjectOutput, KeyValuePair) - Method in class org.infinispan.util.KeyValuePair.Externalizer
- writeObject(ObjectOutput, XSiteRequest) - Method in class org.infinispan.xsite.commands.remote.XSiteRequestExternalizer
- writeObject(ObjectOutput, XSiteState) - Method in class org.infinispan.xsite.statetransfer.XSiteState.XSiteStateExternalizer
- writeObject(ObjectOutput, T) - Method in interface org.infinispan.commons.marshall.Externalizer
-
Deprecated.Write the object reference to the stream.
- writeObject(ObjectOutput, T) - Method in class org.infinispan.commons.marshall.exts.NoStateExternalizer
- writeObject(ObjectOutput, T) - Method in class org.infinispan.commons.marshall.InstanceReusingAdvancedExternalizer
- writeObject(ObjectOutput, T) - Method in class org.infinispan.commons.marshall.SingletonExternalizer
- writeObject(ObjectOutput, T) - Method in class org.infinispan.commons.marshall.SuppliedExternalizer
- writeObject(Object) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeObject(Object) - Method in class org.infinispan.io.UnclosableObjectOutputStream
-
Deprecated.
- writeObject(Object, OutputStream) - Method in interface org.infinispan.commons.marshall.StreamAwareMarshaller
-
Marshall an object to the
OutputStream
- writeOnly() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
-
If true, any operation that reads from the cache won't be retrieved from the given store.
- writeOnly() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
- writeOnly(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
- writeOnly(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
- writeOnly(boolean) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
-
If true, this cache store will be only used to write entries.
- writeOnly(CacheEntry, DataConversion) - Static method in class org.infinispan.functional.impl.EntryViews
- WriteOnlyMapImpl<K,
V> - Class in org.infinispan.functional.impl -
Write-only map implementation.
- writeOptional(ConfigurationWriter, Enum<?>, String) - Static method in class org.infinispan.configuration.serializing.SerializeUtils
- writeOwners() - Method in class org.infinispan.distribution.DistributionInfo
- writeOwnership() - Method in class org.infinispan.distribution.DistributionInfo
- writeQueryTimeout - Variable in class org.infinispan.persistence.jdbc.common.sql.BaseTableOperations
- writeQueryTimeout() - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfiguration
- writeQueryTimeout(Integer) - Method in class org.infinispan.persistence.jdbc.common.configuration.AbstractJdbcStoreConfigurationBuilder
- writer - Variable in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- writer() - Method in class org.infinispan.configuration.cache.IndexMergeConfigurationBuilder
- writer() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
- writer() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
- writer() - Method in interface org.infinispan.configuration.cache.IndexingConfigurationChildBuilder
- writer() - Method in class org.infinispan.persistence.support.NonBlockingStoreAdapter
- writeRangedBytes(byte[], int, ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
- writeRangedBytes(byte[], ByteBuf) - Static method in class org.infinispan.server.core.transport.ExtendedByteBuf
- writeRangedBytes(byte[], ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
- writeRangedBytes(ByteBuffer, ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
- writeResponse(HotRodHeader, ByteBuf) - Method in class org.infinispan.server.hotrod.BaseRequestProcessor
- writeResponseOrThrowable(Channel, Object, Throwable) - Method in class org.infinispan.server.memcached.MemcachedDecoder
- writeScopedState(ScopedPersistentState) - Method in interface org.infinispan.globalstate.GlobalStateManager
-
Persists the specified scoped state
- writeScopedState(ScopedPersistentState) - Method in class org.infinispan.globalstate.impl.GlobalStateManagerImpl
- writeShort(int) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeShort(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
-
Deprecated.
- writeSignedInt(ObjectOutput, int) - Static method in class org.infinispan.commons.io.SignedNumeric
- writeSignedInt(OutputStream, int) - Static method in class org.infinispan.commons.io.SignedNumeric
- WriteSkewException - Exception in org.infinispan.transaction
-
Thrown when a write skew is detected
- WriteSkewException() - Constructor for exception org.infinispan.transaction.WriteSkewException
- WriteSkewException(String, Object) - Constructor for exception org.infinispan.transaction.WriteSkewException
- WriteSkewException(String, Throwable, Object) - Constructor for exception org.infinispan.transaction.WriteSkewException
- WriteSkewException(Throwable, Object) - Constructor for exception org.infinispan.transaction.WriteSkewException
- WriteSkewHelper - Class in org.infinispan.transaction.impl
-
Encapsulates write skew logic in maintaining version maps, etc.
- WriteSkewHelper() - Constructor for class org.infinispan.transaction.impl.WriteSkewHelper
- WriteSkewHelper.KeySpecificLogic - Interface in org.infinispan.transaction.impl
- writeStartArrayElement(Enum<?>) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- writeStartArrayElement(Enum<?>) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeStartArrayElement(String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
-
Writes an array element.
- writeStartArrayElement(String) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeStartArrayElement(String) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeStartArrayElement(String) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- writeStartDocument() - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeStartDocument() - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeStartDocument() - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeStartDocument() - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- writeStartElement(Enum<?>) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- writeStartElement(Enum<?>) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeStartElement(String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeStartElement(String) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeStartElement(String) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeStartElement(String) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- writeStartElement(String, String, Enum<?>) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- writeStartElement(String, String, Enum<?>) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeStartElement(String, String, String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeStartElement(String, String, String) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeStartElement(String, String, String) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeStartElement(String, String, String) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- writeStartListElement(Enum<?>, boolean) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- writeStartListElement(Enum<?>, boolean) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeStartListElement(String, boolean) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
-
Starts a list element.
- writeStartListElement(String, boolean) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeStartListElement(String, boolean) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeStartListElement(String, boolean) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- writeStartListElement(String, String, Enum<?>, boolean) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- writeStartListElement(String, String, Enum<?>, boolean) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeStartListElement(String, String, String, boolean) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeStartListElement(String, String, String, boolean) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeStartListElement(String, String, String, boolean) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeStartListElement(String, String, String, boolean) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- writeStartMap(Enum<?>) - Method in class org.infinispan.commons.configuration.io.AbstractConfigurationWriter
- writeStartMap(Enum<?>) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeStartMap(String) - Method in interface org.infinispan.commons.configuration.io.ConfigurationWriter
- writeStartMap(String) - Method in class org.infinispan.commons.configuration.io.json.JsonConfigurationWriter
- writeStartMap(String) - Method in class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- writeStartMap(String) - Method in class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- writeString(String, ByteBuf) - Static method in class org.infinispan.server.core.transport.ExtendedByteBuf
- writeString(String, ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
- writeString(Optional<String>, ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
- writeTo(ByteBuf) - Method in class org.infinispan.client.hotrod.transaction.manager.RemoteXid
- writeTo(ByteBuf) - Method in class org.infinispan.server.hotrod.counter.listener.ClientCounterEvent
- writeTo(ObjectOutput) - Method in interface org.infinispan.commands.ReplicableCommand
-
Writes this instance to the
ObjectOutput
. - writeTo(ObjectOutput) - Method in class org.infinispan.expiration.impl.TouchCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.manager.impl.ReplicableManagerFunctionCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.manager.impl.ReplicableRunnableCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.notifications.cachelistener.cluster.MultiClusterEventCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.server.hotrod.command.tx.ForwardCommitCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.topology.HeartBeatCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.commands.remote.IracPutManyRequest
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.commands.remote.IracTombstoneCheckRequest
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.commands.remote.IracTouchKeyRequest
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.commands.remote.XSiteCacheRequest
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.commands.remote.XSiteRemoteEventCommand
- writeTo(ObjectOutput) - Method in interface org.infinispan.xsite.commands.remote.XSiteRequest
-
Writes this instance to the
ObjectOutput
. - writeTo(ObjectOutput) - Method in class org.infinispan.xsite.commands.remote.XSiteStatePushRequest
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.commands.remote.XSiteStateTransferControlRequest
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.commands.XSiteAmendOfflineStatusCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.commands.XSiteAutoTransferStatusCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.commands.XSiteBringOnlineCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.commands.XSiteLocalEventCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.commands.XSiteOfflineStatusCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.commands.XSiteSetStateTransferModeCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.commands.XSiteStateTransferCancelSendCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.commands.XSiteStateTransferFinishReceiveCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.commands.XSiteStateTransferFinishSendCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.commands.XSiteStateTransferRestartSendingCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.commands.XSiteStateTransferStartReceiveCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.commands.XSiteStateTransferStartSendCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.commands.XSiteTakeOfflineCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
- writeTo(ObjectOutput, E) - Method in interface org.infinispan.commons.marshall.MarshallUtil.ElementWriter
- writeTo(ObjectOutput, CommandInvocationId) - Static method in class org.infinispan.commands.CommandInvocationId
- writeTo(ObjectOutput, XidImpl) - Static method in class org.infinispan.commons.tx.XidImpl
- writeTo(ObjectOutput, IntSet) - Static method in class org.infinispan.commons.util.IntSetsExternalization
- writeTo(ObjectOutput, SmallIntSet) - Static method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- writeTo(ObjectOutput, IracTombstoneInfo) - Static method in class org.infinispan.container.versioning.irac.IracTombstoneInfo
- writeTo(ObjectOutput, DataConversion) - Static method in class org.infinispan.encoding.DataConversion
- writeTo(ObjectOutput, MetaParams) - Static method in class org.infinispan.functional.impl.MetaParams
- writeTo(ObjectOutput, IracMetadata) - Static method in class org.infinispan.metadata.impl.IracMetadata
- writeTo(ObjectOutput, CacheXid) - Static method in class org.infinispan.server.hotrod.tx.table.CacheXid
- writeTo(ObjectOutput, Status) - Static method in enum org.infinispan.server.hotrod.tx.table.Status
- writeTo(ObjectOutput, XSiteEvent) - Static method in class org.infinispan.xsite.events.XSiteEvent
- writeTo(ObjectOutput, IracManagerKeyInfo) - Static method in class org.infinispan.xsite.irac.IracManagerKeyInfoImpl
- writeTo(PrepareResponse, ObjectOutput) - Static method in class org.infinispan.remoting.responses.PrepareResponse
- writeToAllNonTxStores(MarshallableEntry, int, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- writeToAllNonTxStores(MarshallableEntry, int, Predicate<? super StoreConfiguration>, long) - Method in class org.infinispan.persistence.support.DelegatingPersistenceManager
- writeToManifest(Properties) - Method in interface org.infinispan.server.core.backup.ContainerResource
-
Writes the name of the individual resources that have been included in this backup.
- writeToManifest(Properties) - Method in class org.infinispan.server.core.backup.resources.CounterResource
- writeTypedProperties(ConfigurationWriter, TypedProperties) - Static method in class org.infinispan.configuration.serializing.SerializeUtils
- writeTypedProperties(ConfigurationWriter, TypedProperties, Enum<?>, Enum<?>) - Static method in class org.infinispan.configuration.serializing.SerializeUtils
- writeUnknown(Marshaller, Object, ObjectOutput) - Static method in class org.infinispan.marshall.core.GlobalMarshaller
- writeUnsignedInt(byte[], int, int) - Static method in class org.infinispan.commons.io.UnsignedNumeric
-
Writes an int in a variable-length format.
- writeUnsignedInt(int, ByteBuf) - Static method in class org.infinispan.server.core.transport.ExtendedByteBuf
- writeUnsignedInt(int, ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
- writeUnsignedInt(DataOutput, int) - Static method in class org.infinispan.commons.io.UnsignedNumeric
-
Writes an int in a variable-length format.
- writeUnsignedInt(OutputStream, int) - Static method in class org.infinispan.commons.io.UnsignedNumeric
- writeUnsignedInt(ByteBuffer, int) - Static method in class org.infinispan.commons.io.UnsignedNumeric
- writeUnsignedLong(byte[], int, long) - Static method in class org.infinispan.commons.io.UnsignedNumeric
-
Writes an int in a variable-length format.
- writeUnsignedLong(long, ByteBuf) - Static method in class org.infinispan.server.core.transport.ExtendedByteBuf
- writeUnsignedLong(long, ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
- writeUnsignedLong(DataOutput, long) - Static method in class org.infinispan.commons.io.UnsignedNumeric
-
Writes a long in a variable-length format.
- writeUnsignedLong(OutputStream, long) - Static method in class org.infinispan.commons.io.UnsignedNumeric
- writeUnsignedLong(ByteBuffer, long) - Static method in class org.infinispan.commons.io.UnsignedNumeric
- writeUnsignedShort(int, ByteBuf) - Static method in class org.infinispan.server.core.transport.ExtendedByteBuf
- writeUnsignedShort(int, ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
- writeUTF(String) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeUTF(String) - Method in class org.infinispan.io.UnclosableObjectOutputStream
-
Deprecated.
- writeXid(XidImpl, ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
- WrongDateFormatException - Exception in org.infinispan.rest.operations.exceptions
- WrongDateFormatException(String) - Constructor for exception org.infinispan.rest.operations.exceptions.WrongDateFormatException
- wrongMediaType(String, String) - Method in interface org.infinispan.rest.logging.Log
- wrongMethod(String) - Method in interface org.infinispan.rest.logging.Log
- WWW_AUTHENTICATE_HEADER - Enum constant in enum org.infinispan.rest.ResponseHeader
- WWW_FORM_URLENCODED_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
X
- X_SITE_STATE - Static variable in interface org.infinispan.commons.marshall.Ids
- XaTransactionTable - Class in org.infinispan.transaction.xa
-
TransactionTable
to be used withTransactionXaAdapter
. - XaTransactionTable() - Constructor for class org.infinispan.transaction.xa.XaTransactionTable
- xid - Variable in class org.infinispan.server.hotrod.command.tx.ForwardCommitCommand
- XID - Static variable in interface org.infinispan.commons.marshall.Ids
- XID_DEADLOCK_DETECTING_GLOBAL_TRANSACTION - Static variable in interface org.infinispan.commons.marshall.Ids
- XID_GLOBAL_TRANSACTION - Static variable in interface org.infinispan.commons.marshall.Ids
- XID_IMPL - Static variable in interface org.infinispan.commons.marshall.Ids
- XID_PREDICATE - Static variable in class org.infinispan.server.core.ExternalizerIds
- xid2LocalTx - Variable in class org.infinispan.transaction.xa.XaTransactionTable
- XidImpl - Class in org.infinispan.commons.tx
-
A
Xid
implementation. - XidImpl(int, byte[], byte[]) - Constructor for class org.infinispan.commons.tx.XidImpl
- XidPredicate - Class in org.infinispan.server.hotrod.tx.table.functions
- XidPredicate(XidImpl) - Constructor for class org.infinispan.server.hotrod.tx.table.functions.XidPredicate
- XINCLUDE - Static variable in class org.infinispan.commons.configuration.io.xml.XmlConfigurationReader
- XINCLUDE_NS - Static variable in class org.infinispan.commons.configuration.io.xml.XmlConfigurationReader
- XML_URI - Static variable in class org.infinispan.commons.configuration.io.xml.MXParser
- XmlConfigurationReader - Class in org.infinispan.commons.configuration.io.xml
- XmlConfigurationReader(Reader, ConfigurationResourceResolver, Properties, PropertyReplacer, NamingStrategy) - Constructor for class org.infinispan.commons.configuration.io.xml.XmlConfigurationReader
- XmlConfigurationWriter - Class in org.infinispan.commons.configuration.io.xml
- XmlConfigurationWriter(Writer, boolean, boolean) - Constructor for class org.infinispan.commons.configuration.io.xml.XmlConfigurationWriter
- xmlDeclContent - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- xmlDeclStandalone - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- xmlDeclVersion - Variable in class org.infinispan.commons.configuration.io.xml.MXParser
- XMLNS_URI - Static variable in class org.infinispan.commons.configuration.io.xml.MXParser
- XmlPullParser - Interface in org.infinispan.commons.configuration.io.xml
-
XML Pull Parser is an interface that defines parsing functionlity provided in XMLPULL V1 API (visit this website to learn more about API and its implementations).
- XmlPullParserException - Exception in org.infinispan.commons.configuration.io.xml
-
This exception is thrown to signal XML Pull Parser related faults.
- XmlPullParserException(String) - Constructor for exception org.infinispan.commons.configuration.io.xml.XmlPullParserException
- XmlPullParserException(String, XmlPullParser, Throwable) - Constructor for exception org.infinispan.commons.configuration.io.xml.XmlPullParserException
- XMLStringConfiguration - Class in org.infinispan.commons.configuration
-
Deprecated, for removal: This API element is subject to removal in a future version.Use
StringConfiguration
instead - XMLStringConfiguration(String) - Constructor for class org.infinispan.commons.configuration.XMLStringConfiguration
-
Deprecated.
- XMLTranscoder - Class in org.infinispan.server.core.dataconversion
-
Basic XML transcoder supporting conversions from XML to commons formats.
- XMLTranscoder() - Constructor for class org.infinispan.server.core.dataconversion.XMLTranscoder
- XMLTranscoder(ClassLoader, ClassAllowList) - Constructor for class org.infinispan.server.core.dataconversion.XMLTranscoder
- XMLTranscoder(ClassAllowList) - Constructor for class org.infinispan.server.core.dataconversion.XMLTranscoder
- xorSSLContext() - Method in interface org.infinispan.client.hotrod.logging.Log
- xorSSLContext() - Method in interface org.infinispan.server.core.logging.Log
- XPRESS - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.CompressionType
- XSITE_AUTO_TRANSFER_RESPONSE - Static variable in interface org.infinispan.commons.marshall.Ids
- XSITE_COMMANDS_EXTERNALIZER - Static variable in interface org.infinispan.commons.marshall.Ids
- XSiteAmendOfflineStatusCommand - Class in org.infinispan.xsite.commands
-
Amend a sites offline status.
- XSiteAmendOfflineStatusCommand() - Constructor for class org.infinispan.xsite.commands.XSiteAmendOfflineStatusCommand
- XSiteAmendOfflineStatusCommand(ByteString) - Constructor for class org.infinispan.xsite.commands.XSiteAmendOfflineStatusCommand
- XSiteAmendOfflineStatusCommand(ByteString, String, Integer, Long) - Constructor for class org.infinispan.xsite.commands.XSiteAmendOfflineStatusCommand
- XSiteAsyncAckListener - Interface in org.infinispan.remoting.transport
-
A listener to be notified when an asynchronous cross-site request is completed.
- XSiteAutoTransferStatusCommand - Class in org.infinispan.xsite.commands
-
A
CacheRpcCommand
to check the remote site status and state transfer mode in the local cluster. - XSiteAutoTransferStatusCommand() - Constructor for class org.infinispan.xsite.commands.XSiteAutoTransferStatusCommand
- XSiteAutoTransferStatusCommand(ByteString) - Constructor for class org.infinispan.xsite.commands.XSiteAutoTransferStatusCommand
- XSiteAutoTransferStatusCommand(ByteString, String) - Constructor for class org.infinispan.xsite.commands.XSiteAutoTransferStatusCommand
- XSiteBringOnlineCommand - Class in org.infinispan.xsite.commands
-
Take a site offline.
- XSiteBringOnlineCommand() - Constructor for class org.infinispan.xsite.commands.XSiteBringOnlineCommand
- XSiteBringOnlineCommand(ByteString) - Constructor for class org.infinispan.xsite.commands.XSiteBringOnlineCommand
- XSiteBringOnlineCommand(ByteString, String) - Constructor for class org.infinispan.xsite.commands.XSiteBringOnlineCommand
- XSiteCacheRequest<T> - Class in org.infinispan.xsite.commands.remote
-
A
XSiteRequest
which is associated to a cache. - XSiteCacheRequest(ByteString) - Constructor for class org.infinispan.xsite.commands.remote.XSiteCacheRequest
- XSiteEntryMergePolicy<K,
V> - Interface in org.infinispan.xsite.spi -
An interface to resolve conflicts for asynchronous cross-site replication.
- XSiteEntryMergePolicyFactory - Class in org.infinispan.factories
-
A factory for
XSiteEntryMergePolicy
. - XSiteEntryMergePolicyFactory() - Constructor for class org.infinispan.factories.XSiteEntryMergePolicyFactory
- XSiteEvent - Class in org.infinispan.xsite.events
-
Represents an event related to cross-site.
- XSiteEventSender - Class in org.infinispan.xsite.events
-
A collector of events to be sent to the remote site.
- XSiteEventSender(BiConsumer<XSiteBackup, XSiteRemoteEventCommand>) - Constructor for class org.infinispan.xsite.events.XSiteEventSender
- XSiteEventsManager - Interface in org.infinispan.xsite.events
-
A manager class that handles the
XSiteEvent
from local and remote sites. - XSiteEventsManagerImpl - Class in org.infinispan.xsite.events
-
Default implementation of
XSiteEventsManager
. - XSiteEventsManagerImpl() - Constructor for class org.infinispan.xsite.events.XSiteEventsManagerImpl
- XSiteEventType - Enum in org.infinispan.xsite.events
-
Types of
XSiteEvent
. - XSiteLocalEventCommand - Class in org.infinispan.xsite.commands
-
Sends
XSiteEvent
list from a local site node. - XSiteLocalEventCommand() - Constructor for class org.infinispan.xsite.commands.XSiteLocalEventCommand
- XSiteLocalEventCommand(List<XSiteEvent>) - Constructor for class org.infinispan.xsite.commands.XSiteLocalEventCommand
- XSiteMergePolicy - Enum in org.infinispan.xsite.spi
-
An alias with the provided implementation of
XSiteEntryMergePolicy
. - XSiteMetricsCollector - Interface in org.infinispan.xsite.metrics
-
Collects metrics about cross-site replication operations.
- XSiteOfflineStatusCommand - Class in org.infinispan.xsite.commands
-
Get the offline status of a
BackupSender
. - XSiteOfflineStatusCommand() - Constructor for class org.infinispan.xsite.commands.XSiteOfflineStatusCommand
- XSiteOfflineStatusCommand(ByteString) - Constructor for class org.infinispan.xsite.commands.XSiteOfflineStatusCommand
- XSiteOfflineStatusCommand(ByteString, String) - Constructor for class org.infinispan.xsite.commands.XSiteOfflineStatusCommand
- XSiteRemoteEventCommand - Class in org.infinispan.xsite.commands.remote
-
Sends a
XSiteEvent
list from a remote site. - XSiteRemoteEventCommand() - Constructor for class org.infinispan.xsite.commands.remote.XSiteRemoteEventCommand
- XSiteRemoteEventCommand(List<XSiteEvent>) - Constructor for class org.infinispan.xsite.commands.remote.XSiteRemoteEventCommand
- XSiteRequest<T> - Interface in org.infinispan.xsite.commands.remote
-
It represents a cross-site request.
- XSiteRequestExternalizer - Class in org.infinispan.xsite.commands.remote
-
Externalizer for
XSiteRequest
and its implementations. - XSiteResource - Class in org.infinispan.rest.resources
-
Handles REST calls for cache and cache manager level X-Site operations
- XSiteResource(InvocationHelper) - Constructor for class org.infinispan.rest.resources.XSiteResource
- XSiteResponse<O> - Interface in org.infinispan.remoting.transport
-
An extension to
CompletionStage
withXSiteResponse.whenCompleted(XSiteResponseCompleted)
. - XSiteResponse.XSiteResponseCompleted - Interface in org.infinispan.remoting.transport
- XSiteResponseImpl<O> - Class in org.infinispan.remoting.transport.impl
-
Default implementation of
XSiteResponse
. - XSiteResponseImpl(TimeService, XSiteBackup) - Constructor for class org.infinispan.remoting.transport.impl.XSiteResponseImpl
- XSiteSetStateTransferModeCommand - Class in org.infinispan.xsite.commands
-
A
CacheRpcCommand
that sets theXSiteStateTransferMode
cluster-wide. - XSiteSetStateTransferModeCommand() - Constructor for class org.infinispan.xsite.commands.XSiteSetStateTransferModeCommand
- XSiteSetStateTransferModeCommand(ByteString) - Constructor for class org.infinispan.xsite.commands.XSiteSetStateTransferModeCommand
- XSiteSetStateTransferModeCommand(ByteString, String, XSiteStateTransferMode) - Constructor for class org.infinispan.xsite.commands.XSiteSetStateTransferModeCommand
- XSiteState - Class in org.infinispan.xsite.statetransfer
-
Represents the state of a single key to be sent to a backup site.
- XSiteState.XSiteStateExternalizer - Class in org.infinispan.xsite.statetransfer
- XSiteStateConsumer - Interface in org.infinispan.xsite.statetransfer
-
It contains the logic needed to consume the state sent from other site.
- XSiteStateConsumerImpl - Class in org.infinispan.xsite.statetransfer
-
It contains the logic needed to consume the state sent from other site.
- XSiteStateConsumerImpl(Configuration) - Constructor for class org.infinispan.xsite.statetransfer.XSiteStateConsumerImpl
- XSiteStateExternalizer() - Constructor for class org.infinispan.xsite.statetransfer.XSiteState.XSiteStateExternalizer
- XSiteStateProvider - Interface in org.infinispan.xsite.statetransfer
-
It contains the logic to send state to another site.
- XSiteStateProviderImpl - Class in org.infinispan.xsite.statetransfer
-
It contains the logic to send state to another site.
- XSiteStateProviderImpl(Configuration) - Constructor for class org.infinispan.xsite.statetransfer.XSiteStateProviderImpl
- XSiteStateProviderState - Interface in org.infinispan.xsite.statetransfer
-
Interface to store the information about a single remote site for
XSiteStateProviderImpl
. - XSiteStatePushCommand - Class in org.infinispan.xsite.statetransfer
-
Wraps the state to be sent to another site
- XSiteStatePushCommand() - Constructor for class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
- XSiteStatePushCommand(ByteString) - Constructor for class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
- XSiteStatePushCommand(ByteString, XSiteState[]) - Constructor for class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
- XSiteStatePushRequest - Class in org.infinispan.xsite.commands.remote
-
Wraps the state to be sent to another site.
- XSiteStatePushRequest() - Constructor for class org.infinispan.xsite.commands.remote.XSiteStatePushRequest
- XSiteStatePushRequest(ByteString, XSiteState[], long) - Constructor for class org.infinispan.xsite.commands.remote.XSiteStatePushRequest
- XSiteStatePushTask - Interface in org.infinispan.xsite.statetransfer
-
Sends local cluster state to remote site.
- XSiteStateTransferCancelSendCommand - Class in org.infinispan.xsite.commands
-
Cancel sending XSite state.
- XSiteStateTransferCancelSendCommand() - Constructor for class org.infinispan.xsite.commands.XSiteStateTransferCancelSendCommand
- XSiteStateTransferCancelSendCommand(ByteString) - Constructor for class org.infinispan.xsite.commands.XSiteStateTransferCancelSendCommand
- XSiteStateTransferCancelSendCommand(ByteString, String) - Constructor for class org.infinispan.xsite.commands.XSiteStateTransferCancelSendCommand
- XSiteStateTransferClearStatusCommand - Class in org.infinispan.xsite.commands
-
Clear XSite state transfer status.
- XSiteStateTransferClearStatusCommand() - Constructor for class org.infinispan.xsite.commands.XSiteStateTransferClearStatusCommand
- XSiteStateTransferClearStatusCommand(ByteString) - Constructor for class org.infinispan.xsite.commands.XSiteStateTransferClearStatusCommand
- XSiteStateTransferCollector - Class in org.infinispan.xsite.statetransfer
-
It collects the acknowledgements sent from local site member to signal the ending of the state sent.
- XSiteStateTransferCollector(Collection<Address>) - Constructor for class org.infinispan.xsite.statetransfer.XSiteStateTransferCollector
- XSiteStateTransferConfiguration - Class in org.infinispan.configuration.cache
-
Configuration needed for State Transfer between different sites.
- XSiteStateTransferConfiguration(AttributeSet) - Constructor for class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- XSiteStateTransferConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Configuration Builder to configure the state transfer between sites.
- XSiteStateTransferConfigurationBuilder(ConfigurationBuilder, BackupConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
- XSiteStateTransferControlRequest - Class in org.infinispan.xsite.commands.remote
-
Controls the start and stop of receiving the cross-site state transfer.
- XSiteStateTransferControlRequest() - Constructor for class org.infinispan.xsite.commands.remote.XSiteStateTransferControlRequest
- XSiteStateTransferControlRequest(ByteString, boolean) - Constructor for class org.infinispan.xsite.commands.remote.XSiteStateTransferControlRequest
- XSiteStateTransferFinishReceiveCommand - Class in org.infinispan.xsite.commands
-
Finish receiving XSite state.
- XSiteStateTransferFinishReceiveCommand() - Constructor for class org.infinispan.xsite.commands.XSiteStateTransferFinishReceiveCommand
- XSiteStateTransferFinishReceiveCommand(ByteString) - Constructor for class org.infinispan.xsite.commands.XSiteStateTransferFinishReceiveCommand
- XSiteStateTransferFinishReceiveCommand(ByteString, String) - Constructor for class org.infinispan.xsite.commands.XSiteStateTransferFinishReceiveCommand
- XSiteStateTransferFinishSendCommand - Class in org.infinispan.xsite.commands
-
Finish sending XSite state.
- XSiteStateTransferFinishSendCommand() - Constructor for class org.infinispan.xsite.commands.XSiteStateTransferFinishSendCommand
- XSiteStateTransferFinishSendCommand(ByteString) - Constructor for class org.infinispan.xsite.commands.XSiteStateTransferFinishSendCommand
- XSiteStateTransferFinishSendCommand(ByteString, String, boolean) - Constructor for class org.infinispan.xsite.commands.XSiteStateTransferFinishSendCommand
- XSiteStateTransferManager - Interface in org.infinispan.xsite.statetransfer
-
It manages the state transfer between sites.
- XSiteStateTransferManagerImpl - Class in org.infinispan.xsite.statetransfer
-
XSiteStateTransferManager
implementation. - XSiteStateTransferManagerImpl(Configuration) - Constructor for class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
- XSiteStateTransferMode - Enum in org.infinispan.configuration.cache
-
Cross site state transfer mode.
- XSiteStateTransferRestartSendingCommand - Class in org.infinispan.xsite.commands
-
Restart sending XSite state.
- XSiteStateTransferRestartSendingCommand() - Constructor for class org.infinispan.xsite.commands.XSiteStateTransferRestartSendingCommand
- XSiteStateTransferRestartSendingCommand(ByteString) - Constructor for class org.infinispan.xsite.commands.XSiteStateTransferRestartSendingCommand
- XSiteStateTransferRestartSendingCommand(ByteString, String, int) - Constructor for class org.infinispan.xsite.commands.XSiteStateTransferRestartSendingCommand
- XSiteStateTransferStartReceiveCommand - Class in org.infinispan.xsite.commands
-
Start receiving XSite state.
- XSiteStateTransferStartReceiveCommand() - Constructor for class org.infinispan.xsite.commands.XSiteStateTransferStartReceiveCommand
- XSiteStateTransferStartReceiveCommand(ByteString) - Constructor for class org.infinispan.xsite.commands.XSiteStateTransferStartReceiveCommand
- XSiteStateTransferStartReceiveCommand(ByteString, String) - Constructor for class org.infinispan.xsite.commands.XSiteStateTransferStartReceiveCommand
- XSiteStateTransferStartSendCommand - Class in org.infinispan.xsite.commands
-
Start send XSite state.
- XSiteStateTransferStartSendCommand() - Constructor for class org.infinispan.xsite.commands.XSiteStateTransferStartSendCommand
- XSiteStateTransferStartSendCommand(ByteString) - Constructor for class org.infinispan.xsite.commands.XSiteStateTransferStartSendCommand
- XSiteStateTransferStartSendCommand(ByteString, String, int) - Constructor for class org.infinispan.xsite.commands.XSiteStateTransferStartSendCommand
- XSiteStateTransferStatusRequestCommand - Class in org.infinispan.xsite.commands
-
Get XSite state transfer status.
- XSiteStateTransferStatusRequestCommand() - Constructor for class org.infinispan.xsite.commands.XSiteStateTransferStatusRequestCommand
- XSiteStateTransferStatusRequestCommand(ByteString) - Constructor for class org.infinispan.xsite.commands.XSiteStateTransferStatusRequestCommand
- XSiteStatusCommand - Class in org.infinispan.xsite.commands
-
Return the status of a
BackupSender
. - XSiteStatusCommand() - Constructor for class org.infinispan.xsite.commands.XSiteStatusCommand
- XSiteStatusCommand(ByteString) - Constructor for class org.infinispan.xsite.commands.XSiteStatusCommand
- XSiteTakeOfflineCommand - Class in org.infinispan.xsite.commands
-
Take a site offline.
- XSiteTakeOfflineCommand() - Constructor for class org.infinispan.xsite.commands.XSiteTakeOfflineCommand
- XSiteTakeOfflineCommand(ByteString) - Constructor for class org.infinispan.xsite.commands.XSiteTakeOfflineCommand
- XSiteTakeOfflineCommand(ByteString, String) - Constructor for class org.infinispan.xsite.commands.XSiteTakeOfflineCommand
- XStreamEngine - Class in org.infinispan.server.core.dataconversion.xml
-
Adapter for the XStream XML Engine with pre-defined configurations.
- XStreamEngine() - Constructor for class org.infinispan.server.core.dataconversion.xml.XStreamEngine
Y
- YamlConfigurationReader - Class in org.infinispan.commons.configuration.io.yaml
- YamlConfigurationReader(Reader, ConfigurationResourceResolver, Properties, PropertyReplacer, NamingStrategy) - Constructor for class org.infinispan.commons.configuration.io.yaml.YamlConfigurationReader
- YamlConfigurationReader.Parsed - Class in org.infinispan.commons.configuration.io.yaml
- YamlConfigurationWriter - Class in org.infinispan.commons.configuration.io.yaml
- YamlConfigurationWriter(Writer, boolean) - Constructor for class org.infinispan.commons.configuration.io.yaml.YamlConfigurationWriter
- YES - Static variable in class org.infinispan.commons.configuration.io.xml.MXParser
Z
- ZERO - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- ZERO_CAPACITY_NODE - Enum constant in enum org.infinispan.configuration.parsing.Attribute
- ZERO_CAPACITY_NODE - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- ZERO_LOCK_ACQUISITION_TIMEOUT - Enum constant in enum org.infinispan.context.Flag
-
Overrides the
LockingConfiguration.lockAcquisitionTimeout(long)
configuration setting by ensuring lock managers use a 0-millisecond lock acquisition timeout. - ZERO_LOCK_ACQUISITION_TIMEOUT - Static variable in class org.infinispan.context.impl.FlagBitSets
- zeroCapacityNode() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- zeroCapacityNode(boolean) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
-
Set the zero capacity node to true to configure a global capacity factor 0.0f for every distributed cache.
- ZLIB - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.CompressionType
- ZSTD - Enum constant in enum org.infinispan.persistence.rocksdb.configuration.CompressionType
_
- _list(Object) - Method in class org.infinispan.io.GridFile
-
Deprecated.
- _listFiles(Object) - Method in class org.infinispan.io.GridFile
-
Deprecated.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
BasicComponentRegistry
instead.